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

AbstractAnalyzerProvider<T extends org.apache.lucene.analysis.Analyzer> - Class in org.elasticsearch.index.analysis
 
AbstractAnalyzerProvider(Index, Settings, String) - Constructor for class org.elasticsearch.index.analysis.AbstractAnalyzerProvider
 
AbstractBindingBuilder<T> - Class in org.elasticsearch.util.inject.internal
Bind a value or constant.
AbstractBindingBuilder(Binder, List<Element>, Object, Key<T>) - Constructor for class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
AbstractComponent - Class in org.elasticsearch.util.component
 
AbstractComponent(Settings) - Constructor for class org.elasticsearch.util.component.AbstractComponent
 
AbstractComponent(Settings, String) - Constructor for class org.elasticsearch.util.component.AbstractComponent
 
AbstractComponent(Settings, Class) - Constructor for class org.elasticsearch.util.component.AbstractComponent
 
AbstractComponent(Settings, String, Class) - Constructor for class org.elasticsearch.util.component.AbstractComponent
 
AbstractComponent(Settings, Class, Class) - Constructor for class org.elasticsearch.util.component.AbstractComponent
 
AbstractComponent(Settings, String, Class, Class) - Constructor for class org.elasticsearch.util.component.AbstractComponent
 
AbstractConcurrentMapFilterCache - Class in org.elasticsearch.index.cache.filter.support
A base concurrent filter cache that accepts the actual cache to use.
AbstractConcurrentMapFilterCache(Index, Settings, ThreadPool, ConcurrentMap<IndexReader, ConcurrentMap<Filter, DocIdSet>>) - Constructor for class org.elasticsearch.index.cache.filter.support.AbstractConcurrentMapFilterCache
 
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.util.logging.support
 
AbstractESLogger(String) - Constructor for class org.elasticsearch.util.logging.support.AbstractESLogger
 
AbstractFsStore<T extends org.apache.lucene.store.Directory> - Class in org.elasticsearch.index.store.fs
 
AbstractFsStore(ShardId, Settings) - Constructor for class org.elasticsearch.index.store.fs.AbstractFsStore
 
AbstractFuture<V> - Class in org.elasticsearch.util.concurrent
An abstract implementation of the Future interface.
AbstractFuture() - Constructor for class org.elasticsearch.util.concurrent.AbstractFuture
 
AbstractIndexComponent - Class in org.elasticsearch.index
 
AbstractIndexComponent(Index, Settings) - Constructor for class org.elasticsearch.index.AbstractIndexComponent
 
AbstractIndexComponent(Index, Settings, String) - Constructor for class org.elasticsearch.index.AbstractIndexComponent
 
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
 
AbstractIterator<T> - Class in org.elasticsearch.util.collect
This class provides a skeletal implementation of the Iterator interface, to make this interface easier to implement for certain types of data sources.
AbstractIterator() - Constructor for class org.elasticsearch.util.collect.AbstractIterator
 
AbstractLifecycleComponent<T> - Class in org.elasticsearch.util.component
 
AbstractLifecycleComponent(Settings) - Constructor for class org.elasticsearch.util.component.AbstractLifecycleComponent
 
AbstractLifecycleComponent(Settings, Class) - Constructor for class org.elasticsearch.util.component.AbstractLifecycleComponent
 
AbstractLifecycleComponent(Settings, Class, Class) - Constructor for class org.elasticsearch.util.component.AbstractLifecycleComponent
 
AbstractLifecycleComponent(Settings, String) - Constructor for class org.elasticsearch.util.component.AbstractLifecycleComponent
 
AbstractLifecycleComponent(Settings, String, Class) - Constructor for class org.elasticsearch.util.component.AbstractLifecycleComponent
 
AbstractLifecycleComponent(Settings, String, Class, Class) - Constructor for class org.elasticsearch.util.component.AbstractLifecycleComponent
 
AbstractListenableActionFuture<T,L> - Class in org.elasticsearch.action.support
 
AbstractListenableActionFuture(boolean, ThreadPool) - Constructor for class org.elasticsearch.action.support.AbstractListenableActionFuture
 
AbstractMatcher<T> - Class in org.elasticsearch.util.inject.matcher
Implements and() and or().
AbstractMatcher() - Constructor for class org.elasticsearch.util.inject.matcher.AbstractMatcher
 
AbstractModule - Class in org.elasticsearch.util.inject
A support class for Modules which reduces repetition and results in a more readable configuration.
AbstractModule() - Constructor for class org.elasticsearch.util.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
 
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
 
AbstractStore<T extends org.apache.lucene.store.Directory> - Class in org.elasticsearch.index.store.support
 
AbstractStore(ShardId, Settings) - Constructor for class org.elasticsearch.index.store.support.AbstractStore
 
AbstractThreadPool - Class in org.elasticsearch.threadpool.support
 
AbstractThreadPool(Settings) - Constructor for class org.elasticsearch.threadpool.support.AbstractThreadPool
 
AbstractThreadPool.FutureCallable<T> - Class in org.elasticsearch.threadpool.support
 
AbstractThreadPool.FutureCallable(Callable<T>, FutureListener<T>) - Constructor for class org.elasticsearch.threadpool.support.AbstractThreadPool.FutureCallable
 
AbstractThreadPool.FutureRunnable<T> - Class in org.elasticsearch.threadpool.support
 
AbstractTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
AbstractTokenFilterFactory(Index, Settings, String) - Constructor for class org.elasticsearch.index.analysis.AbstractTokenFilterFactory
 
AbstractTokenizerFactory - Class in org.elasticsearch.index.analysis
 
AbstractTokenizerFactory(Index, Settings, String) - Constructor for class org.elasticsearch.index.analysis.AbstractTokenizerFactory
 
AbstractXContentGenerator - Class in org.elasticsearch.util.xcontent.support
 
AbstractXContentGenerator() - Constructor for class org.elasticsearch.util.xcontent.support.AbstractXContentGenerator
 
AbstractXContentParser - Class in org.elasticsearch.util.xcontent.support
 
AbstractXContentParser() - Constructor for class org.elasticsearch.util.xcontent.support.AbstractXContentParser
 
accept(String) - Method in class org.elasticsearch.index.mapper.FieldMappersFieldSelector
 
accept(String) - Method in class org.elasticsearch.index.mapper.UidAndSourceFieldSelector
 
accept(String) - Method in class org.elasticsearch.index.mapper.UidFieldSelector
 
acceptScopingVisitor(BindingScopingVisitor<V>) - Method in interface org.elasticsearch.util.inject.Binding
Accepts a scoping visitor.
acceptScopingVisitor(BindingScopingVisitor<V>) - Method in class org.elasticsearch.util.inject.internal.BindingImpl
 
acceptsDocsOutOfOrder() - Method in class org.elasticsearch.util.lucene.docidset.DocIdSetCollector
 
acceptsDocsOutOfOrder() - Method in class org.elasticsearch.util.lucene.Lucene.CountCollector
 
acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in interface org.elasticsearch.util.inject.Binding
Accepts a target visitor.
acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.util.inject.internal.ExposedBindingImpl
 
acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.util.inject.internal.InstanceBindingImpl
 
acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.util.inject.internal.LinkedBindingImpl
 
acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.util.inject.internal.LinkedProviderBindingImpl
 
acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.util.inject.internal.ProviderInstanceBindingImpl
 
acceptTargetVisitor(BindingTargetVisitor<? super T, V>) - Method in class org.elasticsearch.util.inject.internal.UntargettedBindingImpl
 
acceptVisitor(ElementVisitor<V>) - Method in class org.elasticsearch.util.inject.internal.BindingImpl
 
acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.util.inject.internal.PrivateElementsImpl
 
acceptVisitor(BindingScopingVisitor<V>) - Method in class org.elasticsearch.util.inject.internal.Scoping
 
acceptVisitor(ElementVisitor<T>) - Method in interface org.elasticsearch.util.inject.spi.Element
Accepts an element visitor.
acceptVisitor(ElementVisitor<R>) - Method in class org.elasticsearch.util.inject.spi.InjectionRequest
 
acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.util.inject.spi.MembersInjectorLookup
 
acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.util.inject.spi.Message
 
acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.util.inject.spi.ProviderLookup
 
acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.util.inject.spi.ScopeBinding
 
acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.util.inject.spi.StaticInjectionRequest
 
acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.util.inject.spi.TypeConverterBinding
 
acceptVisitor(ElementVisitor<T>) - Method in class org.elasticsearch.util.inject.spi.TypeListenerBinding
 
accessed(long) - Method in class org.elasticsearch.search.internal.SearchContext
 
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.shutdown.TransportNodesShutdownAction
 
accumulateExceptions() - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
 
accumulateExceptions() - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportIndexReplicationPingAction
 
accumulateExceptions() - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportReplicationPingAction
 
accumulateExceptions() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
 
accumulateExceptions() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportIndexGatewaySnapshotAction
 
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
 
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.util.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.util.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.util.TimeValue).
acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetaDataService.CreateIndexResult
 
acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetaDataService.DeleteIndexResult
 
acknowledged() - Method in class org.elasticsearch.cluster.metadata.MetaDataService.PutMappingResult
 
AcquirableResource<T extends Releasable> - Interface in org.elasticsearch.util.concurrent.resource
A wrapper around a resource that can be released.
AcquirableResourceFactory - Class in org.elasticsearch.util.concurrent.resource
 
acquire() - Method in interface org.elasticsearch.util.concurrent.resource.AcquirableResource
Acquires the resource, returning true if it was acquired.
acquire() - Method in class org.elasticsearch.util.concurrent.resource.BlockingAcquirableResource
Acquires the resource, returning true if it was acquired.
acquire() - Method in class org.elasticsearch.util.concurrent.resource.NonBlockingAcquirableResource
 
Action<Request extends ActionRequest,Response extends ActionResponse> - Interface in org.elasticsearch.action
 
action() - Method in class org.elasticsearch.client.transport.action.admin.cluster.health.ClientTransportClusterHealthAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.cluster.node.info.ClientTransportNodesInfoAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.cluster.node.restart.ClientTransportNodesRestartAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.cluster.node.shutdown.ClientTransportNodesShutdownAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.cluster.node.stats.ClientTransportNodesStatsAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.cluster.ping.broadcast.ClientTransportBroadcastPingAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.cluster.ping.replication.ClientTransportReplicationPingAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.cluster.ping.single.ClientTransportSinglePingAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.cluster.state.ClientTransportClusterStateAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.indices.alias.ClientTransportIndicesAliasesAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.indices.cache.clear.ClientTransportClearIndicesCacheAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.indices.create.ClientTransportCreateIndexAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.indices.delete.ClientTransportDeleteIndexAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.indices.flush.ClientTransportFlushAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.indices.gateway.snapshot.ClientTransportGatewaySnapshotAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.indices.mapping.create.ClientTransportPutMappingAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.indices.optimize.ClientTransportOptimizeAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.indices.refresh.ClientTransportRefreshAction
 
action() - Method in class org.elasticsearch.client.transport.action.admin.indices.status.ClientTransportIndicesStatusAction
 
action() - Method in class org.elasticsearch.client.transport.action.count.ClientTransportCountAction
 
action() - Method in class org.elasticsearch.client.transport.action.delete.ClientTransportDeleteAction
 
action() - Method in class org.elasticsearch.client.transport.action.deletebyquery.ClientTransportDeleteByQueryAction
 
action() - Method in class org.elasticsearch.client.transport.action.get.ClientTransportGetAction
 
action() - Method in class org.elasticsearch.client.transport.action.index.ClientTransportIndexAction
 
action() - Method in class org.elasticsearch.client.transport.action.mlt.ClientTransportMoreLikeThisAction
 
action() - Method in class org.elasticsearch.client.transport.action.search.ClientTransportSearchAction
 
action() - Method in class org.elasticsearch.client.transport.action.search.ClientTransportSearchScrollAction
 
action() - Method in class org.elasticsearch.client.transport.action.support.BaseClientTransportAction
 
action() - Method in class org.elasticsearch.client.transport.action.terms.ClientTransportTermsAction
 
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 exception org.elasticsearch.transport.RemoteTransportException
 
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.
ActionNotFoundTransportException - Exception in org.elasticsearch.transport
 
ActionNotFoundTransportException(String) - Constructor for exception org.elasticsearch.transport.ActionNotFoundTransportException
 
ActionRequest - 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
 
Actions - Class in org.elasticsearch.action
 
Actions() - Constructor for class org.elasticsearch.action.Actions
 
ActionTransportRequestHandler<T extends Streamable> - Interface in org.elasticsearch.transport
 
actionType() - Method in class org.elasticsearch.cluster.metadata.AliasAction
 
activateOptions() - Method in class org.elasticsearch.util.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.
activeCount() - Method in class org.elasticsearch.threadpool.ThreadPoolStats
Returns the approximate number of threads that are actively executing tasks.
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
 
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
 
actualFree() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
 
actualSizeToRead() - Method in class org.elasticsearch.util.lucene.store.InputStreamIndexInput
 
actualUsed() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
 
adapt(Runnable) - Static method in class org.elasticsearch.util.concurrent.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 org.elasticsearch.util.concurrent.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 org.elasticsearch.util.concurrent.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
 
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) - Method in class org.elasticsearch.cluster.action.index.NodeMappingCreatedAction
 
add(ClusterStateListener) - Method in interface org.elasticsearch.cluster.ClusterService
 
add(TimeValue, TimeoutClusterStateListener) - Method in interface org.elasticsearch.cluster.ClusterService
 
add(ShardsIterator) - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
 
add(Iterable<ShardsIterator>) - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
 
add(MutableShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
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(TimeValue, TimeoutClusterStateListener) - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
add(FieldMappers) - Method in class org.elasticsearch.index.mapper.FieldMappersFieldSelector
 
add(String, String) - Method in class org.elasticsearch.index.mapper.MapperService
 
add(String) - Method in class org.elasticsearch.index.mapper.MapperService
 
add(DocumentMapper) - Method in class org.elasticsearch.index.mapper.MapperService
 
add(String) - Method in class org.elasticsearch.index.mapper.xcontent.ContentPath
 
add(XContentMapper.Builder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper.Builder
 
add(XContentMapper.Builder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.Builder
 
add(XContentQueryBuilder) - Method in class org.elasticsearch.index.query.xcontent.DisMaxQueryBuilder
Add a sub-query to this disjunction.
add(Translog.Operation) - Method in class org.elasticsearch.index.translog.memory.MemoryTranslog
 
add(Translog.Operation) - Method in interface org.elasticsearch.index.translog.Translog
Adds a create operation to the transaction log.
add(E) - Method in class org.elasticsearch.util.BoundedTreeSet
 
add(E, int) - Method in class org.elasticsearch.util.collect.ConcurrentHashMultiset
Adds a number of occurrences of the specified element to this multiset.
add(E) - Method in class org.elasticsearch.util.collect.ForwardingCollection
 
add(int, E) - Method in class org.elasticsearch.util.collect.ForwardingList
 
add(E) - Method in class org.elasticsearch.util.collect.ForwardingListIterator
 
add(E, int) - Method in class org.elasticsearch.util.collect.ForwardingMultiset
 
add(E) - Method in class org.elasticsearch.util.collect.ImmutableCollection
Guaranteed to throw an exception and leave the collection unmodified.
add(int, E) - Method in class org.elasticsearch.util.collect.ImmutableList
Guaranteed to throw an exception and leave the list unmodified.
add(E) - Method in class org.elasticsearch.util.collect.ImmutableList.Builder
Adds element to the ImmutableList.
add(E...) - Method in class org.elasticsearch.util.collect.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
add(E, int) - Method in class org.elasticsearch.util.collect.ImmutableMultiset
Guaranteed to throw an exception and leave the collection unmodified.
add(E) - Method in class org.elasticsearch.util.collect.ImmutableMultiset.Builder
Adds element to the ImmutableMultiset.
add(E...) - Method in class org.elasticsearch.util.collect.ImmutableMultiset.Builder
Adds each element of elements to the ImmutableMultiset.
add(E) - Method in class org.elasticsearch.util.collect.ImmutableSet.Builder
Adds element to the ImmutableSet.
add(E...) - Method in class org.elasticsearch.util.collect.ImmutableSet.Builder
Adds each element of elements to the ImmutableSet, ignoring duplicate elements (only the first duplicate element is added).
add(E) - Method in class org.elasticsearch.util.collect.ImmutableSortedSet.Builder
Adds element to the ImmutableSortedSet.
add(E...) - Method in class org.elasticsearch.util.collect.ImmutableSortedSet.Builder
Adds each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
add(E, int) - Method in interface org.elasticsearch.util.collect.Multiset
Adds a number of occurrences of an element to this multiset.
add(E) - Method in interface org.elasticsearch.util.collect.Multiset
Adds a single occurrence of the specified element to this multiset.
add(T) - Method in class org.elasticsearch.util.concurrent.ConcurrentSafeArray
 
add(int, T) - Method in class org.elasticsearch.util.concurrent.ConcurrentSafeArray
 
add(long) - Method in class org.elasticsearch.util.concurrent.highscalelib.ConcurrentAutoTable
Add the given value to current counter value.
add(E) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashSet
Add o to the set.
add(Integer) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingSetInt
Add i to the set.
add(int) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingSetInt
Add i to the set.
add(E) - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
Inserts the specified element at the tail of this queue.
add(Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteHashSetDecorator
Inserts a value into the set.
add(Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleHashSetDecorator
Inserts a value into the set.
add(Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatHashSetDecorator
Inserts a value into the set.
add(Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntHashSetDecorator
Inserts a value into the set.
add(Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongHashSetDecorator
Inserts a value into the set.
add(Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortHashSetDecorator
Inserts a value into the set.
add(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Adds val to the end of the list, growing as needed.
add(byte[]) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Adds the values in the array vals to the end of the list, in order.
add(byte[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Adds a subset of the values in the array vals to the end of the list, in order.
add(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteHashSet
Inserts a value into the set.
add(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Adds val to the end of the list, growing as needed.
add(double[]) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Adds the values in the array vals to the end of the list, in order.
add(double[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Adds a subset of the values in the array vals to the end of the list, in order.
add(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Inserts a value into the set.
add(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Adds val to the end of the list, growing as needed.
add(float[]) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Adds the values in the array vals to the end of the list, in order.
add(float[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Adds a subset of the values in the array vals to the end of the list, in order.
add(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatHashSet
Inserts a value into the set.
add(E) - Method in class org.elasticsearch.util.gnu.trove.THashSet
Inserts a value into the set.
add(int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Adds val to the end of the list, growing as needed.
add(int[]) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Adds the values in the array vals to the end of the list, in order.
add(int[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Adds a subset of the values in the array vals to the end of the list, in order.
add(int) - Method in class org.elasticsearch.util.gnu.trove.TIntHashSet
Inserts a value into the set.
add(int, T) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Inserts linkable at index index in the list.
add(T) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Appends linkable to the end of the list.
add(T) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList.IteratorImpl
Insert linkable at the current position of the iterator.
add(long) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Adds val to the end of the list, growing as needed.
add(long[]) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Adds the values in the array vals to the end of the list, in order.
add(long[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Adds a subset of the values in the array vals to the end of the list, in order.
add(long) - Method in class org.elasticsearch.util.gnu.trove.TLongHashSet
Inserts a value into the set.
add(short) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Adds val to the end of the list, growing as needed.
add(short[]) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Adds the values in the array vals to the end of the list, in order.
add(short[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Adds a subset of the values in the array vals to the end of the list, in order.
add(short) - Method in class org.elasticsearch.util.gnu.trove.TShortHashSet
Inserts a value into the set.
add(E) - Method in class org.elasticsearch.util.IdentityHashSet
Adds the specified element to this set if it is not already present.
add(String, Object) - Method in class org.elasticsearch.util.inject.internal.ToStringBuilder
 
add(Fieldable) - Method in class org.elasticsearch.util.lucene.DocumentBuilder
 
add(FieldBuilder) - Method in class org.elasticsearch.util.lucene.DocumentBuilder
 
add(E) - Method in class org.elasticsearch.util.MapBackedSet
 
add(T) - Method in interface org.elasticsearch.util.SafeArray
 
add(int, T) - Method in interface org.elasticsearch.util.SafeArray
 
addAddressType(TransportAddress) - Static method in class org.elasticsearch.util.transport.TransportAddressSerializers
 
addAfter(T, T) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Inserts newElement into the list immediately after current.
addAlias(String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
Adds an alias to the index.
addAll(Collection<? extends E>) - Method in class org.elasticsearch.util.BoundedTreeSet
 
addAll(Collection<? extends E>) - Method in class org.elasticsearch.util.collect.ForwardingCollection
 
addAll(int, Collection<? extends E>) - Method in class org.elasticsearch.util.collect.ForwardingList
 
addAll(Collection<? extends E>) - Method in class org.elasticsearch.util.collect.ImmutableCollection
Guaranteed to throw an exception and leave the collection unmodified.
addAll(int, Collection<? extends E>) - Method in class org.elasticsearch.util.collect.ImmutableList
Guaranteed to throw an exception and leave the list unmodified.
addAll(Iterable<? extends E>) - Method in class org.elasticsearch.util.collect.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
addAll(Iterator<? extends E>) - Method in class org.elasticsearch.util.collect.ImmutableList.Builder
Adds each element of elements to the ImmutableList.
addAll(Iterable<? extends E>) - Method in class org.elasticsearch.util.collect.ImmutableMultiset.Builder
Adds each element of elements to the ImmutableMultiset.
addAll(Iterator<? extends E>) - Method in class org.elasticsearch.util.collect.ImmutableMultiset.Builder
Adds each element of elements to the ImmutableMultiset.
addAll(Iterable<? extends E>) - Method in class org.elasticsearch.util.collect.ImmutableSet.Builder
Adds each element of elements to the ImmutableSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Iterator<? extends E>) - Method in class org.elasticsearch.util.collect.ImmutableSet.Builder
Adds each element of elements to the ImmutableSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Iterable<? extends E>) - Method in class org.elasticsearch.util.collect.ImmutableSortedSet.Builder
Adds each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Iterator<? extends E>) - Method in class org.elasticsearch.util.collect.ImmutableSortedSet.Builder
Adds each element of elements to the ImmutableSortedSet, ignoring duplicate elements (only the first duplicate element is added).
addAll(Collection<T>, Iterable<? extends T>) - Static method in class org.elasticsearch.util.collect.Iterables
Adds all elements in iterable to collection.
addAll(Collection<T>, Iterator<? extends T>) - Static method in class org.elasticsearch.util.collect.Iterators
Adds all elements in iterator to collection.
addAll(byte[]) - Method in class org.elasticsearch.util.gnu.trove.TByteHashSet
Adds all of the elements in array to the set.
addAll(double[]) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Adds all of the elements in array to the set.
addAll(float[]) - Method in class org.elasticsearch.util.gnu.trove.TFloatHashSet
Adds all of the elements in array to the set.
addAll(Collection<? extends E>) - Method in class org.elasticsearch.util.gnu.trove.THashSet
Adds all of the elements in collection to the set.
addAll(int[]) - Method in class org.elasticsearch.util.gnu.trove.TIntHashSet
Adds all of the elements in array to the set.
addAll(long[]) - Method in class org.elasticsearch.util.gnu.trove.TLongHashSet
Adds all of the elements in array to the set.
addAll(short[]) - Method in class org.elasticsearch.util.gnu.trove.TShortHashSet
Adds all of the elements in array to the set.
addBefore(T, T) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Inserts newElement into the list immediately before current.
addBinding(K) - Method in class org.elasticsearch.util.inject.multibindings.MapBinder
Returns a binding builder used to add a new entry in the map.
addBinding() - Method in class org.elasticsearch.util.inject.multibindings.Multibinder
Returns a binding builder used to add a new element in the set.
addChild(PathTrie.TrieNode<T>) - Method in class org.elasticsearch.util.path.PathTrie.TrieNode
 
addConflict(String) - Method in class org.elasticsearch.index.mapper.xcontent.MergeContext
 
addConnectionListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.TransportService
 
addCopies(E, int) - Method in class org.elasticsearch.util.collect.ImmutableMultiset.Builder
Adds a number of occurrences of an element to this ImmutableMultiset.
addCustomNameResolver(String, NetworkService.CustomNameResolver) - Method in class org.elasticsearch.util.network.NetworkService
 
added() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
 
addedMapper() - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
 
addedNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
 
addError(String, Object...) - Method in class org.elasticsearch.util.inject.AbstractModule
 
addError(Throwable) - Method in class org.elasticsearch.util.inject.AbstractModule
 
addError(Message) - Method in class org.elasticsearch.util.inject.AbstractModule
 
addError(String, Object...) - Method in interface org.elasticsearch.util.inject.Binder
Records an error message which will be presented to the user at a later time.
addError(Throwable) - Method in interface org.elasticsearch.util.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.util.inject.Binder
Records an error message to be presented to the user at a later time.
addError(String, Object...) - Method in class org.elasticsearch.util.inject.PrivateModule
 
addError(Throwable) - Method in class org.elasticsearch.util.inject.PrivateModule
 
addError(Message) - Method in class org.elasticsearch.util.inject.PrivateModule
 
addError(String, Object...) - Method in interface org.elasticsearch.util.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.util.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.util.inject.spi.TypeEncounter
Records an error message to be presented to the user at a later time.
addExposureBuilder(ExposureBuilder<?>) - Method in class org.elasticsearch.util.inject.internal.PrivateElementsImpl
 
addFailure(String) - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
 
addFieldMapperListener(FieldMapperListener, boolean) - Method in interface org.elasticsearch.index.mapper.DocumentMapper
Adds a field mapper listener.
addFieldMapperListener(FieldMapperListener, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
addFilter(SettingsFilter.Filter) - Method in class org.elasticsearch.util.settings.SettingsFilter
 
addFirst(T) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Inserts linkable at the head of the list.
addIndexFailure(String, String) - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
 
addIndexShard(IndexShardRoutingTable) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
 
addLast(T) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Adds linkable to the end of the list.
addLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.util.component.AbstractLifecycleComponent
 
addLifecycleListener(LifecycleListener) - Method in interface org.elasticsearch.util.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(IndicesLifecycle.Listener) - Method in interface org.elasticsearch.indices.IndicesLifecycle
Add a listener.
addListener(IndicesLifecycle.Listener) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
 
addMessage(String, Object...) - Method in class org.elasticsearch.util.inject.internal.Errors
 
addMessage(Message) - Method in class org.elasticsearch.util.inject.internal.Errors
 
addOperation() - Method in enum org.elasticsearch.action.ThreadingModel
 
addProcessor(AnalysisModule.AnalysisBinderProcessor) - Method in class org.elasticsearch.index.analysis.AnalysisModule
 
address() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
The address that the node can be communicated with.
address() - Method in class org.elasticsearch.monitor.network.NetworkInfo.Interface
 
address() - Method in exception org.elasticsearch.transport.RemoteTransportException
 
address() - Method in class org.elasticsearch.transport.TransportInfo
 
address() - Method in class org.elasticsearch.util.transport.InetSocketTransportAddress
 
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.util.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.util.transport.TransportAddressSerializers
 
addShard(ShardRouting) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
 
addShard(int, String, boolean, ShardRoutingState) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
 
addShard(ImmutableShardRouting) - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
 
addStringToArray(String[], String) - Static method in class org.elasticsearch.util.Strings
Append the given String to the given String array, returning a new array consisting of the input array contents plus the given String.
addText(String, String, float) - Method in class org.elasticsearch.util.lucene.all.AllEntries
 
addTransportAddress(TransportAddress) - Method in class org.elasticsearch.client.transport.TransportClient
Adds a transport address that will be used to connect to.
addTransportAddress(TransportAddress) - Method in class org.elasticsearch.client.transport.TransportClientNodesService
 
addValidationError(String) - Method in exception org.elasticsearch.action.ActionRequestValidationException
 
addValidationError(String, ActionRequestValidationException) - Static method in class org.elasticsearch.action.Actions
 
adjustOrPutValue(byte, byte, byte) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(byte, double, double) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(byte, float, float) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(byte, int, int) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(byte, long, long) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(byte, short, short) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(double, byte, byte) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(double, double, double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(double, float, float) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(double, int, int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(double, long, long) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(double, short, short) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(float, byte, byte) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(float, double, double) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(float, float, float) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(float, int, int) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(float, long, long) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(float, short, short) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(int, byte, byte) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(int, double, double) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(int, float, float) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(int, int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(int, long, long) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(int, short, short) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(long, byte, byte) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(long, double, double) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(long, float, float) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(long, int, int) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(long, long, long) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(long, short, short) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(K, byte, byte) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(K, double, double) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(K, float, float) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(K, int, int) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(K, long, long) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(K, short, short) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(short, byte, byte) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(short, double, double) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(short, float, float) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(short, int, int) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(short, long, long) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustOrPutValue(short, short, short) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Adjusts the primitive value mapped to the key if the key is present in the map.
adjustValue(byte, byte) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Adjusts the primitive value mapped to key.
adjustValue(byte, double) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Adjusts the primitive value mapped to key.
adjustValue(byte, float) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Adjusts the primitive value mapped to key.
adjustValue(byte, int) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Adjusts the primitive value mapped to key.
adjustValue(byte, long) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Adjusts the primitive value mapped to key.
adjustValue(byte, short) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Adjusts the primitive value mapped to key.
adjustValue(double, byte) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Adjusts the primitive value mapped to key.
adjustValue(double, double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Adjusts the primitive value mapped to key.
adjustValue(double, float) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Adjusts the primitive value mapped to key.
adjustValue(double, int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Adjusts the primitive value mapped to key.
adjustValue(double, long) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Adjusts the primitive value mapped to key.
adjustValue(double, short) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Adjusts the primitive value mapped to key.
adjustValue(float, byte) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Adjusts the primitive value mapped to key.
adjustValue(float, double) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Adjusts the primitive value mapped to key.
adjustValue(float, float) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Adjusts the primitive value mapped to key.
adjustValue(float, int) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Adjusts the primitive value mapped to key.
adjustValue(float, long) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Adjusts the primitive value mapped to key.
adjustValue(float, short) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Adjusts the primitive value mapped to key.
adjustValue(int, byte) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Adjusts the primitive value mapped to key.
adjustValue(int, double) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Adjusts the primitive value mapped to key.
adjustValue(int, float) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Adjusts the primitive value mapped to key.
adjustValue(int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Adjusts the primitive value mapped to key.
adjustValue(int, long) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Adjusts the primitive value mapped to key.
adjustValue(int, short) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Adjusts the primitive value mapped to key.
adjustValue(long, byte) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Adjusts the primitive value mapped to key.
adjustValue(long, double) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Adjusts the primitive value mapped to key.
adjustValue(long, float) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Adjusts the primitive value mapped to key.
adjustValue(long, int) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Adjusts the primitive value mapped to key.
adjustValue(long, long) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Adjusts the primitive value mapped to key.
adjustValue(long, short) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Adjusts the primitive value mapped to key.
adjustValue(K, byte) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Adjusts the primitive value mapped to key.
adjustValue(K, double) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Adjusts the primitive value mapped to key.
adjustValue(K, float) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Adjusts the primitive value mapped to key.
adjustValue(K, int) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Adjusts the primitive value mapped to key.
adjustValue(K, long) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Adjusts the primitive value mapped to key.
adjustValue(K, short) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Adjusts the primitive value mapped to key.
adjustValue(short, byte) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Adjusts the primitive value mapped to key.
adjustValue(short, double) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Adjusts the primitive value mapped to key.
adjustValue(short, float) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Adjusts the primitive value mapped to key.
adjustValue(short, int) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Adjusts the primitive value mapped to key.
adjustValue(short, long) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Adjusts the primitive value mapped to key.
adjustValue(short, short) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Adjusts the primitive value mapped to key.
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() - Method in class org.elasticsearch.util.gnu.trove.TByteByteIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TByteFloatIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TByteIntIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TByteLongIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TByteObjectIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TByteShortIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TFloatByteIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TFloatIntIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TFloatLongIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TFloatShortIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TIntByteIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TIntFloatIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TIntIntIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TIntLongIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TIntObjectIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TIntShortIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TLongByteIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TLongFloatIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TLongIntIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TLongLongIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TLongObjectIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TLongShortIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TObjectByteIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TObjectIntIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TObjectLongIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TObjectShortIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TShortByteIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TShortFloatIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TShortIntIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TShortLongIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TShortObjectIterator
Moves the iterator forward to the next entry in the underlying map.
advance() - Method in class org.elasticsearch.util.gnu.trove.TShortShortIterator
Moves the iterator forward to the next entry in the underlying map.
afterClose() - Method in interface org.elasticsearch.util.component.LifecycleListener
 
afterExecute(Runnable, Throwable) - Method in class org.elasticsearch.util.concurrent.DynamicThreadPoolExecutor
 
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
 
afterInjection(I) - Method in interface org.elasticsearch.util.inject.spi.InjectionListener
Invoked by Guice after it injects the fields and methods of instance.
afterStart() - Method in interface org.elasticsearch.util.component.LifecycleListener
 
afterStop() - Method in interface org.elasticsearch.util.component.LifecycleListener
 
AggregatedDfs - Class in org.elasticsearch.search.dfs
 
AggregatedDfs(ExtTObjectIntHasMap<Term>, long) - Constructor for class org.elasticsearch.search.dfs.AggregatedDfs
 
aggregateDfs(Iterable<DfsSearchResult>) - Method in class org.elasticsearch.search.controller.SearchPhaseController
 
alias() - Method in class org.elasticsearch.cluster.metadata.AliasAction
 
AliasAction - Class in org.elasticsearch.cluster.metadata
 
AliasAction(AliasAction.Type, String, String) - Constructor for class org.elasticsearch.cluster.metadata.AliasAction
 
AliasAction.Type - Enum in org.elasticsearch.cluster.metadata
 
ALIASES - Static variable in class org.elasticsearch.action.TransportActions.Admin.Indices
 
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.node.NodeIndicesAdminClient
 
aliases(IndicesAliasesRequest, ActionListener<IndicesAliasesResponse>) - Method in class org.elasticsearch.client.node.NodeIndicesAdminClient
 
aliases(IndicesAliasesRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
aliases(IndicesAliasesRequest, ActionListener<IndicesAliasesResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
aliases() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
aliases() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
all() - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
all(Iterable<T>, Predicate<? super T>) - Static method in class org.elasticsearch.util.collect.Iterables
Returns true if every element in iterable satisfies the predicate.
all(Iterator<T>, Predicate<? super T>) - Static method in class org.elasticsearch.util.collect.Iterators
Returns true if every element returned by iterator satisfies the given predicate.
ALL_NODES - Static variable in class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
AllAnalyzer - Class in org.elasticsearch.util.lucene.all
An all analyzer.
AllAnalyzer(Analyzer) - Constructor for class org.elasticsearch.util.lucene.all.AllAnalyzer
 
allEntries() - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
 
AllEntries - Class in org.elasticsearch.util.lucene.all
 
AllEntries() - Constructor for class org.elasticsearch.util.lucene.all.AllEntries
 
allEntries() - Method in class org.elasticsearch.util.lucene.all.AllTokenFilter
 
AllEntries.Entry - Class in org.elasticsearch.util.lucene.all
 
AllEntries.Entry(String, CharSequenceReader, float) - Constructor for class org.elasticsearch.util.lucene.all.AllEntries.Entry
 
allFailures() - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
 
allField(XContentAllFieldMapper.Builder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper.Builder
 
AllFieldMapper - Interface in org.elasticsearch.index.mapper
 
allFieldMapper() - Method in interface org.elasticsearch.index.mapper.DocumentMapper
 
allFieldMapper() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
allowLeadingWildcard(boolean) - Method in class org.elasticsearch.index.query.xcontent.FieldQueryBuilder
Should leading wildcards be allowed or not.
allowLeadingWildcard(boolean) - Method in class org.elasticsearch.index.query.xcontent.QueryStringQueryBuilder
Should leading wildcards be allowed or not.
allowsNull(Annotation[]) - Static method in class org.elasticsearch.util.inject.internal.Nullability
 
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 (replicas) for the provided indices grouped (each group is a single element, consisting of the shard).
AllTermQuery - Class in org.elasticsearch.util.lucene.all
A term query that takes all payload boost values into account.
AllTermQuery(Term) - Constructor for class org.elasticsearch.util.lucene.all.AllTermQuery
 
AllTermQuery(Term, boolean) - Constructor for class org.elasticsearch.util.lucene.all.AllTermQuery
 
AllTermQuery.AllTermWeight - Class in org.elasticsearch.util.lucene.all
 
AllTermQuery.AllTermWeight(AllTermQuery, Searcher) - Constructor for class org.elasticsearch.util.lucene.all.AllTermQuery.AllTermWeight
 
AllTermQuery.AllTermWeight.AllTermSpanScorer - Class in org.elasticsearch.util.lucene.all
 
AllTermQuery.AllTermWeight.AllTermSpanScorer(TermSpans, Weight, Similarity, byte[]) - Constructor for class org.elasticsearch.util.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
AllTokenFilter - Class in org.elasticsearch.util.lucene.all
 
allTokenStream(String, AllEntries, Analyzer) - Static method in class org.elasticsearch.util.lucene.all.AllTokenFilter
 
allValidationFailures() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
All the validation failures, including index level validation failures.
AlphaMemoryMonitor - Class in org.elasticsearch.monitor.memory.alpha
 
AlphaMemoryMonitor(Settings, ThreadPool, IndicesMemoryCleaner) - Constructor for class org.elasticsearch.monitor.memory.alpha.AlphaMemoryMonitor
 
alwaysFalse() - Static method in class org.elasticsearch.util.base.Predicates
Returns a predicate that always evaluates to false.
alwaysTrue() - Static method in class org.elasticsearch.util.base.Predicates
Returns a predicate that always evaluates to true.
ambiguousTypeConversion(String, Object, TypeLiteral<?>, MatcherAndConverter, MatcherAndConverter) - Method in class org.elasticsearch.util.inject.internal.Errors
 
AnalysisModule - Class in org.elasticsearch.index.analysis
 
AnalysisModule(Settings) - Constructor for class org.elasticsearch.index.analysis.AnalysisModule
 
AnalysisModule.AnalysisBinderProcessor - Interface in org.elasticsearch.index.analysis
 
AnalysisService - Class in org.elasticsearch.index.analysis
 
AnalysisService(Index) - Constructor for class org.elasticsearch.index.analysis.AnalysisService
 
AnalysisService(Index, Settings, Map<String, AnalyzerProviderFactory>, Map<String, TokenizerFactoryFactory>, Map<String, TokenFilterFactoryFactory>) - Constructor for class org.elasticsearch.index.analysis.AnalysisService
 
analysisService() - Method in class org.elasticsearch.index.mapper.xcontent.XContentTypeParser.ParserContext
 
analyzed() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
analyzed() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
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.engine.Engine.Create
 
analyzer() - Method in class org.elasticsearch.index.engine.Engine.Index
 
analyzer(String) - Method in class org.elasticsearch.index.query.xcontent.FieldQueryBuilder
The optional analyzer used to analyze the query string.
analyzer(String) - Method in class org.elasticsearch.index.query.xcontent.QueryStringQueryBuilder
The optional analyzer used to analyze the query string.
analyzerProvider(String) - Method in class org.elasticsearch.index.analysis.AnalysisService
 
AnalyzerProvider<T extends org.apache.lucene.analysis.Analyzer> - Interface in org.elasticsearch.index.analysis
 
AnalyzerProviderFactory - Interface in org.elasticsearch.index.analysis
 
and(Iterable<? extends Predicate<? super T>>) - Static method in class org.elasticsearch.util.base.Predicates
Returns a predicate that evaluates to true if each of its components evaluates to true.
and(Predicate<? super T>...) - Static method in class org.elasticsearch.util.base.Predicates
Returns a predicate that evaluates to true if each of its components evaluates to true.
and(Predicate<? super T>, Predicate<? super T>) - Static method in class org.elasticsearch.util.base.Predicates
Returns a predicate that evaluates to true if both of its components evaluate to true.
and(BytecodeGen.Visibility) - Method in enum org.elasticsearch.util.inject.internal.BytecodeGen.Visibility
 
and(Matcher<? super T>) - Method in class org.elasticsearch.util.inject.matcher.AbstractMatcher
 
and(Matcher<? super T>) - Method in interface org.elasticsearch.util.inject.matcher.Matcher
Returns a new matcher which returns true if both this and the given matcher return true.
AnnotatedBindingBuilder<T> - Interface in org.elasticsearch.util.inject.binder
See the EDSL examples at Binder.
AnnotatedConstantBindingBuilder - Interface in org.elasticsearch.util.inject.binder
See the EDSL examples at Binder.
AnnotatedElementBuilder - Interface in org.elasticsearch.util.inject.binder
See the EDSL examples at Binder.
annotatedWith(Class<? extends Annotation>) - Method in interface org.elasticsearch.util.inject.binder.AnnotatedBindingBuilder
See the EDSL examples at Binder.
annotatedWith(Annotation) - Method in interface org.elasticsearch.util.inject.binder.AnnotatedBindingBuilder
See the EDSL examples at Binder.
annotatedWith(Class<? extends Annotation>) - Method in interface org.elasticsearch.util.inject.binder.AnnotatedConstantBindingBuilder
See the EDSL examples at Binder.
annotatedWith(Annotation) - Method in interface org.elasticsearch.util.inject.binder.AnnotatedConstantBindingBuilder
See the EDSL examples at Binder.
annotatedWith(Class<? extends Annotation>) - Method in interface org.elasticsearch.util.inject.binder.AnnotatedElementBuilder
See the EDSL examples at Binder.
annotatedWith(Annotation) - Method in interface org.elasticsearch.util.inject.binder.AnnotatedElementBuilder
See the EDSL examples at Binder.
annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.util.inject.internal.BindingBuilder
 
annotatedWith(Annotation) - Method in class org.elasticsearch.util.inject.internal.BindingBuilder
 
annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.util.inject.internal.ConstantBindingBuilderImpl
 
annotatedWith(Annotation) - Method in class org.elasticsearch.util.inject.internal.ConstantBindingBuilderImpl
 
annotatedWith(Class<? extends Annotation>) - Method in class org.elasticsearch.util.inject.internal.ExposureBuilder
 
annotatedWith(Annotation) - Method in class org.elasticsearch.util.inject.internal.ExposureBuilder
 
annotatedWith(Class<? extends Annotation>) - Static method in class org.elasticsearch.util.inject.matcher.Matchers
Returns a matcher which matches elements (methods, classes, etc.) with a given annotation.
annotatedWith(Annotation) - Static method in class org.elasticsearch.util.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.util.inject.internal.AbstractBindingBuilder
Sets the binding to a copy with the specified annotation on the bound key
annotatedWithInternal(Annotation) - Method in class org.elasticsearch.util.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.util.inject.internal.AbstractBindingBuilder
 
Annotations - Class in org.elasticsearch.util.inject.internal
Annotation utilities.
Annotations() - Constructor for class org.elasticsearch.util.inject.internal.Annotations
 
ANSI - Class in org.elasticsearch.util.jline
 
ANSI() - Constructor for class org.elasticsearch.util.jline.ANSI
 
ANSI.Buffer - Class in org.elasticsearch.util.jline
 
ANSI.Buffer() - Constructor for class org.elasticsearch.util.jline.ANSI.Buffer
 
ANSI.Code - Class in org.elasticsearch.util.jline
 
ANSI.Code() - Constructor for class org.elasticsearch.util.jline.ANSI.Code
 
ANSI.Renderer - Class in org.elasticsearch.util.jline
 
ANSI.Renderer() - Constructor for class org.elasticsearch.util.jline.ANSI.Renderer
 
ANSI.Renderer.RenderException - Exception in org.elasticsearch.util.jline
 
ANSI.Renderer.RenderException(String) - Constructor for exception org.elasticsearch.util.jline.ANSI.Renderer.RenderException
 
ANSI.RenderWriter - Class in org.elasticsearch.util.jline
 
ANSI.RenderWriter(OutputStream) - Constructor for class org.elasticsearch.util.jline.ANSI.RenderWriter
 
ANSI.RenderWriter(OutputStream, boolean) - Constructor for class org.elasticsearch.util.jline.ANSI.RenderWriter
 
ANSI.RenderWriter(Writer) - Constructor for class org.elasticsearch.util.jline.ANSI.RenderWriter
 
ANSI.RenderWriter(Writer, boolean) - Constructor for class org.elasticsearch.util.jline.ANSI.RenderWriter
 
any(Iterable<T>, Predicate<? super T>) - Static method in class org.elasticsearch.util.collect.Iterables
Returns true if one or more elements in iterable satisfy the predicate.
any(Iterator<T>, Predicate<? super T>) - Static method in class org.elasticsearch.util.collect.Iterators
Returns true if one or more elements returned by iterator satisfy the given predicate.
any() - Static method in class org.elasticsearch.util.inject.matcher.Matchers
Returns a matcher which matches any input.
append(CharSequence) - Method in class org.elasticsearch.util.io.FastCharArrayWriter
Appends the specified character sequence to this writer.
append(CharSequence, int, int) - Method in class org.elasticsearch.util.io.FastCharArrayWriter
Appends a subsequence of the specified character sequence to this writer.
append(char) - Method in class org.elasticsearch.util.io.FastCharArrayWriter
Appends the specified character to this writer.
append(char) - Method in class org.elasticsearch.util.io.StringBuilderWriter
Append a single character to this Writer.
append(CharSequence) - Method in class org.elasticsearch.util.io.StringBuilderWriter
Append a character sequence to this Writer.
append(CharSequence, int, int) - Method in class org.elasticsearch.util.io.StringBuilderWriter
Append a portion of a character sequence to the StringBuilder.
append(String) - Method in class org.elasticsearch.util.jline.ANSI.Buffer
 
append(Object) - Method in class org.elasticsearch.util.jline.ANSI.Buffer
 
appendTo(A, Iterable<?>) - Method in class org.elasticsearch.util.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to appendable.
appendTo(A, Object[]) - Method in class org.elasticsearch.util.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to appendable.
appendTo(A, Object, Object, Object...) - Method in class org.elasticsearch.util.base.Joiner
Appends to appendable the string representation of each of the remaining arguments.
appendTo(StringBuilder, Iterable<?>) - Method in class org.elasticsearch.util.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to builder.
appendTo(StringBuilder, Object[]) - Method in class org.elasticsearch.util.base.Joiner
Appends the string representation of each of parts, using the previously configured separator between each, to builder.
appendTo(StringBuilder, Object, Object, Object...) - Method in class org.elasticsearch.util.base.Joiner
Appends to builder the string representation of each of the remaining arguments.
appendTo(A, Map<?, ?>) - Method in class org.elasticsearch.util.base.Joiner.MapJoiner
Appends the string representation of each entry of map, using the previously configured separator and key-value separator, to appendable.
appendTo(StringBuilder, Map<?, ?>) - Method in class org.elasticsearch.util.base.Joiner.MapJoiner
Appends the string representation of each entry of map, using the previously configured separator and key-value separator, to builder.
apply(F) - Method in interface org.elasticsearch.util.base.Function
Applies the function to an object of type F, resulting in an object of type T.
apply(T) - Method in interface org.elasticsearch.util.base.Predicate
Applies this predicate to the given object.
applyFailedShards(ClusterState, Iterable<? extends ShardRouting>) - Method in class org.elasticsearch.cluster.routing.strategy.DefaultShardsRoutingStrategy
 
applyFailedShards(ClusterState, Iterable<? extends ShardRouting>) - Method in interface org.elasticsearch.cluster.routing.strategy.ShardsRoutingStrategy
Applies the failed shards.
applyRelativePath(String, String) - Static method in class org.elasticsearch.util.Strings
Apply the given relative path to the given path, assuming standard Java folder separation (i.e.
applyStartedShards(ClusterState, Iterable<? extends ShardRouting>) - Method in class org.elasticsearch.cluster.routing.strategy.DefaultShardsRoutingStrategy
 
applyStartedShards(ClusterState, Iterable<? extends ShardRouting>) - Method in interface org.elasticsearch.cluster.routing.strategy.ShardsRoutingStrategy
Applies the started shards.
applyTo(Binder) - Method in class org.elasticsearch.util.inject.internal.ExposedBindingImpl
 
applyTo(Binder) - Method in class org.elasticsearch.util.inject.internal.InstanceBindingImpl
 
applyTo(Binder) - Method in class org.elasticsearch.util.inject.internal.LinkedBindingImpl
 
applyTo(Binder) - Method in class org.elasticsearch.util.inject.internal.LinkedProviderBindingImpl
 
applyTo(Binder) - Method in class org.elasticsearch.util.inject.internal.PrivateElementsImpl
 
applyTo(Binder) - Method in class org.elasticsearch.util.inject.internal.ProviderInstanceBindingImpl
 
applyTo(ScopedBindingBuilder) - Method in class org.elasticsearch.util.inject.internal.Scoping
 
applyTo(Binder) - Method in class org.elasticsearch.util.inject.internal.UntargettedBindingImpl
 
applyTo(Binder) - Method in interface org.elasticsearch.util.inject.spi.Element
Writes this module element to the given binder (optional operation).
applyTo(Binder) - Method in interface org.elasticsearch.util.inject.spi.ExposedBinding
Unsupported.
applyTo(Binder) - Method in class org.elasticsearch.util.inject.spi.InjectionRequest
 
applyTo(Binder) - Method in class org.elasticsearch.util.inject.spi.MembersInjectorLookup
 
applyTo(Binder) - Method in class org.elasticsearch.util.inject.spi.Message
 
applyTo(Binder) - Method in class org.elasticsearch.util.inject.spi.ProviderLookup
 
applyTo(Binder) - Method in class org.elasticsearch.util.inject.spi.ScopeBinding
 
applyTo(Binder) - Method in class org.elasticsearch.util.inject.spi.StaticInjectionRequest
 
applyTo(Binder) - Method in class org.elasticsearch.util.inject.spi.TypeConverterBinding
 
applyTo(Binder) - Method in class org.elasticsearch.util.inject.spi.TypeListenerBinding
 
ArabicAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
ArabicAnalyzerProvider(Index, Settings, 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
 
areEqual() - Method in interface org.elasticsearch.util.collect.MapDifference
Returns true if there are no differences between the two maps; that is, if the maps are equal.
array(String, String...) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
array(String, Object...) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
ArrayListMultimap<K,V> - Class in org.elasticsearch.util.collect
Implementation of Multimap that uses an ArrayList to store the values for a given key.
arrayOf(Type) - Static method in class org.elasticsearch.util.inject.util.Types
Returns an array type whose elements are all instances of componentType.
arrayToCommaDelimitedString(Object[]) - Static method in class org.elasticsearch.util.Strings
Convenience method to return a String array as a CSV String.
arrayToDelimitedString(Object[], String) - Static method in class org.elasticsearch.util.Strings
Convenience method to return a String array as a delimited (e.g.
arrive() - Method in class org.elasticsearch.util.concurrent.jsr166y.Phaser
Arrives at the barrier, but does not wait for others.
arriveAndAwaitAdvance() - Method in class org.elasticsearch.util.concurrent.jsr166y.Phaser
Arrives at the barrier and awaits others.
arriveAndDeregister() - Method in class org.elasticsearch.util.concurrent.jsr166y.Phaser
Arrives at the barrier and deregisters from it without waiting for others.
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.util.inject.binder.ScopedBindingBuilder
Instructs the Injector to eagerly initialize this singleton-scoped binding upon creation.
asEagerSingleton() - Method in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
asEnumeration(Iterator<T>) - Static method in class org.elasticsearch.util.collect.Iterators
Adapts an Iterator to the Enumeration interface.
asList(E, E[]) - Static method in class org.elasticsearch.util.collect.Lists
Returns an unmodifiable list containing the specified first element and backed by the specified array of additional elements.
asList(E, E, E[]) - Static method in class org.elasticsearch.util.collect.Lists
Returns an unmodifiable list containing the specified first and second element, and backed by the specified array of additional elements.
asMap() - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
asMap() - Method in class org.elasticsearch.util.collect.ImmutableMultimap
Returns an immutable map that associates each key with its corresponding values in the multimap.
asMap() - Method in class org.elasticsearch.util.collect.LinkedListMultimap
 
asMap() - Method in interface org.elasticsearch.util.collect.ListMultimap
Returns a map view that associates each key with the corresponding values in the multimap.
asMap() - Method in interface org.elasticsearch.util.collect.Multimap
Returns a map view that associates each key with the corresponding values in the multimap.
asMap() - Method in interface org.elasticsearch.util.collect.SetMultimap
Returns a map view that associates each key with the corresponding values in the multimap.
asMap() - Method in interface org.elasticsearch.util.collect.SortedSetMultimap
Returns a map view that associates each key with the corresponding values in the multimap.
asMap() - Method in class org.elasticsearch.util.collect.TreeMultimap
Returns a map view that associates each key with the corresponding values in the multimap.
assignedToNode() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
assignedToNode() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
 
assignToNode(String) - Method in class org.elasticsearch.cluster.routing.MutableShardRouting
 
Assisted - Annotation Type in org.elasticsearch.util.inject.assistedinject
Annotates an injected parameter or field whose value comes from an argument to a factory method.
AssistedInject - Annotation Type in org.elasticsearch.util.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.
AsynchronousComputationException - Exception in org.elasticsearch.util.collect
Wraps an exception that occured during a computation in a different thread.
AsynchronousComputationException(Throwable) - Constructor for exception org.elasticsearch.util.collect.AsynchronousComputationException
Creates a new instance with the given cause.
AsynchronousComputationException - Exception in org.elasticsearch.util.inject.internal
Wraps an exception that occured during a computation in a different thread.
AsynchronousComputationException(Throwable) - Constructor for exception org.elasticsearch.util.inject.internal.AsynchronousComputationException
 
atoi(byte[]) - Static method in class org.elasticsearch.util.Bytes
 
atol(byte[]) - Static method in class org.elasticsearch.util.Bytes
 
attemptFails() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
attrib(int) - Method in class org.elasticsearch.util.jline.ANSI.Buffer
 
attrib(String, int) - Method in class org.elasticsearch.util.jline.ANSI.Buffer
 
attrib(String, String) - Method in class org.elasticsearch.util.jline.ANSI.Buffer
 
attributes() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
The attributes of the node.
attributes() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
The node attributes.
autoClear - Variable in class org.elasticsearch.util.jline.ANSI.Buffer
 
available() - Method in class org.elasticsearch.util.io.FastByteArrayInputStream
Returns the number of remaining bytes that can be read (or skipped over) from this input stream.
await() - Method in class org.elasticsearch.util.concurrent.ThreadBarrier
await(long, TimeUnit) - Method in class org.elasticsearch.util.concurrent.ThreadBarrier
awaitAdvance(int) - Method in class org.elasticsearch.util.concurrent.jsr166y.Phaser
Awaits the phase of the barrier to advance from the given phase value, returning immediately if the current phase of the barrier is not equal to the given phase value or this barrier is terminated.
awaitAdvanceInterruptibly(int) - Method in class org.elasticsearch.util.concurrent.jsr166y.Phaser
Awaits the phase of the barrier to advance from the given phase value, throwing InterruptedException if interrupted while waiting, or returning immediately if the current phase of the barrier is not equal to the given phase value or this barrier is terminated.
awaitAdvanceInterruptibly(int, long, TimeUnit) - Method in class org.elasticsearch.util.concurrent.jsr166y.Phaser
Awaits the phase of the barrier 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 of the barrier is not equal to the given phase value or this barrier is terminated.
awaitTermination(long, TimeUnit) - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
awaitTermination(long, TimeUnit) - Method in interface org.elasticsearch.threadpool.ThreadPool
 
awaitTermination(long, TimeUnit) - Method in class org.elasticsearch.util.concurrent.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.util.concurrent.ScalingThreadPoolExecutor
 

B

backupsShards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
BalancedSegmentMergePolicy - Class in org.elasticsearch.index.merge.policy
Merge policy that tries to balance not doing large segment merges with not accumulating too many segments in the index, to provide for better performance in near real-time setting.
BalancedSegmentMergePolicy(IndexWriter) - Constructor for class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy
 
BalancedSegmentMergePolicy.MergePolicyParams - Class in org.elasticsearch.index.merge.policy
 
BalancedSegmentMergePolicy.MergePolicyParams() - Constructor for class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy.MergePolicyParams
 
BalancedSegmentMergePolicyProvider - Class in org.elasticsearch.index.merge.policy
 
BalancedSegmentMergePolicyProvider(Store) - Constructor for class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicyProvider
 
Base64 - Class in org.elasticsearch.util
Encodes and decodes to and from Base64 notation.
Base64.InputStream - Class in org.elasticsearch.util
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.util.Base64.InputStream
Constructs a Base64.InputStream in DECODE mode.
Base64.InputStream(InputStream, int) - Constructor for class org.elasticsearch.util.Base64.InputStream
Constructs a Base64.InputStream in either ENCODE or DECODE mode.
Base64.OutputStream - Class in org.elasticsearch.util
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.util.Base64.OutputStream
Constructs a Base64.OutputStream in ENCODE mode.
Base64.OutputStream(OutputStream, int) - Constructor for class org.elasticsearch.util.Base64.OutputStream
Constructs a Base64.OutputStream in either ENCODE or DECODE mode.
BaseAction<Request extends ActionRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.support
 
BaseAction(Settings) - Constructor for class org.elasticsearch.action.support.BaseAction
 
BaseClientTransportAction<Request extends ActionRequest,Response extends ActionResponse> - Class in org.elasticsearch.client.transport.action.support
 
BaseClientTransportAction(Settings, TransportService, Class<Response>) - Constructor for class org.elasticsearch.client.transport.action.support.BaseClientTransportAction
 
BaseFilterBuilder - Class in org.elasticsearch.index.query.xcontent
 
BaseFilterBuilder() - Constructor for class org.elasticsearch.index.query.xcontent.BaseFilterBuilder
 
BaseQueryBuilder - Class in org.elasticsearch.index.query.xcontent
 
BaseQueryBuilder() - Constructor for class org.elasticsearch.index.query.xcontent.BaseQueryBuilder
 
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
 
beforeClose() - Method in interface org.elasticsearch.util.component.LifecycleListener
 
beforeExecute(Thread, Runnable) - Method in class org.elasticsearch.util.concurrent.DynamicThreadPoolExecutor
 
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(IndexShard, boolean) - Method in class org.elasticsearch.indices.IndicesLifecycle.Listener
Called before the index shard gets closed.
beforeIndexShardClosed(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.count.CountRequest
 
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.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.
beforeStart() - Method in interface org.elasticsearch.util.component.LifecycleListener
 
beforeStop() - Method in interface org.elasticsearch.util.component.LifecycleListener
 
beforeVersion(int, int) - Method in class org.elasticsearch.util.lucene.versioned.ConcurrentVersionedMap
 
beforeVersion(int, int) - Method in class org.elasticsearch.util.lucene.versioned.ConcurrentVersionedMapLong
 
beforeVersion(int, int) - Method in class org.elasticsearch.util.lucene.versioned.NativeVersionedMap
 
beforeVersion(int, int) - Method in interface org.elasticsearch.util.lucene.versioned.VersionedMap
Returns true if the versionToCheck is smaller than the current version associated with the key.
BEGIN_TOKEN - Static variable in class org.elasticsearch.util.jline.ANSI.Renderer
 
beginDownload() - Method in interface org.elasticsearch.util.http.HttpDownloadHelper.DownloadProgress
begin a download
beginDownload() - Method in class org.elasticsearch.util.http.HttpDownloadHelper.NullProgress
begin a download
beginDownload() - Method in class org.elasticsearch.util.http.HttpDownloadHelper.VerboseProgress
begin a download
BG_BLACK - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
BG_BLUE - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
BG_CYAN - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
BG_GREEN - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
BG_MAGENTA - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
BG_RED - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
BG_WHITE - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
BG_YELLOW - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
BiMap<K,V> - Interface in org.elasticsearch.util.collect
A bimap (or "bidirectional map") is a map that preserves the uniqueness of its values as well as that of its keys.
binaryField(String) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
binarySearch(List<? extends T>, T) - Method in class org.elasticsearch.util.collect.Ordering
Searches sortedList for key using the binary search algorithm.
binarySearch(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Performs a binary search for value in the entire list.
binarySearch(byte, int, int) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Performs a binary search for value in the specified range.
binarySearch(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Performs a binary search for value in the entire list.
binarySearch(double, int, int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Performs a binary search for value in the specified range.
binarySearch(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Performs a binary search for value in the entire list.
binarySearch(float, int, int) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Performs a binary search for value in the specified range.
binarySearch(int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Performs a binary search for value in the entire list.
binarySearch(int, int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Performs a binary search for value in the specified range.
binarySearch(long) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Performs a binary search for value in the entire list.
binarySearch(long, int, int) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Performs a binary search for value in the specified range.
binarySearch(short) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Performs a binary search for value in the entire list.
binarySearch(short, int, int) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Performs a binary search for value in the specified range.
binaryValue() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
binaryValue() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
binaryValue() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
BinaryXContentBuilder - Class in org.elasticsearch.util.xcontent.builder
 
BinaryXContentBuilder(XContent) - Constructor for class org.elasticsearch.util.xcontent.builder.BinaryXContentBuilder
 
bind(Key<T>) - Method in class org.elasticsearch.util.inject.AbstractModule
 
bind(TypeLiteral<T>) - Method in class org.elasticsearch.util.inject.AbstractModule
 
bind(Class<T>) - Method in class org.elasticsearch.util.inject.AbstractModule
 
bind(Key<T>) - Method in interface org.elasticsearch.util.inject.Binder
See the EDSL examples at Binder.
bind(TypeLiteral<T>) - Method in interface org.elasticsearch.util.inject.Binder
See the EDSL examples at Binder.
bind(Class<T>) - Method in interface org.elasticsearch.util.inject.Binder
See the EDSL examples at Binder.
bind(Key<T>) - Method in class org.elasticsearch.util.inject.PrivateModule
 
bind(TypeLiteral<T>) - Method in class org.elasticsearch.util.inject.PrivateModule
 
bind(Class<T>) - Method in class org.elasticsearch.util.inject.PrivateModule
 
bindConstant() - Method in class org.elasticsearch.util.inject.AbstractModule
 
bindConstant() - Method in interface org.elasticsearch.util.inject.Binder
See the EDSL examples at Binder.
bindConstant() - Method in class org.elasticsearch.util.inject.PrivateModule
 
binder() - Method in class org.elasticsearch.util.inject.AbstractModule
Gets direct access to the underlying Binder.
Binder - Interface in org.elasticsearch.util.inject
Collects configuration information (primarily bindings) which will be used to create an Injector.
binder - Variable in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
binder() - Method in class org.elasticsearch.util.inject.PrivateModule
Returns the current binder.
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.util.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.util.inject.internal.AbstractBindingBuilder
 
bindingAlreadySet(Key<?>, Object) - Method in class org.elasticsearch.util.inject.internal.Errors
 
BindingAnnotation - Annotation Type in org.elasticsearch.util.inject
Annotates annotations which are used for binding.
BindingBuilder<T> - Class in org.elasticsearch.util.inject.internal
Bind a non-constant key.
BindingBuilder(Binder, List<Element>, Object, Key<T>) - Constructor for class org.elasticsearch.util.inject.internal.BindingBuilder
 
BindingImpl<T> - Class in org.elasticsearch.util.inject.internal
 
BindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping) - Constructor for class org.elasticsearch.util.inject.internal.BindingImpl
 
BindingImpl(Object, Key<T>, Scoping) - Constructor for class org.elasticsearch.util.inject.internal.BindingImpl
 
BindingScopingVisitor<V> - Interface in org.elasticsearch.util.inject.spi
Visits each of the strategies used to scope an injection.
BindingTargetVisitor<T,V> - Interface in org.elasticsearch.util.inject.spi
Visits each of the strategies used to find an instance to satisfy an injection.
bindingToProvider() - Method in class org.elasticsearch.util.inject.internal.Errors
 
bindListener(Matcher<? super TypeLiteral<?>>, TypeListener) - Method in class org.elasticsearch.util.inject.AbstractModule
 
bindListener(Matcher<? super TypeLiteral<?>>, TypeListener) - Method in interface org.elasticsearch.util.inject.Binder
Registers a listener for injectable types.
bindListener(Matcher<? super TypeLiteral<?>>, TypeListener) - Method in class org.elasticsearch.util.inject.PrivateModule
 
bindProperties(Binder, Map<String, String>) - Static method in class org.elasticsearch.util.inject.name.Names
Creates a constant binding to @Named(key) for each entry in properties.
bindProperties(Binder, Properties) - Static method in class org.elasticsearch.util.inject.name.Names
Creates a constant binding to @Named(key) for each property.
bindScope(Class<? extends Annotation>, Scope) - Method in class org.elasticsearch.util.inject.AbstractModule
 
bindScope(Class<? extends Annotation>, Scope) - Method in interface org.elasticsearch.util.inject.Binder
Binds a scope to an annotation.
bindScope(Class<? extends Annotation>, Scope) - Method in class org.elasticsearch.util.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
 
BLACK - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
BLINK - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
block() - Method in interface org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool.ManagedBlocker
Possibly blocks the current thread, for example waiting for a lock or condition.
BLOCK_TYPE_COMPRESSED - Static variable in class org.elasticsearch.util.io.compression.lzf.LZFChunk
 
BLOCK_TYPE_NON_COMPRESSED - Static variable in class org.elasticsearch.util.io.compression.lzf.LZFChunk
 
BlockingAcquirableResource<T extends Releasable> - Class in org.elasticsearch.util.concurrent.resource
A wrapper around a resource that can be released.
BlockingAcquirableResource(T) - Constructor for class org.elasticsearch.util.concurrent.resource.BlockingAcquirableResource
 
BlockingThreadPool - Class in org.elasticsearch.threadpool.blocking
A thread pool that will will block the execute if all threads are busy.
BlockingThreadPool() - Constructor for class org.elasticsearch.threadpool.blocking.BlockingThreadPool
 
BlockingThreadPool(Settings) - Constructor for class org.elasticsearch.threadpool.blocking.BlockingThreadPool
 
BlockingThreadPoolManagement - Class in org.elasticsearch.threadpool.blocking
 
BlockingThreadPoolManagement(ThreadPool) - Constructor for class org.elasticsearch.threadpool.blocking.BlockingThreadPoolManagement
 
BlockingThreadPoolModule - Class in org.elasticsearch.threadpool.blocking
 
BlockingThreadPoolModule() - Constructor for class org.elasticsearch.threadpool.blocking.BlockingThreadPoolModule
 
BLUE - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
BOLD - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
booleanField(String) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
Booleans - Class in org.elasticsearch.util
 
Booleans() - Constructor for class org.elasticsearch.util.Booleans
 
BooleanStreamable - Class in org.elasticsearch.util.io
 
BooleanStreamable() - Constructor for class org.elasticsearch.util.io.BooleanStreamable
 
BooleanStreamable(boolean) - Constructor for class org.elasticsearch.util.io.BooleanStreamable
 
booleanValue() - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentParser
 
booleanValue() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
boolFilter() - Static method in class org.elasticsearch.index.query.xcontent.FilterBuilders
 
BoolFilterBuilder - Class in org.elasticsearch.index.query.xcontent
A filter that matches documents matching boolean combinations of other filters.
BoolFilterBuilder() - Constructor for class org.elasticsearch.index.query.xcontent.BoolFilterBuilder
 
BoolFilterParser - Class in org.elasticsearch.index.query.xcontent
 
BoolFilterParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.BoolFilterParser
 
boolQuery() - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A Query that matches documents matching boolean combinations of other queries.
BoolQueryBuilder - Class in org.elasticsearch.index.query.xcontent
A Query that matches documents matching boolean combinations of other queries.
BoolQueryBuilder() - Constructor for class org.elasticsearch.index.query.xcontent.BoolQueryBuilder
 
BoolQueryParser - Class in org.elasticsearch.index.query.xcontent
 
BoolQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.BoolQueryParser
 
boost() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
boost(float) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper.Builder
 
boost - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
boost() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
boost - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
boost(float) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
BOOST - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Defaults
 
boost(float) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.OpenBuilder
 
boost(String) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
boost(float) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.Builder
 
boost(float) - Method in class org.elasticsearch.index.query.xcontent.BoolQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.xcontent.ConstantScoreQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.xcontent.DisMaxQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.xcontent.FieldQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.xcontent.FilteredQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisFieldQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.xcontent.MatchAllQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.xcontent.MoreLikeThisFieldQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.xcontent.MoreLikeThisQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.xcontent.PrefixQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.xcontent.QueryStringQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.xcontent.SpanFirstQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.xcontent.SpanNearQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.xcontent.SpanNotQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.xcontent.SpanOrQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.xcontent.SpanTermQueryBuilder
 
boost(float) - Method in class org.elasticsearch.index.query.xcontent.TermQueryBuilder
Sets the boost for this query.
boost(float) - Method in class org.elasticsearch.index.query.xcontent.WildcardQueryBuilder
Sets the boost for this query.
boost() - Method in class org.elasticsearch.util.lucene.all.AllEntries.Entry
 
boost(float) - Method in class org.elasticsearch.util.lucene.DocumentBuilder
 
boost(float) - Method in class org.elasticsearch.util.lucene.FieldBuilder
 
boostFactor(float) - Method in class org.elasticsearch.index.query.xcontent.CustomBoostFactorQueryBuilder
Sets the boost factor for this query.
boostField(XContentBoostFieldMapper.Builder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper.Builder
 
BoostFieldMapper - Interface in org.elasticsearch.index.mapper
A field mapper that allows to control the boosting of a parsed document.
boostMapper() - Method in interface org.elasticsearch.index.mapper.DocumentMapper
 
boostMapper() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
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.xcontent.MoreLikeThisFieldQueryBuilder
Sets the boost factor to use when boosting terms.
boostTerms(float) - Method in class org.elasticsearch.index.query.xcontent.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
 
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
 
boundAddress() - Method in class org.elasticsearch.util.transport.BoundTransportAddress
 
BoundedTreeSet<E> - Class in org.elasticsearch.util
 
BoundedTreeSet(int) - Constructor for class org.elasticsearch.util.BoundedTreeSet
 
BoundedTreeSet(Comparator<? super E>, int) - Constructor for class org.elasticsearch.util.BoundedTreeSet
 
BoundTransportAddress - Class in org.elasticsearch.util.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.util.transport.BoundTransportAddress
 
BrazilianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
BrazilianAnalyzerProvider(Index, Settings, 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
 
BROADCAST - Static variable in class org.elasticsearch.action.TransportActions.Admin.Cluster.Ping
 
BroadcastOperationRequest - Class in org.elasticsearch.action.support.broadcast
 
BroadcastOperationRequest() - Constructor for class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
BroadcastOperationRequest(String[], 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.
BroadcastPingRequest - Class in org.elasticsearch.action.admin.cluster.ping.broadcast
 
BroadcastPingRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.ping.broadcast.BroadcastPingRequest
 
BroadcastPingResponse - Class in org.elasticsearch.action.admin.cluster.ping.broadcast
 
BroadcastPingResponse(int, int, int, List<ShardOperationFailedException>) - Constructor for class org.elasticsearch.action.admin.cluster.ping.broadcast.BroadcastPingResponse
 
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
 
BroadcastShardPingRequest - Class in org.elasticsearch.action.admin.cluster.ping.broadcast
 
BroadcastShardPingRequest(String, int) - Constructor for class org.elasticsearch.action.admin.cluster.ping.broadcast.BroadcastShardPingRequest
 
BroadcastShardPingResponse - Class in org.elasticsearch.action.admin.cluster.ping.broadcast
 
BroadcastShardPingResponse(String, int) - Constructor for class org.elasticsearch.action.admin.cluster.ping.broadcast.BroadcastShardPingResponse
 
buf - Variable in class org.elasticsearch.util.io.FastByteArrayInputStream
An array of bytes that was provided by the creator of the stream.
buf - Variable in class org.elasticsearch.util.io.FastByteArrayOutputStream
The buffer where data is stored.
buf - Variable in class org.elasticsearch.util.io.FastCharArrayReader
The character buffer.
buf - Variable in class org.elasticsearch.util.io.FastCharArrayWriter
The buffer where data is stored.
buf - Variable in class org.elasticsearch.util.io.stream.BytesStreamInput
 
buf - Variable in class org.elasticsearch.util.io.stream.BytesStreamOutput
The buffer where data is stored.
BUFFER_SIZE - Static variable in class org.elasticsearch.util.io.Streams
 
bufferSize() - Method in class org.elasticsearch.index.store.memory.HeapDirectory
 
bufferSizeInBytes() - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectory
 
build() - Method in class org.elasticsearch.cluster.ClusterState.Builder
 
build() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.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(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBinaryFieldMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper.Builder
 
build() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper.Builder
 
build(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper.Builder
 
build() - Method in class org.elasticsearch.node.NodeBuilder
Builds the node without starting it.
build() - Method in class org.elasticsearch.util.collect.ImmutableBiMap.Builder
Returns a newly-created immutable bimap.
build() - Method in class org.elasticsearch.util.collect.ImmutableClassToInstanceMap.Builder
Returns a new immutable class-to-instance map containing the entries provided to this builder.
build() - Method in class org.elasticsearch.util.collect.ImmutableList.Builder
Returns a newly-created ImmutableList based on the contents of the Builder.
build() - Method in class org.elasticsearch.util.collect.ImmutableListMultimap.Builder
Returns a newly-created immutable multimap.
build() - Method in class org.elasticsearch.util.collect.ImmutableMap.Builder
Returns a newly-created immutable map.
build() - Method in class org.elasticsearch.util.collect.ImmutableMultimap.Builder
Returns a newly-created immutable multimap.
build() - Method in class org.elasticsearch.util.collect.ImmutableMultiset.Builder
Returns a newly-created ImmutableMultiset based on the contents of the Builder.
build() - Method in class org.elasticsearch.util.collect.ImmutableSet.Builder
Returns a newly-created ImmutableSet based on the contents of the Builder.
build() - Method in class org.elasticsearch.util.collect.ImmutableSetMultimap.Builder
Returns a newly-created immutable set multimap.
build() - Method in class org.elasticsearch.util.collect.ImmutableSortedMap.Builder
Returns a newly-created immutable sorted map.
build() - Method in class org.elasticsearch.util.collect.ImmutableSortedSet.Builder
Returns a newly-created ImmutableSortedSet based on the contents of the Builder and its comparator.
build() - Method in class org.elasticsearch.util.lucene.DocumentBuilder
 
build() - Method in class org.elasticsearch.util.lucene.FieldBuilder
 
build() - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Builds a Settings (underlying uses ImmutableSettings) based on everything set on this builder.
build() - Method in interface org.elasticsearch.util.settings.Settings.Builder
Builds the settings.
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.index.query.xcontent.BaseQueryBuilder
 
buildAsBytes(XContentType) - Method in class org.elasticsearch.index.query.xcontent.BaseQueryBuilder
 
buildAsBytes() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
 
buildAsBytes(XContentType) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
 
buildAsUnsafeBytes() - Method in interface org.elasticsearch.index.query.QueryBuilder
 
buildAsUnsafeBytes(XContentType) - Method in interface org.elasticsearch.index.query.QueryBuilder
 
buildAsUnsafeBytes() - Method in class org.elasticsearch.index.query.xcontent.BaseQueryBuilder
 
buildAsUnsafeBytes(XContentType) - Method in class org.elasticsearch.index.query.xcontent.BaseQueryBuilder
 
buildAsUnsafeBytes() - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
 
buildAsUnsafeBytes(XContentType) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
 
buildBroadcastShardsHeader(XContentBuilder, BroadcastOperationResponse) - Static method in class org.elasticsearch.rest.action.support.RestActions
 
buildCommonNodesAttributes(Settings) - Static method in class org.elasticsearch.cluster.node.DiscoveryNode
 
buildConflicts() - Method in class org.elasticsearch.index.mapper.xcontent.MergeContext
 
buildDynamicNodes() - Method in class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
 
builder - Variable in class org.elasticsearch.index.mapper.xcontent.XContentMapper.Builder
 
builder() - Static method in class org.elasticsearch.util.collect.ImmutableBiMap
Returns a new builder.
builder() - Static method in class org.elasticsearch.util.collect.ImmutableClassToInstanceMap
Returns a new builder.
builder() - Static method in class org.elasticsearch.util.collect.ImmutableList
Returns a new builder.
builder() - Static method in class org.elasticsearch.util.collect.ImmutableListMultimap
Returns a new builder.
builder() - Static method in class org.elasticsearch.util.collect.ImmutableMap
Returns a new builder.
builder() - Static method in class org.elasticsearch.util.collect.ImmutableMultimap
Returns a new builder.
builder() - Static method in class org.elasticsearch.util.collect.ImmutableMultiset
Returns a new builder.
builder() - Static method in class org.elasticsearch.util.collect.ImmutableSet
Returns a new builder.
builder() - Static method in class org.elasticsearch.util.collect.ImmutableSetMultimap
Returns a new ImmutableSetMultimap.Builder.
builder - Variable in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
buildFilterMap() - Method in class org.elasticsearch.index.cache.filter.support.AbstractConcurrentMapFilterCache
 
buildFullName(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
buildIndexGroupName(Index) - Static method in class org.elasticsearch.index.IndexServiceManagement
 
buildIndexName(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
buildNames(XContentMapper.BuilderContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
buildScrollId(SearchType, Iterable<? extends SearchPhaseResult>) - Static method in class org.elasticsearch.action.search.type.TransportSearchHelper
 
buildScrollId(String, Iterable<? extends SearchPhaseResult>) - Static method in class org.elasticsearch.action.search.type.TransportSearchHelper
 
buildShardFailures(Collection<ShardSearchFailure>, TransportSearchCache) - Static method in class org.elasticsearch.action.search.type.TransportSearchHelper
Builds the shard failures, and releases the cache (meaning this should only be called once!).
buildShardFailures() - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
Builds the shard failures, and releases the cache (meaning this should only be called once!).
buildShardGroupName(ShardId) - Static method in class org.elasticsearch.index.shard.IndexShardManagement
 
buildSource() - Method in interface org.elasticsearch.index.mapper.DocumentMapper
Generates the source of the mapper based on the current mappings.
buildSource() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
buildSwitchDirectoryIfNeeded(Directory) - Method in class org.elasticsearch.index.store.fs.AbstractFsStore
 
buildText() - Method in class org.elasticsearch.util.lucene.all.AllEntries
 
bulkRegister(int) - Method in class org.elasticsearch.util.concurrent.jsr166y.Phaser
Adds the given number of new unarrived parties to this phaser.
BYTE_V - Static variable in class org.elasticsearch.util.io.compression.lzf.LZFChunk
 
BYTE_Z - Static variable in class org.elasticsearch.util.io.compression.lzf.LZFChunk
 
ByteArrayDataInputStream - Class in org.elasticsearch.util.io
 
ByteArrayDataInputStream(byte[]) - Constructor for class org.elasticsearch.util.io.ByteArrayDataInputStream
Creates a DataInputStream that uses the specified underlying InputStream.
ByteArrayDataOutputStream - Class in org.elasticsearch.util.io
 
ByteArrayDataOutputStream() - Constructor for class org.elasticsearch.util.io.ByteArrayDataOutputStream
 
ByteArrayDataOutputStream.Cached - Class in org.elasticsearch.util.io
A thread local based cache of ByteArrayDataOutputStream.
ByteArrayDataOutputStream.Cached() - Constructor for class org.elasticsearch.util.io.ByteArrayDataOutputStream.Cached
 
ByteBufferDirectory - Class in org.elasticsearch.index.store.memory
A memory based directory that uses ByteBuffer in order to store the directory content.
ByteBufferDirectory(int, int, boolean, boolean) - Constructor for class org.elasticsearch.index.store.memory.ByteBufferDirectory
Constructs a new byte buffer directory.
ByteBufferFile - Class in org.elasticsearch.index.store.memory
 
ByteBufferFile(ByteBufferDirectory) - Constructor for class org.elasticsearch.index.store.memory.ByteBufferFile
 
ByteBufferIndexInput - Class in org.elasticsearch.index.store.memory
 
ByteBufferIndexInput(ByteBufferDirectory, ByteBufferFile) - Constructor for class org.elasticsearch.index.store.memory.ByteBufferIndexInput
 
ByteBufferIndexOutput - Class in org.elasticsearch.index.store.memory
 
ByteBufferIndexOutput(ByteBufferDirectory, ByteBufferFile) - Constructor for class org.elasticsearch.index.store.memory.ByteBufferIndexOutput
 
ByteBufferStore - Class in org.elasticsearch.index.store.memory
 
ByteBufferStore(ShardId, Settings) - Constructor for class org.elasticsearch.index.store.memory.ByteBufferStore
 
BytecodeGen - Class in org.elasticsearch.util.inject.internal
Utility methods for runtime code generation and class loading.
BytecodeGen() - Constructor for class org.elasticsearch.util.inject.internal.BytecodeGen
 
BytecodeGen.Visibility - Enum in org.elasticsearch.util.inject.internal
The required visibility of a user's class from a Guice-generated class.
Bytes - Class in org.elasticsearch.util
 
Bytes() - Constructor for class org.elasticsearch.util.Bytes
 
bytes() - Method in class org.elasticsearch.util.SizeValue
 
BytesStreamInput - Class in org.elasticsearch.util.io.stream
 
BytesStreamInput(byte[]) - Constructor for class org.elasticsearch.util.io.stream.BytesStreamInput
 
BytesStreamInput(byte[], int, int) - Constructor for class org.elasticsearch.util.io.stream.BytesStreamInput
 
BytesStreamOutput - Class in org.elasticsearch.util.io.stream
 
BytesStreamOutput() - Constructor for class org.elasticsearch.util.io.stream.BytesStreamOutput
 
BytesStreamOutput(int) - Constructor for class org.elasticsearch.util.io.stream.BytesStreamOutput
 
BytesStreamOutput.Cached - Class in org.elasticsearch.util.io.stream
A thread local based cache of BytesStreamOutput.
BytesStreamOutput.Cached() - Constructor for class org.elasticsearch.util.io.stream.BytesStreamOutput.Cached
 
bytesToDouble(byte[]) - Static method in class org.elasticsearch.util.Numbers
Converts a byte array to double.
bytesToFloat(byte[]) - Static method in class org.elasticsearch.util.Numbers
Converts a byte array to float.
bytesToInt(byte[]) - Static method in class org.elasticsearch.util.Numbers
Converts a byte array to an int.
bytesToLong(byte[]) - Static method in class org.elasticsearch.util.Numbers
Converts a byte array to a long.
bytesToShort(byte[]) - Static method in class org.elasticsearch.util.Numbers
Converts a byte array to an short.

C

cache(Filter) - Method in interface org.elasticsearch.index.cache.filter.FilterCache
 
cache(Filter) - Method in class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
cache(Filter) - Method in class org.elasticsearch.index.cache.filter.support.AbstractConcurrentMapFilterCache
 
cache() - Method in interface org.elasticsearch.index.service.IndexService
 
cache() - Method in class org.elasticsearch.index.service.InternalIndexService
 
cacheable(IndexReader, DocIdSet) - Static method in class org.elasticsearch.util.lucene.docidset.DocIdSets
Returns a cacheable version of the doc id set (might be the same instance provided as a parameter).
cached() - Static method in class org.elasticsearch.util.io.ByteArrayDataOutputStream.Cached
Returns the cached thread local byte strean, with its internal stream cleared.
cached() - Static method in class org.elasticsearch.util.io.FastByteArrayOutputStream.Cached
Returns the cached thread local byte stream, with its internal stream cleared.
cached() - Static method in class org.elasticsearch.util.io.FastCharArrayWriter.Cached
Returns the cached thread local byte stream, with its internal stream cleared.
cached() - Static method in class org.elasticsearch.util.io.stream.BytesStreamOutput.Cached
Returns the cached thread local byte stream, with its internal stream cleared.
cached(StreamInput) - Static method in class org.elasticsearch.util.io.stream.HandlesStreamInput.Cached
Returns the cached thread local byte stream, with its internal stream cleared.
cached() - Static method in class org.elasticsearch.util.io.StringBuilderWriter.Cached
Returns the cached thread local writer, with its internal StringBuilder cleared.
cachedBytes - Static variable in class org.elasticsearch.util.Bytes
 
CachedDfSource - Class in org.elasticsearch.search.dfs
 
CachedDfSource(AggregatedDfs, Similarity) - Constructor for class org.elasticsearch.search.dfs.CachedDfSource
 
cachedHandles() - Static method in class org.elasticsearch.util.io.stream.BytesStreamOutput.Cached
 
cachedStringBuilder - Variable in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
CachedThreadPool - Class in org.elasticsearch.threadpool.cached
A thread pool that will create an unbounded number of threads.
CachedThreadPool() - Constructor for class org.elasticsearch.threadpool.cached.CachedThreadPool
 
CachedThreadPool(Settings) - Constructor for class org.elasticsearch.threadpool.cached.CachedThreadPool
 
CachedThreadPoolManagement - Class in org.elasticsearch.threadpool.cached
 
CachedThreadPoolManagement(ThreadPool) - Constructor for class org.elasticsearch.threadpool.cached.CachedThreadPoolManagement
 
CachedThreadPoolModule - Class in org.elasticsearch.threadpool.cached
 
CachedThreadPoolModule() - Constructor for class org.elasticsearch.threadpool.cached.CachedThreadPoolModule
 
cacheFilterIfPossible(Filter) - Method in class org.elasticsearch.index.query.xcontent.QueryParseContext
 
cacheSize() - Method in class org.elasticsearch.index.store.memory.HeapDirectory
 
cacheSize() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
cacheSizeInBytes() - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectory
 
calculateGrownCapacity() - Method in class org.elasticsearch.util.gnu.trove.THash
 
call() - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool.FutureCallable
 
canAllocate(MetaData, RoutingTable) - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
canAllocate(ShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
canAllocate(MutableShardRouting) - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
cancel(boolean) - Method in class org.elasticsearch.util.concurrent.AbstractFuture
 
cancel() - Method in class org.elasticsearch.util.concurrent.AbstractFuture
Subclasses should invoke this method to mark the future as cancelled.
cancel(boolean) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Attempts to cancel execution of this task.
cancel() - Method in interface org.elasticsearch.util.timer.Timeout
Cancels the TimerTask associated with this handle.
cancelRelocation() - Method in class org.elasticsearch.cluster.routing.MutableShardRouting
 
canMoveToClosed() - Method in class org.elasticsearch.util.component.Lifecycle
 
canMoveToStarted() - Method in class org.elasticsearch.util.component.Lifecycle
 
canMoveToStopped() - Method in class org.elasticsearch.util.component.Lifecycle
 
cannotBindToGuiceType(String) - Method in class org.elasticsearch.util.inject.internal.Errors
 
cannotInjectInnerClass(Class<?>) - Method in class org.elasticsearch.util.inject.internal.Errors
 
cannotInjectRawMembersInjector() - Method in class org.elasticsearch.util.inject.internal.Errors
 
cannotInjectRawProvider() - Method in class org.elasticsearch.util.inject.internal.Errors
 
cannotInjectRawTypeLiteral() - Method in class org.elasticsearch.util.inject.internal.Errors
 
cannotInjectTypeLiteralOf(Type) - Method in class org.elasticsearch.util.inject.internal.Errors
 
cannotSatisfyCircularDependency(Class<?>) - Method in class org.elasticsearch.util.inject.internal.Errors
 
canonicalize(Type) - Static method in class org.elasticsearch.util.inject.internal.MoreTypes
Returns a type that is functionally equal but not necessarily equal according to Object.equals().
capacity() - Method in class org.elasticsearch.util.gnu.trove.THash
 
capacity() - Method in class org.elasticsearch.util.gnu.trove.TObjectHash
 
capacity() - Method in class org.elasticsearch.util.gnu.trove.TPrimitiveHash
Returns the capacity of the hash table.
capitalize(String) - Static method in class org.elasticsearch.util.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.util.Strings
Capitalize a String, changing the first letter to upper case as per Character.toUpperCase(char).
cause(String) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
The cause for this index creation.
cause() - Method in class org.elasticsearch.monitor.dump.AbstractDump
 
cause() - Method in interface org.elasticsearch.monitor.dump.Dump
 
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.
ChannelBufferStreamInput - Class in org.elasticsearch.transport.netty
A Netty ChannelBuffer based StreamInput.
ChannelBufferStreamInput(ChannelBuffer) - Constructor for class org.elasticsearch.transport.netty.ChannelBufferStreamInput
 
charAt(int) - Method in class org.elasticsearch.util.io.FastStringReader
 
charAt(int) - Method in class org.elasticsearch.util.lucene.analysis.CharSequenceTermAttribute
 
CharSequenceReader - Class in org.elasticsearch.util.io
 
CharSequenceReader() - Constructor for class org.elasticsearch.util.io.CharSequenceReader
 
CharSequenceTermAttribute - Class in org.elasticsearch.util.lucene.analysis
 
CharSequenceTermAttribute(TermAttribute) - Constructor for class org.elasticsearch.util.lucene.analysis.CharSequenceTermAttribute
 
checkArgument(boolean) - Static method in class org.elasticsearch.util.base.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.util.base.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.util.base.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean) - Static method in class org.elasticsearch.util.inject.internal.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.util.inject.internal.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.util.inject.internal.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean) - Static method in class org.elasticsearch.util.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.util.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.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkContentsNotNull(T) - Static method in class org.elasticsearch.util.inject.internal.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.util.inject.internal.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.util.inject.internal.Preconditions
Ensures that an Iterable object passed as a parameter to the calling method is not null and contains no null elements.
checkContentsNotNull(T) - Static method in class org.elasticsearch.util.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.util.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.util.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.util.base.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.util.base.Preconditions
Ensures that index specifies a valid element in an array, list or string of size size.
checkElementIndex(int, int) - Static method in class org.elasticsearch.util.inject.internal.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.util.inject.internal.Preconditions
Ensures that index specifies a valid element in an array, list or string of size size.
checkElementIndex(int, int) - Static method in class org.elasticsearch.util.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.util.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.util.inject.internal.Annotations
Adds an error if there is a misplaced annotations on type.
checkForNull(T, Object, Dependency<?>) - Method in class org.elasticsearch.util.inject.internal.Errors
Returns value if it is non-null allowed to be null.
checkNotAnnotated() - Method in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
checkNotAnnotated() - Method in class org.elasticsearch.util.inject.internal.ExposureBuilder
 
checkNotNull(T) - Static method in class org.elasticsearch.util.base.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.util.base.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.util.base.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T) - Static method in class org.elasticsearch.util.inject.internal.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.util.inject.internal.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.util.inject.internal.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotNull(T) - Static method in class org.elasticsearch.util.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.util.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.util.Preconditions
Ensures that an object reference passed as a parameter to the calling method is not null.
checkNotScoped() - Method in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
checkNotTargetted() - Method in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
checkPositionIndex(int, int) - Static method in class org.elasticsearch.util.base.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.util.base.Preconditions
Ensures that index specifies a valid position in an array, list or string of size size.
checkPositionIndex(int, int) - Static method in class org.elasticsearch.util.inject.internal.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.util.inject.internal.Preconditions
Ensures that index specifies a valid position in an array, list or string of size size.
checkPositionIndex(int, int) - Static method in class org.elasticsearch.util.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.util.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.util.base.Preconditions
Ensures that start and end specify a valid positions in an array, list or string of size size, and are in order.
checkPositionIndexes(int, int, int) - Static method in class org.elasticsearch.util.inject.internal.Preconditions
Ensures that start and end specify a valid positions in an array, list or string of size size, and are in order.
checkPositionIndexes(int, int, int) - Static method in class org.elasticsearch.util.Preconditions
Ensures that start and end specify a valid positions in an array, list or string of size size, and are in order.
checkState(boolean) - Static method in class org.elasticsearch.util.base.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.util.base.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.util.base.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) - Static method in class org.elasticsearch.util.inject.internal.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.util.inject.internal.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.util.inject.internal.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) - Static method in class org.elasticsearch.util.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.util.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.util.Preconditions
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the calling method.
checksum(Directory, String) - Static method in class org.elasticsearch.util.lucene.Directories
Computes the checksum of the given file name with the directory.
checksum(IndexInput) - Static method in class org.elasticsearch.util.lucene.Directories
Computes the checksum of the content represented by the provided index input.
childBindingAlreadySet(Key<?>) - Method in class org.elasticsearch.util.inject.internal.Errors
 
ChineseAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
ChineseAnalyzerProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ChineseAnalyzerProvider
 
ChunkEncoder - Class in org.elasticsearch.util.io.compression.lzf
Class that handles actual encoding of individual chunks.
ChunkEncoder(int) - Constructor for class org.elasticsearch.util.io.compression.lzf.ChunkEncoder
 
CjkAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
CjkAnalyzerProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CjkAnalyzerProvider
 
Classes - Class in org.elasticsearch.util
 
classLoader(ClassLoader) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Sets the class loader associated with the settings built.
classPath() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
ClassToInstanceMap<B> - Interface in org.elasticsearch.util.collect
A map, each entry of which maps a Java raw type to an instance of that type.
clause(XContentSpanQueryBuilder) - Method in class org.elasticsearch.index.query.xcontent.SpanNearQueryBuilder
 
clause(XContentSpanQueryBuilder) - Method in class org.elasticsearch.index.query.xcontent.SpanOrQueryBuilder
 
clauses() - Method in class org.elasticsearch.index.query.xcontent.BoolQueryBuilder
A list of the current clauses.
CLEAN_SUPPORTED - Static variable in class org.elasticsearch.index.store.memory.ByteBufferDirectory
 
cleaned() - Method in class org.elasticsearch.indices.IndicesMemoryCleaner.MemoryCleanResult
 
cleaned() - Method in class org.elasticsearch.indices.IndicesMemoryCleaner.TranslogCleanResult
 
cleanedShards() - Method in class org.elasticsearch.indices.IndicesMemoryCleaner.MemoryCleanResult
 
cleanedShards() - Method in class org.elasticsearch.indices.IndicesMemoryCleaner.TranslogCleanResult
 
cleanMemory(long, SizeValue) - Method in class org.elasticsearch.indices.IndicesMemoryCleaner
Checks if memory needs to be cleaned and cleans it.
cleanPath(String) - Static method in class org.elasticsearch.util.Strings
Normalize the path by suppressing sequences like "path/.." and inner simple dots.
cleanShard(int) - Method in interface org.elasticsearch.index.service.IndexService
Cleans the shard locally, does not touch the gateway!.
cleanShard(int) - Method in class org.elasticsearch.index.service.InternalIndexService
 
cleanTranslog(int) - Method in class org.elasticsearch.indices.IndicesMemoryCleaner
 
CLEAR - Static variable in class org.elasticsearch.action.TransportActions.Admin.Indices.Cache
 
clear() - Method in interface org.elasticsearch.index.cache.filter.FilterCache
 
clear() - Method in class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
clear() - Method in class org.elasticsearch.index.cache.filter.support.AbstractConcurrentMapFilterCache
 
clear() - Method in class org.elasticsearch.index.cache.IndexCache
 
clear() - Method in class org.elasticsearch.util.collect.ForwardingCollection
 
clear() - Method in class org.elasticsearch.util.collect.ForwardingMap
 
clear() - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
clear() - Method in class org.elasticsearch.util.collect.ImmutableCollection
Guaranteed to throw an exception and leave the collection unmodified.
clear() - Method in class org.elasticsearch.util.collect.ImmutableMap
Guaranteed to throw an exception and leave the map unmodified.
clear() - Method in class org.elasticsearch.util.collect.ImmutableMultimap
Guaranteed to throw an exception and leave the multimap unmodified.
clear() - Method in class org.elasticsearch.util.collect.LinkedListMultimap
 
clear() - Method in interface org.elasticsearch.util.collect.Multimap
Removes all key-value pairs from the multimap.
clear() - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
clear() - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Removes all of the mappings from this map.
clear() - Method in class org.elasticsearch.util.concurrent.ConcurrentSafeArray
 
clear() - Method in class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
clear() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Removes all of the mappings from this map.
clear() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Removes all of the mappings from this map.
clear() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashSet
Empty the set.
clear() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Removes all of the mappings from this map.
clear() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Removes all of the mappings from this map.
clear() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingSetInt
Empty the bitvector.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteHashSetDecorator
Empties the set.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleHashSetDecorator
Empties the set.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatHashSetDecorator
Empties the set.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntHashSetDecorator
Empties the set.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongHashSetDecorator
Empties the set.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortHashSetDecorator
Empties the set.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Flushes the internal state of the list, resetting the capacity to the default.
clear(int) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Flushes the internal state of the list, setting the capacity of the empty list to capacity.
clear() - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TByteHashSet
Empties the set.
clear() - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TByteStack
Clears the stack, reseting its capacity to the default.
clear() - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Flushes the internal state of the list, resetting the capacity to the default.
clear(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Flushes the internal state of the list, setting the capacity of the empty list to capacity.
clear() - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Empties the set.
clear() - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TDoubleStack
Clears the stack, reseting its capacity to the default.
clear() - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Flushes the internal state of the list, resetting the capacity to the default.
clear(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Flushes the internal state of the list, setting the capacity of the empty list to capacity.
clear() - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TFloatHashSet
Empties the set.
clear() - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TFloatStack
Clears the stack, reseting its capacity to the default.
clear() - Method in class org.elasticsearch.util.gnu.trove.THash
Empties the collection.
clear() - Method in class org.elasticsearch.util.gnu.trove.THashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.THashSet
Empties the set.
clear() - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Flushes the internal state of the list, resetting the capacity to the default.
clear(int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Flushes the internal state of the list, setting the capacity of the empty list to capacity.
clear() - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TIntHashSet
Empties the set.
clear() - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TIntStack
Clears the stack, reseting its capacity to the default.
clear() - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Empties the list.
clear() - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Flushes the internal state of the list, resetting the capacity to the default.
clear(int) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Flushes the internal state of the list, setting the capacity of the empty list to capacity.
clear() - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TLongHashSet
Empties the set.
clear() - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TLongStack
Clears the stack, reseting its capacity to the default.
clear() - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Flushes the internal state of the list, resetting the capacity to the default.
clear(int) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Flushes the internal state of the list, setting the capacity of the empty list to capacity.
clear() - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TShortHashSet
Empties the set.
clear() - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Empties the map.
clear() - Method in class org.elasticsearch.util.gnu.trove.TShortStack
Clears the stack, reseting its capacity to the default.
clear() - Method in class org.elasticsearch.util.IdentityHashSet
Removes all of the elements from this set.
clear() - Method in class org.elasticsearch.util.jline.ANSI.Buffer
 
clear() - Method in class org.elasticsearch.util.lucene.all.AllEntries
 
clear() - Method in class org.elasticsearch.util.lucene.versioned.ConcurrentVersionedMap
 
clear() - Method in class org.elasticsearch.util.lucene.versioned.ConcurrentVersionedMapLong
 
clear() - Method in class org.elasticsearch.util.lucene.versioned.NativeVersionedMap
 
clear() - Method in interface org.elasticsearch.util.lucene.versioned.VersionedMap
Clears the map.
clear() - Method in class org.elasticsearch.util.MapBackedSet
 
clear() - Method in interface org.elasticsearch.util.SafeArray
 
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.node.NodeIndicesAdminClient
 
clearCache(ClearIndicesCacheRequest, ActionListener<ClearIndicesCacheResponse>) - Method in class org.elasticsearch.client.node.NodeIndicesAdminClient
 
clearCache(ClearIndicesCacheRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
clearCache(ClearIndicesCacheRequest, ActionListener<ClearIndicesCacheResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
clearIndicesCache(String...) - Static method in class org.elasticsearch.client.Requests
Creates a clean indices cache request.
ClearIndicesCacheRequest - Class in org.elasticsearch.action.admin.indices.cache.clear
 
ClearIndicesCacheRequest(String...) - Constructor for class org.elasticsearch.action.admin.indices.cache.clear.ClearIndicesCacheRequest
 
ClearIndicesCacheResponse - Class in org.elasticsearch.action.admin.indices.cache.clear
The response of a refresh action.
clearReferencesThreadLocals() - Static method in class org.elasticsearch.util.ThreadLocals
 
clearUnreferenced() - Method in interface org.elasticsearch.index.cache.filter.FilterCache
Clears unreferenced filters.
clearUnreferenced() - Method in class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
clearUnreferenced() - Method in class org.elasticsearch.index.cache.filter.support.AbstractConcurrentMapFilterCache
 
clearUnreferenced() - Method in class org.elasticsearch.index.cache.IndexCache
 
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() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
Is the node a client node or not.
ClientTransportAction<Request extends ActionRequest,Response extends ActionResponse> - Interface in org.elasticsearch.client.transport.action
 
ClientTransportActionModule - Class in org.elasticsearch.client.transport.action
 
ClientTransportActionModule() - Constructor for class org.elasticsearch.client.transport.action.ClientTransportActionModule
 
ClientTransportBroadcastPingAction - Class in org.elasticsearch.client.transport.action.admin.cluster.ping.broadcast
 
ClientTransportBroadcastPingAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.cluster.ping.broadcast.ClientTransportBroadcastPingAction
 
ClientTransportClearIndicesCacheAction - Class in org.elasticsearch.client.transport.action.admin.indices.cache.clear
 
ClientTransportClearIndicesCacheAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.indices.cache.clear.ClientTransportClearIndicesCacheAction
 
ClientTransportClusterHealthAction - Class in org.elasticsearch.client.transport.action.admin.cluster.health
 
ClientTransportClusterHealthAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.cluster.health.ClientTransportClusterHealthAction
 
ClientTransportClusterStateAction - Class in org.elasticsearch.client.transport.action.admin.cluster.state
 
ClientTransportClusterStateAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.cluster.state.ClientTransportClusterStateAction
 
ClientTransportCountAction - Class in org.elasticsearch.client.transport.action.count
 
ClientTransportCountAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.count.ClientTransportCountAction
 
ClientTransportCreateIndexAction - Class in org.elasticsearch.client.transport.action.admin.indices.create
 
ClientTransportCreateIndexAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.indices.create.ClientTransportCreateIndexAction
 
ClientTransportDeleteAction - Class in org.elasticsearch.client.transport.action.delete
 
ClientTransportDeleteAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.delete.ClientTransportDeleteAction
 
ClientTransportDeleteByQueryAction - Class in org.elasticsearch.client.transport.action.deletebyquery
 
ClientTransportDeleteByQueryAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.deletebyquery.ClientTransportDeleteByQueryAction
 
ClientTransportDeleteIndexAction - Class in org.elasticsearch.client.transport.action.admin.indices.delete
 
ClientTransportDeleteIndexAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.indices.delete.ClientTransportDeleteIndexAction
 
ClientTransportFlushAction - Class in org.elasticsearch.client.transport.action.admin.indices.flush
 
ClientTransportFlushAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.indices.flush.ClientTransportFlushAction
 
ClientTransportGatewaySnapshotAction - Class in org.elasticsearch.client.transport.action.admin.indices.gateway.snapshot
 
ClientTransportGatewaySnapshotAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.indices.gateway.snapshot.ClientTransportGatewaySnapshotAction
 
ClientTransportGetAction - Class in org.elasticsearch.client.transport.action.get
 
ClientTransportGetAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.get.ClientTransportGetAction
 
ClientTransportIndexAction - Class in org.elasticsearch.client.transport.action.index
 
ClientTransportIndexAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.index.ClientTransportIndexAction
 
ClientTransportIndicesAliasesAction - Class in org.elasticsearch.client.transport.action.admin.indices.alias
 
ClientTransportIndicesAliasesAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.indices.alias.ClientTransportIndicesAliasesAction
 
ClientTransportIndicesStatusAction - Class in org.elasticsearch.client.transport.action.admin.indices.status
 
ClientTransportIndicesStatusAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.indices.status.ClientTransportIndicesStatusAction
 
ClientTransportModule - Class in org.elasticsearch.client.transport
 
ClientTransportModule() - Constructor for class org.elasticsearch.client.transport.ClientTransportModule
 
ClientTransportMoreLikeThisAction - Class in org.elasticsearch.client.transport.action.mlt
 
ClientTransportMoreLikeThisAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.mlt.ClientTransportMoreLikeThisAction
 
ClientTransportNodesInfoAction - Class in org.elasticsearch.client.transport.action.admin.cluster.node.info
 
ClientTransportNodesInfoAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.cluster.node.info.ClientTransportNodesInfoAction
 
ClientTransportNodesRestartAction - Class in org.elasticsearch.client.transport.action.admin.cluster.node.restart
 
ClientTransportNodesRestartAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.cluster.node.restart.ClientTransportNodesRestartAction
 
ClientTransportNodesShutdownAction - Class in org.elasticsearch.client.transport.action.admin.cluster.node.shutdown
 
ClientTransportNodesShutdownAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.cluster.node.shutdown.ClientTransportNodesShutdownAction
 
ClientTransportNodesStatsAction - Class in org.elasticsearch.client.transport.action.admin.cluster.node.stats
 
ClientTransportNodesStatsAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.cluster.node.stats.ClientTransportNodesStatsAction
 
ClientTransportOptimizeAction - Class in org.elasticsearch.client.transport.action.admin.indices.optimize
 
ClientTransportOptimizeAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.indices.optimize.ClientTransportOptimizeAction
 
ClientTransportPutMappingAction - Class in org.elasticsearch.client.transport.action.admin.indices.mapping.create
 
ClientTransportPutMappingAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.indices.mapping.create.ClientTransportPutMappingAction
 
ClientTransportRefreshAction - Class in org.elasticsearch.client.transport.action.admin.indices.refresh
 
ClientTransportRefreshAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.indices.refresh.ClientTransportRefreshAction
 
ClientTransportReplicationPingAction - Class in org.elasticsearch.client.transport.action.admin.cluster.ping.replication
 
ClientTransportReplicationPingAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.cluster.ping.replication.ClientTransportReplicationPingAction
 
ClientTransportSearchAction - Class in org.elasticsearch.client.transport.action.search
 
ClientTransportSearchAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.search.ClientTransportSearchAction
 
ClientTransportSearchScrollAction - Class in org.elasticsearch.client.transport.action.search
 
ClientTransportSearchScrollAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.search.ClientTransportSearchScrollAction
 
ClientTransportSinglePingAction - Class in org.elasticsearch.client.transport.action.admin.cluster.ping.single
 
ClientTransportSinglePingAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.admin.cluster.ping.single.ClientTransportSinglePingAction
 
ClientTransportTermsAction - Class in org.elasticsearch.client.transport.action.terms
 
ClientTransportTermsAction(Settings, TransportService) - Constructor for class org.elasticsearch.client.transport.action.terms.ClientTransportTermsAction
 
clone() - Method in class org.elasticsearch.index.store.memory.ByteBufferIndexInput
 
clone() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Creates a shallow copy of this hashtable.
clone() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Creates a shallow copy of this hashtable.
clone() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Creates a shallow copy of this hashtable.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteHashSetDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleHashSetDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatHashSetDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntHashSetDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongHashSetDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortHashSetDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Clones the underlying trove collection and returns the clone wrapped in a new decorator instance.
clone() - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Returns a clone of this list.
clone() - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TByteHash
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Returns a clone of this list.
clone() - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TDoubleHash
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Returns a clone of this list.
clone() - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TFloatHash
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.THash
 
clone() - Method in class org.elasticsearch.util.gnu.trove.THashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Returns a clone of this list.
clone() - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TIntHash
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Returns a clone of this list.
clone() - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TLongHash
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
clone() - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
clone() - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
clone() - Method in class org.elasticsearch.util.gnu.trove.TObjectHash
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
clone() - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
clone() - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
clone() - Method in class org.elasticsearch.util.gnu.trove.TPrimitiveHash
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Returns a clone of this list.
clone() - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TShortHash
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
 
clone() - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
 
clone() - Method in class org.elasticsearch.util.IdentityHashSet
Returns a shallow copy of this HashSet instance: the elements themselves are not cloned.
close() - Method in interface org.elasticsearch.client.Client
Closes the client.
close() - Method in class org.elasticsearch.client.node.NodeClient
 
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.TransportClientClusterService
 
close() - Method in class org.elasticsearch.client.transport.TransportClientNodesService
 
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.http.netty.OpenChannelsHandler
 
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.filter.none.NoneFilterCache
 
close() - Method in class org.elasticsearch.index.cache.filter.support.AbstractConcurrentMapFilterCache
 
close() - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
close(boolean) - Method in class org.elasticsearch.index.gateway.fs.FsIndexGateway
 
close(boolean) - Method in class org.elasticsearch.index.gateway.fs.FsIndexShardGateway
 
close(boolean) - Method in class org.elasticsearch.index.gateway.IndexShardGatewayService
 
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.xcontent.XContentNumberFieldMapper.CachedNumericTokenStream
Close the input TokenStream.
close(boolean) - Method in class org.elasticsearch.index.service.InternalIndexService
 
close() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
close() - Method in class org.elasticsearch.index.shard.recovery.RecoveryAction
 
close() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
close() - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectory
 
close() - Method in class org.elasticsearch.index.store.memory.ByteBufferIndexInput
 
close() - Method in class org.elasticsearch.index.store.memory.ByteBufferIndexOutput
 
close() - Method in class org.elasticsearch.index.store.memory.HeapDirectory
 
close() - Method in class org.elasticsearch.index.store.memory.HeapIndexInput
 
close() - Method in class org.elasticsearch.index.store.memory.HeapIndexOutput
 
close() - Method in interface org.elasticsearch.index.store.Store
Close the store.
close() - Method in class org.elasticsearch.index.store.support.AbstractStore
 
close() - Method in class org.elasticsearch.index.translog.memory.MemoryTranslog
 
close() - Method in interface org.elasticsearch.index.translog.Translog
Closes the transaction log.
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.search.dfs.CachedDfSource
 
close() - Method in class org.elasticsearch.timer.TimerService
 
close() - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
 
close() - Method in class org.elasticsearch.transport.netty.OpenChannelsHandler
 
close() - Method in class org.elasticsearch.util.Base64.OutputStream
Flushes and closes (I think, in the superclass) the stream.
close() - Method in class org.elasticsearch.util.component.AbstractLifecycleComponent
 
close() - Method in interface org.elasticsearch.util.component.CloseableComponent
 
close(boolean) - Method in interface org.elasticsearch.util.component.CloseableIndexComponent
Closes the index component.
close(Injector) - Static method in class org.elasticsearch.util.guice.Injectors
 
close() - Method in class org.elasticsearch.util.io.FastByteArrayInputStream
Closing a ByteArrayInputStream has no effect.
close() - Method in class org.elasticsearch.util.io.FastByteArrayOutputStream
Closing a ByteArrayOutputStream has no effect.
close() - Method in class org.elasticsearch.util.io.FastCharArrayReader
Closes the stream and releases any system resources associated with it.
close() - Method in class org.elasticsearch.util.io.FastCharArrayWriter
Close the stream.
close() - Method in class org.elasticsearch.util.io.FastStringReader
Closes the stream and releases any system resources associated with it.
close() - Method in class org.elasticsearch.util.io.stream.BytesStreamInput
 
close() - Method in class org.elasticsearch.util.io.stream.BytesStreamOutput
 
close() - Method in class org.elasticsearch.util.io.stream.DataInputStreamInput
 
close() - Method in class org.elasticsearch.util.io.stream.DataOutputStreamOutput
 
close() - Method in class org.elasticsearch.util.io.stream.HandlesStreamInput
 
close() - Method in class org.elasticsearch.util.io.stream.HandlesStreamOutput
 
close() - Method in class org.elasticsearch.util.io.stream.InputStreamStreamInput
 
close() - Method in class org.elasticsearch.util.io.stream.OutputStreamStreamOutput
 
close() - Method in class org.elasticsearch.util.io.stream.StreamInput
Closes the stream to further operations.
close() - Method in class org.elasticsearch.util.io.stream.StreamOutput
Closes this stream to further operations.
close() - Method in class org.elasticsearch.util.io.StringBuilderWriter
Closing this writer has no effect.
close() - Method in class org.elasticsearch.util.lucene.all.AllEntries
 
close() - Method in class org.elasticsearch.util.lucene.store.SwitchDirectory
 
close() - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
close() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
close() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
close() - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
close() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
close() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
close() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
CloseableComponent - Interface in org.elasticsearch.util.component
 
CloseableIndexComponent - Interface in org.elasticsearch.util.component
 
closed() - Method in class org.elasticsearch.util.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
 
closeWriter() - Method in class org.elasticsearch.util.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
 
ClusterAdminClient - Interface in org.elasticsearch.client
Administrative actions/operations against indices.
clusterChanged(ClusterChangedEvent) - Method in class org.elasticsearch.client.transport.TransportClientNodesService
 
clusterChanged(ClusterChangedEvent) - Method in interface org.elasticsearch.cluster.ClusterStateListener
 
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.indices.cluster.IndicesClusterStateService
 
ClusterChangedEvent - Class in org.elasticsearch.cluster
 
ClusterChangedEvent(String, ClusterState, ClusterState, boolean) - 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
 
clusterHealth(String...) - Static method in class org.elasticsearch.client.Requests
Creates a cluster health request.
ClusterHealthRequest - Class in org.elasticsearch.action.admin.cluster.health
 
ClusterHealthRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
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.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
 
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.TransportIndicesReplicationOperationAction
 
clusterService - Variable in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
clusterService - Variable in class org.elasticsearch.action.support.single.TransportSingleOperationAction
 
ClusterService - Interface in org.elasticsearch.cluster
 
ClusterShardHealth - Class in org.elasticsearch.action.admin.cluster.health
 
clusterState() - Static method in class org.elasticsearch.client.Requests
Creates a cluster state request.
ClusterState - Class in org.elasticsearch.cluster
 
ClusterState(long, MetaData, RoutingTable, DiscoveryNodes) - Constructor for class org.elasticsearch.cluster.ClusterState
 
ClusterState.Builder - Class in org.elasticsearch.cluster
 
ClusterState.Builder() - Constructor for class org.elasticsearch.cluster.ClusterState.Builder
 
ClusterStateListener - Interface in org.elasticsearch.cluster
 
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
 
ClusterStateResponse - Class in org.elasticsearch.action.admin.cluster.state
 
ClusterStateUpdateTask - Interface in org.elasticsearch.cluster
 
code() - Method in enum org.elasticsearch.util.xcontent.xson.XsonType
 
CODE_LIST_SEPARATOR - Static variable in class org.elasticsearch.util.jline.ANSI.Renderer
 
CODE_TEXT_SEPARATOR - Static variable in class org.elasticsearch.util.jline.ANSI.Renderer
 
collect(int) - Method in class org.elasticsearch.util.lucene.docidset.DocIdSetCollector
 
collect(int) - Method in class org.elasticsearch.util.lucene.Lucene.CountCollector
 
collectionCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
collectionCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
 
Collections2 - Class in org.elasticsearch.util.collect
Provides static methods for working with Collection instances.
Collections2 - Class in org.elasticsearch.util.inject.internal
Provides static methods for working with Collection instances.
collectionTime() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
collectionTime() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
 
collectionToCommaDelimitedString(Collection) - Static method in class org.elasticsearch.util.Strings
Convenience method to return a Collection as a CSV String.
collectionToDelimitedString(Collection, String, String, String) - Static method in class org.elasticsearch.util.Strings
Convenience method to return a Collection as a delimited (e.g.
collectionToDelimitedString(Collection, String) - Static method in class org.elasticsearch.util.Strings
Convenience method to return a Collection as a delimited (e.g.
collectPayloads(boolean) - Method in class org.elasticsearch.index.query.xcontent.SpanNearQueryBuilder
 
combine(Module...) - Static method in class org.elasticsearch.util.inject.util.Modules
Returns a new module that installs all of modules.
combine(Iterable<? extends Module>) - Static method in class org.elasticsearch.util.inject.util.Modules
Returns a new module that installs all of modules.
commaDelimitedListToSet(String) - Static method in class org.elasticsearch.util.Strings
Convenience method to convert a CSV string list to a set.
commaDelimitedListToStringArray(String) - Static method in class org.elasticsearch.util.Strings
Convert a CSV list into an array of Strings.
compact() - Method in class org.elasticsearch.util.gnu.trove.THash
Compresses the hashtable to the minimum prime size (as defined by PrimeFinder) that will hold all of the elements currently in the table.
comparator() - Method in class org.elasticsearch.util.collect.ForwardingSortedMap
 
comparator() - Method in class org.elasticsearch.util.collect.ForwardingSortedSet
 
comparator() - Method in class org.elasticsearch.util.collect.ImmutableSortedMap
Returns the comparator that orders the keys, which is Ordering.natural() when the natural ordering of the keys is used.
comparator() - Method in class org.elasticsearch.util.collect.ImmutableSortedSet
Returns the comparator that orders the elements, which is Ordering.natural() when the natural ordering of the elements is used.
compareTo(UUID) - Method in class org.elasticsearch.util.UUID
Compares this UUID with the specified UUID.
complementOf(Collection<E>) - Static method in class org.elasticsearch.util.collect.Sets
Creates an EnumSet consisting of all enum values that are not in the specified collection.
complementOf(Collection<E>, Class<E>) - Static method in class org.elasticsearch.util.collect.Sets
Creates an EnumSet consisting of all enum values that are not in the specified collection.
complete(V) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Completes this task, and if not already aborted or cancelled, returning a null result upon join and related operations.
completeExceptionally(Throwable) - Method in class org.elasticsearch.util.concurrent.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.index.AbstractIndexComponent
 
componentSettings - Variable in class org.elasticsearch.index.shard.AbstractIndexShardComponent
 
componentSettings - Variable in class org.elasticsearch.util.component.AbstractComponent
 
compose(Function<B, C>, Function<A, ? extends B>) - Static method in class org.elasticsearch.util.base.Functions
Returns the composition of two functions.
compose(Predicate<B>, Function<A, ? extends B>) - Static method in class org.elasticsearch.util.base.Predicates
Returns the composition of a function and a predicate.
compose(Function<? super F, T>, Supplier<F>) - Static method in class org.elasticsearch.util.base.Suppliers
Returns a new supplier which is the composition of the provided function and supplier.
compound(Iterable<? extends Comparator<? super T>>) - Static method in class org.elasticsearch.util.collect.Ordering
Returns an ordering which tries each given comparator in order until a non-zero result is found, returning that result, and returning zero only if all comparators return zero.
compound(Comparator<? super U>) - Method in class org.elasticsearch.util.collect.Ordering
Returns an ordering which first uses the ordering this, but which in the event of a "tie", then delegates to secondaryComparator.
compress(byte[]) - Method in interface org.elasticsearch.util.io.compression.Compressor
 
compress(byte[], int, int) - Method in class org.elasticsearch.util.io.compression.GZIPCompressor
 
compress(byte[]) - Method in class org.elasticsearch.util.io.compression.GZIPCompressor
 
compress(byte[]) - Method in class org.elasticsearch.util.io.compression.LzfCompressor
 
compress(byte[], int, int) - Method in class org.elasticsearch.util.io.compression.ZipCompressor
 
compress(byte[]) - Method in class org.elasticsearch.util.io.compression.ZipCompressor
 
CompressedString - Class in org.elasticsearch.util.io.compression
 
CompressedString(String) - Constructor for class org.elasticsearch.util.io.compression.CompressedString
 
Compressor - Interface in org.elasticsearch.util.io.compression
 
compressString(String) - Method in interface org.elasticsearch.util.io.compression.Compressor
 
compressString(String) - Method in class org.elasticsearch.util.io.compression.GZIPCompressor
 
compressString(String) - Method in class org.elasticsearch.util.io.compression.LzfCompressor
 
compressString(String) - Method in class org.elasticsearch.util.io.compression.ZipCompressor
 
ComputationException - Exception in org.elasticsearch.util.collect
Wraps an exception that occured during a computation.
ComputationException(Throwable) - Constructor for exception org.elasticsearch.util.collect.ComputationException
Creates a new instance with the given cause.
ComputationException - Exception in org.elasticsearch.util.inject.internal
Wraps an exception that occured during a computation.
ComputationException(Throwable) - Constructor for exception org.elasticsearch.util.inject.internal.ComputationException
 
compute() - Method in class org.elasticsearch.util.concurrent.jsr166y.RecursiveAction
The main computation performed by this task.
compute() - Method in class org.elasticsearch.util.concurrent.jsr166y.RecursiveTask
The main computation performed by this task.
computeHashCode(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteHash
Default implementation of TByteHashingStrategy: delegates hashing to HashFunctions.hash(byte).
computeHashCode(byte) - Method in interface org.elasticsearch.util.gnu.trove.TByteHashingStrategy
Computes a hash code for the specified byte.
computeHashCode(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHash
Default implementation of TDoubleHashingStrategy: delegates hashing to HashFunctions.hash(double).
computeHashCode(double) - Method in interface org.elasticsearch.util.gnu.trove.TDoubleHashingStrategy
Computes a hash code for the specified double.
computeHashCode(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatHash
Default implementation of TFloatHashingStrategy: delegates hashing to HashFunctions.hash(float).
computeHashCode(float) - Method in interface org.elasticsearch.util.gnu.trove.TFloatHashingStrategy
Computes a hash code for the specified float.
computeHashCode(int) - Method in class org.elasticsearch.util.gnu.trove.TIntHash
Default implementation of TIntHashingStrategy: delegates hashing to HashFunctions.hash(int).
computeHashCode(int) - Method in interface org.elasticsearch.util.gnu.trove.TIntHashingStrategy
Computes a hash code for the specified int.
computeHashCode(long) - Method in class org.elasticsearch.util.gnu.trove.TLongHash
Default implementation of TLongHashingStrategy: delegates hashing to HashFunctions.hash(long).
computeHashCode(long) - Method in interface org.elasticsearch.util.gnu.trove.TLongHashingStrategy
Computes a hash code for the specified long.
computeHashCode(T) - Method in class org.elasticsearch.util.gnu.trove.TObjectHash
This is the default implementation of TObjectHashingStrategy: it delegates hashing to the Object's hashCode method.
computeHashCode(T) - Method in interface org.elasticsearch.util.gnu.trove.TObjectHashingStrategy
Computes a hash code for the specified object.
computeHashCode(T) - Method in class org.elasticsearch.util.gnu.trove.TObjectIdentityHashingStrategy
Delegates hash code computation to the System.identityHashCode(Object) method.
computeHashCode(short) - Method in class org.elasticsearch.util.gnu.trove.TShortHash
Default implementation of TShortHashingStrategy: delegates hashing to HashFunctions.hash(short).
computeHashCode(short) - Method in interface org.elasticsearch.util.gnu.trove.TShortHashingStrategy
Computes a hash code for the specified short.
computeNext() - Method in class org.elasticsearch.util.collect.AbstractIterator
Returns the next element.
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(FieldMappers) - Method in class org.elasticsearch.index.mapper.FieldMappers
Concats and returns a new FieldMappers.
concat(Iterable<? extends T>, Iterable<? extends T>) - Static method in class org.elasticsearch.util.collect.Iterables
Combines two iterables into a single iterable.
concat(Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>) - Static method in class org.elasticsearch.util.collect.Iterables
Combines three iterables into a single iterable.
concat(Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>, Iterable<? extends T>) - Static method in class org.elasticsearch.util.collect.Iterables
Combines four iterables into a single iterable.
concat(Iterable<? extends T>...) - Static method in class org.elasticsearch.util.collect.Iterables
Combines multiple iterables into a single iterable.
concat(Iterable<? extends Iterable<? extends T>>) - Static method in class org.elasticsearch.util.collect.Iterables
Combines multiple iterables into a single iterable.
concat(Iterator<? extends T>, Iterator<? extends T>) - Static method in class org.elasticsearch.util.collect.Iterators
Combines two iterators into a single iterator.
concat(Iterator<? extends T>, Iterator<? extends T>, Iterator<? extends T>) - Static method in class org.elasticsearch.util.collect.Iterators
Combines three iterators into a single iterator.
concat(Iterator<? extends T>, Iterator<? extends T>, Iterator<? extends T>, Iterator<? extends T>) - Static method in class org.elasticsearch.util.collect.Iterators
Combines four iterators into a single iterator.
concat(Iterator<? extends T>...) - Static method in class org.elasticsearch.util.collect.Iterators
Combines multiple iterators into a single iterator.
concat(Iterator<? extends Iterator<? extends T>>) - Static method in class org.elasticsearch.util.collect.Iterators
Combines multiple iterators into a single iterator.
concat(T[], T[], Class<T>) - Static method in class org.elasticsearch.util.collect.ObjectArrays
Returns a new array that contains the concatenated contents of two arrays.
concat(T, T[]) - Static method in class org.elasticsearch.util.collect.ObjectArrays
Returns a new array that prepends element to array.
concat(T[], T) - Static method in class org.elasticsearch.util.collect.ObjectArrays
Returns a new array that appends element to array.
concatenateStringArrays(String[], String[]) - Static method in class org.elasticsearch.util.Strings
Concatenate the given String arrays into one, with overlapping array elements included twice.
CONCEALED - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
concreteAllIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData
Returns all the concrete indices.
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.
concurrencyLevel(int) - Method in class org.elasticsearch.util.collect.MapMaker
Guides the allowed concurrency among update operations.
ConcurrentAutoTable - Class in org.elasticsearch.util.concurrent.highscalelib
An auto-resizing table of longs, supporting low-contention CAS operations.
ConcurrentAutoTable() - Constructor for class org.elasticsearch.util.concurrent.highscalelib.ConcurrentAutoTable
 
ConcurrentCollections - Class in org.elasticsearch.util.concurrent
 
ConcurrentHashMapLong<T> - Class in org.elasticsearch.util.concurrent
 
ConcurrentHashMapLong() - Constructor for class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
ConcurrentHashMultiset<E> - Class in org.elasticsearch.util.collect
A multiset that supports concurrent modifications and that provides atomic versions of most Multiset operations (exceptions where noted).
ConcurrentIdentityHashMap<K,V> - Class in org.elasticsearch.util.concurrent
An alternative identity-comparing ConcurrentMap which is similar to ConcurrentHashMap.
ConcurrentIdentityHashMap(int, float, int) - Constructor for class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Creates a new, empty map with the specified initial capacity, load factor and concurrency level.
ConcurrentIdentityHashMap(int, float) - Constructor for class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Creates a new, empty map with the specified initial capacity and load factor and with the default reference types (weak keys, strong values), and concurrencyLevel (16).
ConcurrentIdentityHashMap(int) - Constructor for class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Creates a new, empty map with the specified initial capacity, and with default reference types (weak keys, strong values), load factor (0.75) and concurrencyLevel (16).
ConcurrentIdentityHashMap() - Constructor for class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Creates a new, empty map with a default initial capacity (16), reference types (weak keys, strong values), default load factor (0.75) and concurrencyLevel (16).
ConcurrentIdentityHashMap(Map<? extends K, ? extends V>) - Constructor for class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Creates a new map with the same mappings as the given map.
ConcurrentMapLong<T> - Interface in org.elasticsearch.util.concurrent
 
ConcurrentMergeSchedulerProvider - Class in org.elasticsearch.index.merge.scheduler
 
ConcurrentMergeSchedulerProvider(ShardId, Settings) - Constructor for class org.elasticsearch.index.merge.scheduler.ConcurrentMergeSchedulerProvider
 
ConcurrentSafeArray<T> - Class in org.elasticsearch.util.concurrent
A concurrent version of SafeArray.
ConcurrentSafeArray() - Constructor for class org.elasticsearch.util.concurrent.ConcurrentSafeArray
 
ConcurrentVersionedMap - Class in org.elasticsearch.util.lucene.versioned
An implementation of VersionedMap based on ConcurrentHashMap.
ConcurrentVersionedMap() - Constructor for class org.elasticsearch.util.lucene.versioned.ConcurrentVersionedMap
 
ConcurrentVersionedMapLong - Class in org.elasticsearch.util.lucene.versioned
An implementation of VersionedMap based on ConcurrentMapLong.
ConcurrentVersionedMapLong() - Constructor for class org.elasticsearch.util.lucene.versioned.ConcurrentVersionedMapLong
 
configFile() - Method in class org.elasticsearch.env.Environment
The config location.
ConfigurationException - Exception in org.elasticsearch.util.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.util.inject.ConfigurationException
Creates a ConfigurationException containing messages.
configure() - Method in class org.elasticsearch.action.TransportActionModule
 
configure() - Method in class org.elasticsearch.client.node.NodeClientModule
 
configure() - Method in class org.elasticsearch.client.transport.action.ClientTransportActionModule
 
configure() - Method in class org.elasticsearch.client.transport.ClientTransportModule
 
configure() - Method in class org.elasticsearch.client.transport.TransportClientClusterModule
 
configure() - Method in class org.elasticsearch.cluster.ClusterModule
 
configure() - Method in class org.elasticsearch.cluster.ClusterNameModule
 
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.gateway.fs.FsGatewayModule
 
configure() - Method in class org.elasticsearch.gateway.GatewayModule
 
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.analysis.AnalysisModule
 
configure() - Method in class org.elasticsearch.index.cache.filter.FilterCacheModule
 
configure() - Method in class org.elasticsearch.index.cache.IndexCacheModule
 
configure() - Method in class org.elasticsearch.index.deletionpolicy.DeletionPolicyModule
 
configure() - Method in class org.elasticsearch.index.engine.EngineModule
 
configure() - Method in class org.elasticsearch.index.engine.robin.RobinEngineModule
 
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.none.NoneIndexGatewayModule
 
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.query.IndexQueryParserModule
 
configure() - Method in class org.elasticsearch.index.routing.OperationRoutingModule
 
configure() - Method in class org.elasticsearch.index.routing.plain.PlainOperationRoutingModule
 
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.MmapFsStoreModule
 
configure() - Method in class org.elasticsearch.index.store.fs.NioFsStoreModule
 
configure() - Method in class org.elasticsearch.index.store.fs.SimpleFsStoreModule
 
configure() - Method in class org.elasticsearch.index.store.memory.MemoryStoreModule
 
configure() - Method in class org.elasticsearch.index.store.ram.RamStoreModule
 
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.IndicesModule
 
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.IndicesPluginsModule
 
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.search.SearchModule
 
configure() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPoolModule
 
configure() - Method in class org.elasticsearch.threadpool.cached.CachedThreadPoolModule
 
configure() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPoolModule
 
configure() - Method in class org.elasticsearch.threadpool.ThreadPoolModule
 
configure() - Method in class org.elasticsearch.timer.TimerModule
 
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
 
configure(Binder) - Method in class org.elasticsearch.util.inject.AbstractModule
 
configure() - Method in class org.elasticsearch.util.inject.AbstractModule
Configures a Binder via the exposed methods.
configure(Binder) - Method in class org.elasticsearch.util.inject.internal.ProviderMethod
 
configure(Binder) - Method in class org.elasticsearch.util.inject.internal.ProviderMethodsModule
 
configure(Binder) - Method in interface org.elasticsearch.util.inject.Module
Contributes bindings and other configurations for this module to binder.
configure(Binder) - Method in class org.elasticsearch.util.inject.PrivateModule
 
configure() - Method in class org.elasticsearch.util.inject.PrivateModule
Creates bindings and other configurations private to this module.
configure(Settings) - Static method in class org.elasticsearch.util.logging.log4j.LogConfigurator
 
configure() - Method in class org.elasticsearch.util.network.NetworkModule
 
configure() - Method in class org.elasticsearch.util.settings.SettingsModule
 
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) - 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
 
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
 
ConsoleAppender - Class in org.elasticsearch.util.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.util.logging.log4j.ConsoleAppender
Constructs an unconfigured appender.
ConsoleAppender(Layout) - Constructor for class org.elasticsearch.util.logging.log4j.ConsoleAppender
Creates a configured appender.
ConsoleAppender(Layout, String) - Constructor for class org.elasticsearch.util.logging.log4j.ConsoleAppender
Creates a configured appender.
consoleLoggingEnabled() - Static method in class org.elasticsearch.util.logging.Loggers
 
constant(E) - Static method in class org.elasticsearch.util.base.Functions
Creates a function that returns value for any input.
CONSTANT_VALUE_ALREADY_SET - Static variable in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
ConstantBindingBuilder - Interface in org.elasticsearch.util.inject.binder
Binds to a constant value.
ConstantBindingBuilderImpl<T> - Class in org.elasticsearch.util.inject.internal
Bind a constant.
ConstantBindingBuilderImpl(Binder, List<Element>, Object) - Constructor for class org.elasticsearch.util.inject.internal.ConstantBindingBuilderImpl
 
constantScoreQuery(XContentFilterBuilder) - Static method in class org.elasticsearch.index.query.xcontent.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.xcontent
A query that wraps a filter and simply returns a constant score equal to the query boost for every document in the filter.
ConstantScoreQueryBuilder(XContentFilterBuilder) - Constructor for class org.elasticsearch.index.query.xcontent.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.xcontent
 
ConstantScoreQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.ConstantScoreQueryParser
 
ConstructionContext<T> - Class in org.elasticsearch.util.inject.internal
Context of a dependency construction.
ConstructionContext() - Constructor for class org.elasticsearch.util.inject.internal.ConstructionContext
 
ConstructorBinding<T> - Interface in org.elasticsearch.util.inject.spi
A binding to the constructor of a concrete clss.
contains(Class) - Method in exception org.elasticsearch.ElasticSearchException
Check whether this exception contains an exception of the given type: either it is of the given class itself or it contains a nested cause of the given type.
contains(Object) - Method in class org.elasticsearch.util.collect.ForwardingCollection
 
contains(Object) - Method in class org.elasticsearch.util.collect.ImmutableCollection
 
contains(Object) - Method in class org.elasticsearch.util.collect.ImmutableMultiset
 
contains(Iterable<?>, Object) - Static method in class org.elasticsearch.util.collect.Iterables
Returns true if iterable contains element; that is, any object for while equals(element) is true.
contains(Iterator<?>, Object) - Static method in class org.elasticsearch.util.collect.Iterators
Returns true if iterator contains element.
contains(Object) - Method in interface org.elasticsearch.util.collect.Multiset
Determines whether this multiset contains the specified element.
contains(Object) - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
contains(Object) - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Legacy method testing if some key maps into the specified value in this table.
contains(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Legacy method testing if some key maps into the specified value in this table.
contains(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Legacy method testing if some key maps into the specified value in this table.
contains(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashSet
 
contains(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Legacy method testing if some key maps into the specified value in this table.
contains(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Legacy method testing if some key maps into the specified value in this table.
contains(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingSetInt
Test if o is in the set.
contains(int) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingSetInt
Test if i is in the set.
contains(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Searches the list for value
contains(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteHash
Searches the set for val
contains(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Searches the list for value
contains(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHash
Searches the set for val
contains(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Searches the list for value
contains(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatHash
Searches the set for val
contains(int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Searches the list for value
contains(int) - Method in class org.elasticsearch.util.gnu.trove.TIntHash
Searches the set for val
contains(Object) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
A linear search for o in the list.
contains(long) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Searches the list for value
contains(long) - Method in class org.elasticsearch.util.gnu.trove.TLongHash
Searches the set for val
contains(Object) - Method in class org.elasticsearch.util.gnu.trove.TObjectHash
Searches the set for obj
contains(short) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Searches the list for value
contains(short) - Method in class org.elasticsearch.util.gnu.trove.TShortHash
Searches the set for val
contains(Object) - Method in class org.elasticsearch.util.IdentityHashSet
Returns true if this set contains the specified element.
contains(Object) - Method in class org.elasticsearch.util.MapBackedSet
 
containsAll(Collection<?>) - Method in class org.elasticsearch.util.collect.ForwardingCollection
 
containsAll(Collection<?>) - Method in class org.elasticsearch.util.collect.ImmutableCollection
 
containsAll(Collection<?>) - Method in interface org.elasticsearch.util.collect.Multiset
Returns true if this multiset contains at least one occurrence of each element in the specified collection.
containsAll(byte[]) - Method in class org.elasticsearch.util.gnu.trove.TByteHashSet
Tests the set to determine if all of the elements in array are present.
containsAll(double[]) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Tests the set to determine if all of the elements in array are present.
containsAll(float[]) - Method in class org.elasticsearch.util.gnu.trove.TFloatHashSet
Tests the set to determine if all of the elements in array are present.
containsAll(Collection<?>) - Method in class org.elasticsearch.util.gnu.trove.THashSet
Tests the set to determine if all of the elements in collection are present.
containsAll(int[]) - Method in class org.elasticsearch.util.gnu.trove.TIntHashSet
Tests the set to determine if all of the elements in array are present.
containsAll(long[]) - Method in class org.elasticsearch.util.gnu.trove.TLongHashSet
Tests the set to determine if all of the elements in array are present.
containsAll(short[]) - Method in class org.elasticsearch.util.gnu.trove.TShortHashSet
Tests the set to determine if all of the elements in array are present.
containsElement(Map.Entry<K, V>) - Method in class org.elasticsearch.util.gnu.trove.THashMap.EntryView
 
containsElement(K) - Method in class org.elasticsearch.util.gnu.trove.THashMap.KeyView
 
containsElement(V) - Method in class org.elasticsearch.util.gnu.trove.THashMap.ValueView
 
containsEntry(Object, Object) - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
containsEntry(Object, Object) - Method in class org.elasticsearch.util.collect.ImmutableMultimap
 
containsEntry(Object, Object) - Method in class org.elasticsearch.util.collect.LinkedListMultimap
 
containsEntry(Object, Object) - Method in interface org.elasticsearch.util.collect.Multimap
Returns true if the multimap contains the specified key-value pair.
containsKey(Object) - Method in class org.elasticsearch.util.collect.ForwardingMap
 
containsKey(Object) - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
containsKey(Object) - Method in class org.elasticsearch.util.collect.ImmutableBiMap
 
containsKey(Object) - Method in class org.elasticsearch.util.collect.ImmutableMap
 
containsKey(Object) - Method in class org.elasticsearch.util.collect.ImmutableMultimap
 
containsKey(Object) - Method in class org.elasticsearch.util.collect.LinkedListMultimap
 
containsKey(Object) - Method in interface org.elasticsearch.util.collect.Multimap
Returns true if the multimap contains any values for the specified key.
containsKey(Object) - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
containsKey(Object) - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Tests if the specified object is a key in this table.
containsKey(Object) - Method in class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
containsKey(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Tests if the key in the table using the equals method.
containsKey(long) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Tests if the key in the table.
containsKey(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Auto-boxing version of NonBlockingHashMapLong.containsKey(long).
containsKey(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Tests if the key in the table using the equals method.
containsKey(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Tests if the key in the table using the equals method.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Checks for the present of key in the keys of the map.
containsKey(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
checks for the present of key in the keys of the map.
containsKey(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
checks for the present of key in the keys of the map.
containsKey(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
checks for the present of key in the keys of the map.
containsKey(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
checks for the present of key in the keys of the map.
containsKey(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
checks for the present of key in the keys of the map.
containsKey(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
checks for the present of key in the keys of the map.
containsKey(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
checks for the present of key in the keys of the map.
containsKey(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
checks for the present of key in the keys of the map.
containsKey(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
checks for the present of key in the keys of the map.
containsKey(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
checks for the present of key in the keys of the map.
containsKey(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
checks for the present of key in the keys of the map.
containsKey(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
checks for the present of key in the keys of the map.
containsKey(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
checks for the present of key in the keys of the map.
containsKey(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
checks for the present of key in the keys of the map.
containsKey(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
checks for the present of key in the keys of the map.
containsKey(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
checks for the present of key in the keys of the map.
containsKey(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
checks for the present of key in the keys of the map.
containsKey(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
checks for the present of key in the keys of the map.
containsKey(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
checks for the present of key in the keys of the map.
containsKey(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
checks for the present of key in the keys of the map.
containsKey(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
checks for the present of key in the keys of the map.
containsKey(Object) - Method in class org.elasticsearch.util.gnu.trove.THashMap
checks for the present of key in the keys of the map.
containsKey(int) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
checks for the present of key in the keys of the map.
containsKey(int) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
checks for the present of key in the keys of the map.
containsKey(int) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
checks for the present of key in the keys of the map.
containsKey(int) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
checks for the present of key in the keys of the map.
containsKey(int) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
checks for the present of key in the keys of the map.
containsKey(int) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
checks for the present of key in the keys of the map.
containsKey(int) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
checks for the present of key in the keys of the map.
containsKey(long) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
checks for the present of key in the keys of the map.
containsKey(long) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
checks for the present of key in the keys of the map.
containsKey(long) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
checks for the present of key in the keys of the map.
containsKey(long) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
checks for the present of key in the keys of the map.
containsKey(long) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
checks for the present of key in the keys of the map.
containsKey(long) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
checks for the present of key in the keys of the map.
containsKey(long) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
checks for the present of key in the keys of the map.
containsKey(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
checks for the present of key in the keys of the map.
containsKey(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
checks for the present of key in the keys of the map.
containsKey(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
checks for the present of key in the keys of the map.
containsKey(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
checks for the present of key in the keys of the map.
containsKey(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
checks for the present of key in the keys of the map.
containsKey(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
checks for the present of key in the keys of the map.
containsKey(short) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
checks for the present of key in the keys of the map.
containsKey(short) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
checks for the present of key in the keys of the map.
containsKey(short) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
checks for the present of key in the keys of the map.
containsKey(short) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
checks for the present of key in the keys of the map.
containsKey(short) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
checks for the present of key in the keys of the map.
containsKey(short) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
checks for the present of key in the keys of the map.
containsKey(short) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
checks for the present of key in the keys of the map.
containsKey(K) - Method in class org.elasticsearch.util.MapBuilder
 
containsValue(Object) - Method in class org.elasticsearch.util.collect.ForwardingMap
 
containsValue(Object) - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
containsValue(Object) - Method in class org.elasticsearch.util.collect.ImmutableBiMap
 
containsValue(Object) - Method in class org.elasticsearch.util.collect.ImmutableMap
 
containsValue(Object) - Method in class org.elasticsearch.util.collect.ImmutableMultimap
 
containsValue(Object) - Method in class org.elasticsearch.util.collect.ImmutableSortedMap
 
containsValue(Object) - Method in class org.elasticsearch.util.collect.LinkedListMultimap
 
containsValue(Object) - Method in interface org.elasticsearch.util.collect.Multimap
Returns true if the multimap contains the specified value for any key.
containsValue(Object) - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
containsValue(Object) - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Returns true if this map maps one or more keys to the specified value.
containsValue(Object) - Method in class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
containsValue(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Returns true if this Map maps one or more keys to the specified value.
containsValue(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Returns true if this Map maps one or more keys to the specified value.
containsValue(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Returns true if this Map maps one or more keys to the specified value.
containsValue(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Returns true if this Map maps one or more keys to the specified value.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Checks for the presence of val in the values of the map.
containsValue(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
checks for the presence of val in the values of the map.
containsValue(double) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
checks for the presence of val in the values of the map.
containsValue(float) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
checks for the presence of val in the values of the map.
containsValue(int) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
checks for the presence of val in the values of the map.
containsValue(long) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
checks for the presence of val in the values of the map.
containsValue(V) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
checks for the presence of val in the values of the map.
containsValue(short) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
checks for the presence of val in the values of the map.
containsValue(byte) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
checks for the presence of val in the values of the map.
containsValue(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
checks for the presence of val in the values of the map.
containsValue(float) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
checks for the presence of val in the values of the map.
containsValue(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
checks for the presence of val in the values of the map.
containsValue(long) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
checks for the presence of val in the values of the map.
containsValue(V) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
checks for the presence of val in the values of the map.
containsValue(short) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
checks for the presence of val in the values of the map.
containsValue(byte) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
checks for the presence of val in the values of the map.
containsValue(double) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
checks for the presence of val in the values of the map.
containsValue(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
checks for the presence of val in the values of the map.
containsValue(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
checks for the presence of val in the values of the map.
containsValue(long) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
checks for the presence of val in the values of the map.
containsValue(V) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
checks for the presence of val in the values of the map.
containsValue(short) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
checks for the presence of val in the values of the map.
containsValue(Object) - Method in class org.elasticsearch.util.gnu.trove.THashMap
checks for the presence of val in the values of the map.
containsValue(byte) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
checks for the presence of val in the values of the map.
containsValue(double) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
checks for the presence of val in the values of the map.
containsValue(float) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
checks for the presence of val in the values of the map.
containsValue(int) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
checks for the presence of val in the values of the map.
containsValue(long) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
checks for the presence of val in the values of the map.
containsValue(V) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
checks for the presence of val in the values of the map.
containsValue(short) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
checks for the presence of val in the values of the map.
containsValue(byte) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
checks for the presence of val in the values of the map.
containsValue(double) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
checks for the presence of val in the values of the map.
containsValue(float) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
checks for the presence of val in the values of the map.
containsValue(int) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
checks for the presence of val in the values of the map.
containsValue(long) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
checks for the presence of val in the values of the map.
containsValue(V) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
checks for the presence of val in the values of the map.
containsValue(short) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
checks for the presence of val in the values of the map.
containsValue(byte) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
checks for the presence of val in the values of the map.
containsValue(double) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
checks for the presence of val in the values of the map.
containsValue(float) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
checks for the presence of val in the values of the map.
containsValue(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
checks for the presence of val in the values of the map.
containsValue(long) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
checks for the presence of val in the values of the map.
containsValue(short) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
checks for the presence of val in the values of the map.
containsValue(byte) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
checks for the presence of val in the values of the map.
containsValue(double) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
checks for the presence of val in the values of the map.
containsValue(float) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
checks for the presence of val in the values of the map.
containsValue(int) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
checks for the presence of val in the values of the map.
containsValue(long) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
checks for the presence of val in the values of the map.
containsValue(V) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
checks for the presence of val in the values of the map.
containsValue(short) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
checks for the presence of val in the values of the map.
containsWhitespace(CharSequence) - Static method in class org.elasticsearch.util.Strings
Check whether the given CharSequence contains any whitespace characters.
containsWhitespace(String) - Static method in class org.elasticsearch.util.Strings
Check whether the given String contains any whitespace characters.
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.xcontent.XContentAllFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentBinaryFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper
 
CONTENT_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper
 
contentAsString() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
contentAsString() - Method in interface org.elasticsearch.rest.RestRequest
 
contentBinaryBuilder() - Static method in class org.elasticsearch.util.xcontent.json.JsonXContent
 
contentBinaryBuilder(XContentType) - Static method in class org.elasticsearch.util.xcontent.XContentFactory
Returns a binary content builder for the provided content type.
contentBinaryBuilder() - Static method in class org.elasticsearch.util.xcontent.xson.XsonXContent
 
contentBuilder() - Static method in class org.elasticsearch.util.xcontent.json.JsonXContent
 
contentBuilder(XContentType) - Static method in class org.elasticsearch.util.xcontent.XContentFactory
Returns a binary content builder for the provided content type.
contentByteArray() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
contentByteArray() - Method in interface org.elasticsearch.rest.RestRequest
 
contentByteArrayOffset() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
contentByteArrayOffset() - Method in interface org.elasticsearch.rest.RestRequest
 
contentLength() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
contentLength() - Method in interface org.elasticsearch.rest.RestRequest
 
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.xcontent
 
ContentPath() - Constructor for class org.elasticsearch.index.mapper.xcontent.ContentPath
 
ContentPath(int) - Constructor for class org.elasticsearch.index.mapper.xcontent.ContentPath
Constructs a json path with an offset.
ContentPath.Type - Enum in org.elasticsearch.index.mapper.xcontent
 
contentTextBuilder() - Static method in class org.elasticsearch.util.xcontent.json.JsonXContent
 
contentTextBuilder(XContentType) - Static method in class org.elasticsearch.util.xcontent.XContentFactory
Returns a textual content builder for the provided content type.
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() - Method in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentBinaryFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper
 
contentType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper
 
contentType() - Method in interface org.elasticsearch.rest.RestResponse
 
contentType() - Method in class org.elasticsearch.rest.Utf8RestResponse
 
contentType() - Method in class org.elasticsearch.rest.XContentRestResponse
 
contentType() - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
contentType() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
contentType() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
contentType() - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
contentType() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
contentType() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
contentType() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
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.monitor.dump.AbstractDump
 
context() - Method in interface org.elasticsearch.monitor.dump.Dump
 
ContextIndexSearcher - Class in org.elasticsearch.search.internal
 
ContextIndexSearcher(SearchContext, IndexReader) - Constructor for class org.elasticsearch.search.internal.ContextIndexSearcher
 
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.util.inject.internal.Errors
 
conversionTypeError(String, Object, TypeLiteral<?>, MatcherAndConverter, Object) - Method in class org.elasticsearch.util.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(Exception) - Static method in class org.elasticsearch.util.concurrent.Futures
 
convert(Object) - Static method in class org.elasticsearch.util.inject.internal.Errors
 
convert(String, TypeLiteral<?>) - Method in interface org.elasticsearch.util.inject.spi.TypeConverter
Converts a string value.
ConvertedConstantBinding<T> - Interface in org.elasticsearch.util.inject.spi
A binding created from converting a bound instance to a new type.
converterReturnedNull(String, Object, TypeLiteral<?>, MatcherAndConverter) - Method in class org.elasticsearch.util.inject.internal.Errors
 
convertToTypes(Matcher<? super TypeLiteral<?>>, TypeConverter) - Method in class org.elasticsearch.util.inject.AbstractModule
 
convertToTypes(Matcher<? super TypeLiteral<?>>, TypeConverter) - Method in interface org.elasticsearch.util.inject.Binder
Binds a type converter.
convertToTypes(Matcher<? super TypeLiteral<?>>, TypeConverter) - Method in class org.elasticsearch.util.inject.PrivateModule
 
cookie() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
cookie() - Method in interface org.elasticsearch.rest.RestRequest
 
copiedByteArray() - Method in class org.elasticsearch.util.io.ByteArrayDataOutputStream
 
copiedByteArray() - Method in class org.elasticsearch.util.io.FastByteArrayOutputStream
Creates a newly allocated byte array.
copiedByteArray() - Method in class org.elasticsearch.util.io.stream.BytesStreamOutput
Creates a newly allocated byte array.
copiedBytes() - Method in class org.elasticsearch.util.xcontent.builder.BinaryXContentBuilder
 
copiedBytes() - Method in class org.elasticsearch.util.xcontent.builder.TextXContentBuilder
 
copiedBytes() - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
copy(File, File) - Static method in class org.elasticsearch.util.io.Streams
Copy the contents of the given input File to the given output File.
copy(byte[], File) - Static method in class org.elasticsearch.util.io.Streams
Copy the contents of the given byte array to the given output File.
copy(InputStream, OutputStream) - Static method in class org.elasticsearch.util.io.Streams
Copy the contents of the given InputStream to the given OutputStream.
copy(byte[], OutputStream) - Static method in class org.elasticsearch.util.io.Streams
Copy the contents of the given byte array to the given OutputStream.
copy(Reader, Writer) - Static method in class org.elasticsearch.util.io.Streams
Copy the contents of the given Reader to the given Writer.
copy(String, Writer) - Static method in class org.elasticsearch.util.io.Streams
Copy the contents of the given String to the given output Writer.
copyFile(File, File) - Static method in class org.elasticsearch.util.io.FileSystemUtils
 
copyFromDirectory(Directory, String, File) - Static method in class org.elasticsearch.util.lucene.Directories
 
copyFromDirectory(IndexInput, OutputStream) - Static method in class org.elasticsearch.util.lucene.Directories
 
copyInto(S) - Method in class org.elasticsearch.util.collect.Sets.SetView
Copies the current contents of this set view into an existing set.
copyOf(Map<? extends K, ? extends V>) - Static method in class org.elasticsearch.util.collect.ImmutableBiMap
Returns an immutable bimap containing the same entries as map.
copyOf(Map<? extends Class<? extends S>, ? extends S>) - Static method in class org.elasticsearch.util.collect.ImmutableClassToInstanceMap
Returns an immutable map containing the same entries as map.
copyOf(Iterable<? extends E>) - Static method in class org.elasticsearch.util.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(Iterator<? extends E>) - Static method in class org.elasticsearch.util.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
copyOf(Multimap<? extends K, ? extends V>) - Static method in class org.elasticsearch.util.collect.ImmutableListMultimap
Returns an immutable multimap containing the same mappings as multimap.
copyOf(Map<? extends K, ? extends V>) - Static method in class org.elasticsearch.util.collect.ImmutableMap
Returns an immutable map containing the same entries as map.
copyOf(Multimap<? extends K, ? extends V>) - Static method in class org.elasticsearch.util.collect.ImmutableMultimap
Returns an immutable multimap containing the same mappings as multimap.
copyOf(Iterable<? extends E>) - Static method in class org.elasticsearch.util.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements.
copyOf(Iterator<? extends E>) - Static method in class org.elasticsearch.util.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements.
copyOf(Iterable<? extends E>) - Static method in class org.elasticsearch.util.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
copyOf(Iterator<? extends E>) - Static method in class org.elasticsearch.util.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
copyOf(Multimap<? extends K, ? extends V>) - Static method in class org.elasticsearch.util.collect.ImmutableSetMultimap
Returns an immutable set multimap containing the same mappings as multimap.
copyOf(Map<? extends K, ? extends V>) - Static method in class org.elasticsearch.util.collect.ImmutableSortedMap
Returns an immutable map containing the same entries as map, sorted by the natural ordering of the keys.
copyOf(Map<? extends K, ? extends V>, Comparator<? super K>) - Static method in class org.elasticsearch.util.collect.ImmutableSortedMap
Returns an immutable map containing the same entries as map, with keys sorted by the provided comparator.
copyOf(Iterable<? extends E>) - Static method in class org.elasticsearch.util.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Iterator<? extends E>) - Static method in class org.elasticsearch.util.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
copyOf(Comparator<? super E>, Iterable<? extends E>) - Static method in class org.elasticsearch.util.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by the given Comparator.
copyOf(Comparator<? super E>, Iterator<? extends E>) - Static method in class org.elasticsearch.util.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by the given Comparator.
copyOfSorted(SortedMap<K, ? extends V>) - Static method in class org.elasticsearch.util.collect.ImmutableSortedMap
Returns an immutable map containing the same entries as the provided sorted map, with the same ordering.
copyOfSorted(SortedSet<E>) - Static method in class org.elasticsearch.util.collect.ImmutableSortedSet
Returns an immutable sorted set containing the elements of a sorted set, sorted by the same Comparator.
CopyOnWriteMap<K,V> - Class in org.elasticsearch.util.concurrent
Provides the semantics of a thread safe copy on write map.
CopyOnWriteMap() - Constructor for class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
copyText(Unicode.UTF16Result) - Method in class org.elasticsearch.util.Unicode.UTF16Result
 
copyTo(byte[], int) - Method in class org.elasticsearch.util.io.compression.lzf.LZFChunk
 
copyToByteArray(File) - Static method in class org.elasticsearch.util.io.Streams
Copy the contents of the given input File into a new byte array.
copyToByteArray(InputStream) - Static method in class org.elasticsearch.util.io.Streams
Copy the contents of the given InputStream into a new byte array.
copyToBytesFromClasspath(String) - Static method in class org.elasticsearch.util.io.Streams
 
copyToDirectory(File, Directory, String) - Static method in class org.elasticsearch.util.lucene.Directories
 
copyToDirectory(InputStream, Directory, String) - Static method in class org.elasticsearch.util.lucene.Directories
 
copyToDirectory(InputStream, IndexOutput) - Static method in class org.elasticsearch.util.lucene.Directories
 
copyToString(Reader) - Static method in class org.elasticsearch.util.io.Streams
Copy the contents of the given Reader into a String.
copyToStringFromClasspath(ClassLoader, String) - Static method in class org.elasticsearch.util.io.Streams
 
copyToStringFromClasspath(String) - Static method in class org.elasticsearch.util.io.Streams
 
coresPerSocket() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
count() - Method in class org.elasticsearch.action.count.CountResponse
The count of documents matching the query provided.
COUNT - Static variable in class org.elasticsearch.action.TransportActions
 
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.node.NodeClient
 
count(CountRequest, ActionListener<CountResponse>) - Method in class org.elasticsearch.client.node.NodeClient
 
count(CountRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
count(CountRequest, ActionListener<CountResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
count(CountRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
count(CountRequest, ActionListener<CountResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
count(float, byte[], String, String...) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
count(float, byte[], int, int, String, String...) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
count(float, byte[], String, String...) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
count(float, byte[], int, int, String, String...) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
count() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Threads
 
count() - Method in class org.elasticsearch.search.facets.CountFacet
The count of the facet.
count(Object) - Method in class org.elasticsearch.util.collect.ConcurrentHashMultiset
Returns the number of occurrences of element in this multiset.
count(Object) - Method in class org.elasticsearch.util.collect.ForwardingMultiset
 
count(Object) - Method in class org.elasticsearch.util.collect.ImmutableMultiset
 
count(Object) - Method in interface org.elasticsearch.util.collect.Multiset
Returns the number of occurrences of an element in this multiset (the count of the element).
count(Object) - Method in class org.elasticsearch.util.collect.TreeMultiset
 
count - Variable in class org.elasticsearch.util.io.FastByteArrayInputStream
The index one greater than the last valid character in the input stream buffer.
count - Variable in class org.elasticsearch.util.io.FastByteArrayOutputStream
The number of valid bytes in the buffer.
count - Variable in class org.elasticsearch.util.io.FastCharArrayReader
The index of the end of this buffer.
count - Variable in class org.elasticsearch.util.io.FastCharArrayWriter
The number of chars in the buffer.
count - Variable in class org.elasticsearch.util.io.stream.BytesStreamInput
 
count - Variable in class org.elasticsearch.util.io.stream.BytesStreamOutput
The number of valid bytes in the buffer.
count(IndexSearcher, Query, float) - Static method in class org.elasticsearch.util.lucene.Lucene
 
count() - Method in class org.elasticsearch.util.lucene.Lucene.CountCollector
 
Counter - Class in org.elasticsearch.util.concurrent.highscalelib
A simple high-performance counter.
Counter() - Constructor for class org.elasticsearch.util.concurrent.highscalelib.Counter
 
counterGetAndIncrement() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
 
CountFacet - Class in org.elasticsearch.search.facets
A count facet is a facet that holds a count.
CountFacet(String, long) - Constructor for class org.elasticsearch.search.facets.CountFacet
 
countFacet(String) - Method in class org.elasticsearch.search.facets.Facets
A specific count facet against the registered facet name.
countOccurrencesOf(String, String) - Static method in class org.elasticsearch.util.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.
CountResponse - Class in org.elasticsearch.action.count
The response of the count action.
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.index.IndexRequest
Set to true to force this index to use IndexRequest.OpType.CREATE.
CREATE - Static variable in class org.elasticsearch.action.TransportActions.Admin.Indices
 
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.node.NodeIndicesAdminClient
 
create(CreateIndexRequest, ActionListener<CreateIndexResponse>) - Method in class org.elasticsearch.client.node.NodeIndicesAdminClient
 
create(CreateIndexRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
create(CreateIndexRequest, ActionListener<CreateIndexResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
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(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.FrenchStemTokenFilterFactory
 
create(TokenStream) - Method in class org.elasticsearch.index.analysis.GermanStemTokenFilterFactory
 
create(Reader) - Method in class org.elasticsearch.index.analysis.KeywordTokenizerFactory
 
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(TokenStream) - Method in class org.elasticsearch.index.analysis.NGramTokenFilterFactory
 
create(Reader) - Method in class org.elasticsearch.index.analysis.NGramTokenizerFactory
 
create(TokenStream) - Method in class org.elasticsearch.index.analysis.PorterStemTokenFilterFactory
 
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.StandardTokenFilterFactory
 
create(Reader) - Method in class org.elasticsearch.index.analysis.StandardTokenizerFactory
 
create(TokenStream) - Method in class org.elasticsearch.index.analysis.StopTokenFilterFactory
 
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(Reader) - Method in class org.elasticsearch.index.analysis.WhitespaceTokenizerFactory
 
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.IndexQueryParserFactory
 
create(String, Settings) - Method in interface org.elasticsearch.index.query.xcontent.XContentFilterParserFactory
 
create(String, Settings) - Method in interface org.elasticsearch.index.query.xcontent.XContentQueryParserFactory
 
create(String, String, byte[]) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
create(String, String, byte[]) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
create(String, Settings) - Method in interface org.elasticsearch.index.similarity.SimilarityProviderFactory
 
create(String, Settings) - Method in interface org.elasticsearch.monitor.dump.DumpContributorFactory
 
create() - Static method in class org.elasticsearch.util.collect.ArrayListMultimap
Creates a new, empty ArrayListMultimap with the default initial capacities.
create(int, int) - Static method in class org.elasticsearch.util.collect.ArrayListMultimap
Constructs an empty ArrayListMultimap with enough capacity to hold the specified numbers of keys and values without resizing.
create(Multimap<? extends K, ? extends V>) - Static method in class org.elasticsearch.util.collect.ArrayListMultimap
Constructs an ArrayListMultimap with the same mappings as the specified multimap.
create() - Static method in class org.elasticsearch.util.collect.ConcurrentHashMultiset
Creates a new, empty ConcurrentHashMultiset using the default initial capacity, load factor, and concurrency settings.
create(Iterable<? extends E>) - Static method in class org.elasticsearch.util.collect.ConcurrentHashMultiset
Creates a new ConcurrentHashMultiset containing the specified elements, using the default initial capacity, load factor, and concurrency settings.
create(Class<K>, Class<V>) - Static method in class org.elasticsearch.util.collect.EnumBiMap
Returns a new, empty EnumBiMap using the specified key and value types.
create(Map<K, V>) - Static method in class org.elasticsearch.util.collect.EnumBiMap
Returns a new bimap with the same mappings as the specified map.
create(Class<K>) - Static method in class org.elasticsearch.util.collect.EnumHashBiMap
Returns a new, empty EnumHashBiMap using the specified key type.
create(Map<K, ? extends V>) - Static method in class org.elasticsearch.util.collect.EnumHashBiMap
Constructs a new bimap with the same mappings as the specified map.
create(Class<E>) - Static method in class org.elasticsearch.util.collect.EnumMultiset
Creates an empty EnumMultiset.
create(Iterable<E>) - Static method in class org.elasticsearch.util.collect.EnumMultiset
Creates a new EnumMultiset containing the specified elements.
create() - Static method in class org.elasticsearch.util.collect.HashBiMap
Returns a new, empty HashBiMap with the default initial capacity (16).
create(int) - Static method in class org.elasticsearch.util.collect.HashBiMap
Constructs a new, empty bimap with the specified expected size.
create(Map<? extends K, ? extends V>) - Static method in class org.elasticsearch.util.collect.HashBiMap
Constructs a new bimap containing initial values from map.
create() - Static method in class org.elasticsearch.util.collect.HashMultimap
Creates a new, empty HashMultimap with the default initial capacities.
create(int, int) - Static method in class org.elasticsearch.util.collect.HashMultimap
Constructs an empty HashMultimap with enough capacity to hold the specified numbers of keys and values without rehashing.
create(Multimap<? extends K, ? extends V>) - Static method in class org.elasticsearch.util.collect.HashMultimap
Constructs a HashMultimap with the same mappings as the specified multimap.
create() - Static method in class org.elasticsearch.util.collect.HashMultiset
Creates a new, empty HashMultiset using the default initial capacity.
create(int) - Static method in class org.elasticsearch.util.collect.HashMultiset
Creates a new, empty HashMultiset with the specified expected number of distinct elements.
create(Iterable<? extends E>) - Static method in class org.elasticsearch.util.collect.HashMultiset
Creates a new HashMultiset containing the specified elements.
create() - Static method in class org.elasticsearch.util.collect.LinkedHashMultimap
Creates a new, empty LinkedHashMultimap with the default initial capacities.
create(int, int) - Static method in class org.elasticsearch.util.collect.LinkedHashMultimap
Constructs an empty LinkedHashMultimap with enough capacity to hold the specified numbers of keys and values without rehashing.
create(Multimap<? extends K, ? extends V>) - Static method in class org.elasticsearch.util.collect.LinkedHashMultimap
Constructs a LinkedHashMultimap with the same mappings as the specified multimap.
create() - Static method in class org.elasticsearch.util.collect.LinkedHashMultiset
Creates a new, empty LinkedHashMultiset using the default initial capacity.
create(int) - Static method in class org.elasticsearch.util.collect.LinkedHashMultiset
Creates a new, empty LinkedHashMultiset with the specified expected number of distinct elements.
create(Iterable<? extends E>) - Static method in class org.elasticsearch.util.collect.LinkedHashMultiset
Creates a new LinkedHashMultiset containing the specified elements.
create() - Static method in class org.elasticsearch.util.collect.LinkedListMultimap
Creates a new, empty LinkedListMultimap with the default initial capacity.
create(int) - Static method in class org.elasticsearch.util.collect.LinkedListMultimap
Constructs an empty LinkedListMultimap with enough capacity to hold the specified number of keys without rehashing.
create(Multimap<? extends K, ? extends V>) - Static method in class org.elasticsearch.util.collect.LinkedListMultimap
Constructs a LinkedListMultimap with the same mappings as the specified Multimap.
create() - Static method in class org.elasticsearch.util.collect.MutableClassToInstanceMap
Returns a new MutableClassToInstanceMap instance backed by a HashMap using the default initial capacity and load factor.
create(Map<Class<? extends B>, B>) - Static method in class org.elasticsearch.util.collect.MutableClassToInstanceMap
Returns a new MutableClassToInstanceMap instance backed by a given empty backingMap.
create() - Static method in class org.elasticsearch.util.collect.TreeMultimap
Creates an empty TreeMultimap ordered by the natural ordering of its keys and values.
create(Comparator<? super K>, Comparator<? super V>) - Static method in class org.elasticsearch.util.collect.TreeMultimap
Creates an empty TreeMultimap instance using explicit comparators.
create(Multimap<? extends K, ? extends V>) - Static method in class org.elasticsearch.util.collect.TreeMultimap
Constructs a TreeMultimap, ordered by the natural ordering of its keys and values, with the same mappings as the specified multimap.
create() - Static method in class org.elasticsearch.util.collect.TreeMultiset
Creates a new, empty multiset, sorted according to the elements' natural order.
create(Comparator<? super E>) - Static method in class org.elasticsearch.util.collect.TreeMultiset
Creates a new, empty multiset, sorted according to the specified comparator.
create(Iterable<? extends E>) - Static method in class org.elasticsearch.util.collect.TreeMultiset
Creates an empty multiset containing the given initial elements, sorted according to the elements' natural order.
create(K, Errors) - Method in class org.elasticsearch.util.inject.internal.FailableCache
 
create() - Static method in class org.elasticsearch.util.inject.internal.UniqueAnnotations
Returns an annotation instance that is not equal to any other annotation instances, for use in creating distinct Keys.
CREATE_CONNECTOR - Static variable in class org.elasticsearch.jmx.JmxService.SettingsConstants
 
createChildInjector(Iterable<? extends Module>) - Method in interface org.elasticsearch.util.inject.Injector
Returns a new injector that inherits all state from this injector.
createChildInjector(Module...) - Method in interface org.elasticsearch.util.inject.Injector
Returns a new injector that inherits all state from this injector.
createCompressed(int, byte[], int, int) - Static method in class org.elasticsearch.util.io.compression.lzf.LZFChunk
Factory method for constructing compressed chunk
CreateFailedEngineException - Exception in org.elasticsearch.index.engine
 
CreateFailedEngineException(ShardId, Engine.Create, Throwable) - Constructor for exception org.elasticsearch.index.engine.CreateFailedEngineException
 
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
 
createGenerator(OutputStream) - Method in class org.elasticsearch.util.xcontent.json.JsonXContent
 
createGenerator(Writer) - Method in class org.elasticsearch.util.xcontent.json.JsonXContent
 
createGenerator(OutputStream) - Method in interface org.elasticsearch.util.xcontent.XContent
Creates a new generator using the provided output stream.
createGenerator(Writer) - Method in interface org.elasticsearch.util.xcontent.XContent
Creates a new generator using the provided writer.
createGenerator(OutputStream) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContent
 
createGenerator(Writer) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContent
 
createIndex(String, String, Settings, Map<String, String>, TimeValue) - Method in class org.elasticsearch.cluster.metadata.MetaDataService
 
createIndex(String, Settings, String) - Method in interface org.elasticsearch.indices.IndicesService
 
createIndex(String, Settings, String) - Method in class org.elasticsearch.indices.InternalIndicesService
 
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.
CreateIndexResponse - Class in org.elasticsearch.action.admin.indices.create
A response for a create index action.
createInjector(Module...) - Static method in class org.elasticsearch.util.inject.Guice
Creates an injector for the given set of modules.
createInjector(Iterable<? extends Module>) - Static method in class org.elasticsearch.util.inject.Guice
Creates an injector for the given set of modules.
createInjector(Stage, Module...) - Static method in class org.elasticsearch.util.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.util.inject.Guice
Creates an injector for the given set of modules, in a given development stage.
createModule(String, Settings) - Static method in class org.elasticsearch.util.guice.ModulesFactory
 
createModule(Class<? extends Module>, Settings) - Static method in class org.elasticsearch.util.guice.ModulesFactory
 
createNonCompressed(byte[], int, int) - Static method in class org.elasticsearch.util.io.compression.lzf.LZFChunk
Factory method for constructing compressed chunk
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
 
createOutput(String) - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectory
 
createOutput(String) - Method in class org.elasticsearch.index.store.memory.HeapDirectory
 
createOutput(String) - Method in class org.elasticsearch.util.lucene.store.SwitchDirectory
 
createParser(String) - Method in class org.elasticsearch.util.xcontent.json.JsonXContent
 
createParser(InputStream) - Method in class org.elasticsearch.util.xcontent.json.JsonXContent
 
createParser(byte[]) - Method in class org.elasticsearch.util.xcontent.json.JsonXContent
 
createParser(byte[], int, int) - Method in class org.elasticsearch.util.xcontent.json.JsonXContent
 
createParser(Reader) - Method in class org.elasticsearch.util.xcontent.json.JsonXContent
 
createParser(String) - Method in interface org.elasticsearch.util.xcontent.XContent
Creates a parser over the provided string content.
createParser(InputStream) - Method in interface org.elasticsearch.util.xcontent.XContent
Creates a parser over the provided input stream.
createParser(byte[]) - Method in interface org.elasticsearch.util.xcontent.XContent
Creates a parser over the provided bytes.
createParser(byte[], int, int) - Method in interface org.elasticsearch.util.xcontent.XContent
Creates a parser over the provided bytes.
createParser(Reader) - Method in interface org.elasticsearch.util.xcontent.XContent
Creates a parser over the provided reader.
createParser(String) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContent
 
createParser(InputStream) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContent
 
createParser(byte[]) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContent
 
createParser(byte[], int, int) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContent
 
createParser(Reader) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContent
 
createPatternParser(String) - Method in class org.elasticsearch.util.logging.log4j.JLinePatternLayout
 
createProxy(Errors, Class<?>) - Method in class org.elasticsearch.util.inject.internal.ConstructionContext
 
createShard(int) - Method in interface org.elasticsearch.index.service.IndexService
 
createShard(int) - Method in class org.elasticsearch.index.service.InternalIndexService
 
createStoreFilePath(File, String, ShardId, String) - Static method in class org.elasticsearch.index.store.fs.FsStores
 
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(Query) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
createWeight(Searcher) - Method in class org.elasticsearch.util.lucene.all.AllTermQuery
 
createWeight(Searcher) - Method in class org.elasticsearch.util.lucene.search.CustomBoostFactorQuery
 
CreationException - Exception in org.elasticsearch.util.inject
Thrown when errors occur while creating a Injector.
CreationException(Collection<Message>) - Constructor for exception org.elasticsearch.util.inject.CreationException
Creates a CreationException containing messages.
current() - Static method in class org.elasticsearch.util.concurrent.jsr166y.ThreadLocalRandom
Returns the current thread's ThreadLocalRandom.
current() - Method in class org.elasticsearch.util.lucene.all.AllEntries
 
CURRENT - Static variable in interface org.elasticsearch.util.ThreadNameDeterminer
ThreadNameDeterminer that rejects the proposed thread name and retains the current one.
currentId() - Method in class org.elasticsearch.index.translog.memory.MemoryTranslog
 
currentId() - Method in interface org.elasticsearch.index.translog.Translog
Returns the id of the current transaction log.
currentName() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
currentName() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
currentName() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
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
 
currentStage() - Method in class org.elasticsearch.util.inject.AbstractModule
 
currentStage() - Method in interface org.elasticsearch.util.inject.Binder
Gets the current stage.
currentStage() - Method in class org.elasticsearch.util.inject.PrivateModule
 
currentState() - Method in exception org.elasticsearch.index.shard.IllegalIndexShardStateException
 
currentToken() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
currentToken() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
currentToken() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
currEstab() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
CustomAnalyzer - Class in org.elasticsearch.index.analysis
 
CustomAnalyzer(TokenizerFactory, TokenFilterFactory[]) - 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, Map<String, TokenizerFactoryFactory>, Map<String, TokenFilterFactoryFactory>, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CustomAnalyzerProvider
 
customBoostFactorQuery(XContentQueryBuilder) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A query that simply applies the boost fact to the wrapped query (multiplies it).
CustomBoostFactorQuery - Class in org.elasticsearch.util.lucene.search
A query that wraps another query and applies the provided boost values to it.
CustomBoostFactorQuery(Query, float) - Constructor for class org.elasticsearch.util.lucene.search.CustomBoostFactorQuery
 
CustomBoostFactorQueryBuilder - Class in org.elasticsearch.index.query.xcontent
A query that simply applies the boost factor to another query (multiply it).
CustomBoostFactorQueryBuilder(XContentQueryBuilder) - Constructor for class org.elasticsearch.index.query.xcontent.CustomBoostFactorQueryBuilder
A query that simply applies the boost factor to another query (multiply it).
CustomBoostFactorQueryParser - Class in org.elasticsearch.index.query.xcontent
 
CustomBoostFactorQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.CustomBoostFactorQueryParser
 
CustomFieldQuery - Class in org.apache.lucene.search.vectorhighlight
 
CustomFieldQuery(Query, FastVectorHighlighter) - Constructor for class org.apache.lucene.search.vectorhighlight.CustomFieldQuery
 
CustomFieldQuery(Query, boolean, boolean) - Constructor for class org.apache.lucene.search.vectorhighlight.CustomFieldQuery
 
CYAN - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
cycle(Iterable<T>) - Static method in class org.elasticsearch.util.collect.Iterables
Returns an iterable whose iterators cycle indefinitely over the elements of iterable.
cycle(T...) - Static method in class org.elasticsearch.util.collect.Iterables
Returns an iterable whose iterators cycle indefinitely over the provided elements.
cycle(Iterable<T>) - Static method in class org.elasticsearch.util.collect.Iterators
Returns an iterator that cycles indefinitely over the elements of iterable.
cycle(T...) - Static method in class org.elasticsearch.util.collect.Iterators
Returns an iterator that cycles indefinitely over the provided elements.
CzechAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
CzechAnalyzerProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.CzechAnalyzerProvider
 

D

daemonThreadFactory(Settings, String) - Static method in class org.elasticsearch.util.concurrent.DynamicExecutors
 
daemonThreadFactory(String) - Static method in class org.elasticsearch.util.concurrent.DynamicExecutors
A priority based thread factory, for all Thread priority constants: Thread.MIN_PRIORITY, Thread.NORM_PRIORITY, Thread.MAX_PRIORITY;

This factory is used instead of Executers.DefaultThreadFactory to allow manipulation of priority and thread owner name.

data(boolean) - Method in class org.elasticsearch.node.NodeBuilder
Is the node going to be allowed to allocate data (shards) to it or not.
DataInputStreamInput - Class in org.elasticsearch.util.io.stream
 
DataInputStreamInput(DataInput) - Constructor for class org.elasticsearch.util.io.stream.DataInputStreamInput
 
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.util.io.stream
 
DataOutputStreamOutput(DataOutput) - Constructor for class org.elasticsearch.util.io.stream.DataOutputStreamOutput
 
date() - Static method in class org.elasticsearch.Version
 
DATE_TIME_FORMATTER - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper.Defaults
 
DATE_TIME_FORMATTERS - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.Defaults
 
dateField(String) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
dateTimeFormatter - Variable in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper.Builder
 
dateTimeFormatter(FormatDateTimeFormatter) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper.Builder
 
dateTimeFormatter(Iterable<FormatDateTimeFormatter>) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.Builder
 
dateTimeFormatter(FormatDateTimeFormatter[]) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.Builder
 
dateTimeFormatter(FormatDateTimeFormatter) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.Builder
 
days() - Method in class org.elasticsearch.util.TimeValue
 
daysFrac() - Method in class org.elasticsearch.util.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) - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
 
debug(String, Throwable) - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
 
debug(String, Object...) - Method in interface org.elasticsearch.util.logging.ESLogger
Logs a DEBUG level message.
debug(String, Throwable, Object...) - Method in interface org.elasticsearch.util.logging.ESLogger
Logs a DEBUG level message.
debug(String, Object...) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
debug(String, Throwable, Object...) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
decode(ChannelHandlerContext, Channel, ChannelBuffer) - Method in class org.elasticsearch.transport.netty.SizeHeaderFrameDecoder
 
DECODE - Static variable in class org.elasticsearch.util.Base64
Specify decoding in first bit.
decode(byte[]) - Static method in class org.elasticsearch.util.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.util.Base64
Low-level access to decoding ASCII characters in the form of a byte array.
decode(String) - Static method in class org.elasticsearch.util.Base64
Decodes data from Base64 notation, automatically detecting gzip-compressed data and decompressing it.
decode(String, int) - Static method in class org.elasticsearch.util.Base64
Decodes data from Base64 notation, automatically detecting gzip-compressed data and decompressing it.
decode(byte[], int) - Static method in class org.elasticsearch.util.io.compression.lzf.LZFDecoder
Method for decompressing whole input data, which encoded in LZF block structure (compatible with lzf command line utility), and can consist of any number of blocks
decodeFileToFile(String, String) - Static method in class org.elasticsearch.util.Base64
Reads infile and decodes it to outfile.
decodeFromFile(String) - Static method in class org.elasticsearch.util.Base64
Convenience method for reading a base64-encoded file and decoding it.
decodeQueryString(String, int, Map<String, String>) - Static method in class org.elasticsearch.rest.support.RestUtils
 
decodeToFile(String, String) - Static method in class org.elasticsearch.util.Base64
Convenience method for decoding data to a file.
decodeToObject(String) - Static method in class org.elasticsearch.util.Base64
Attempts to decode Base64 data and deserialize a Java Object within.
decodeToObject(String, int, ClassLoader) - Static method in class org.elasticsearch.util.Base64
Attempts to decode Base64 data and deserialize a Java Object within.
decompress(byte[]) - Method in interface org.elasticsearch.util.io.compression.Compressor
 
decompress(byte[]) - Method in class org.elasticsearch.util.io.compression.GZIPCompressor
 
decompress(byte[]) - Method in class org.elasticsearch.util.io.compression.LzfCompressor
 
decompress(byte[]) - Method in class org.elasticsearch.util.io.compression.ZipCompressor
 
decompressChunk(byte[], int, byte[], int, int) - Static method in class org.elasticsearch.util.io.compression.lzf.LZFDecoder
Main decode method for individual chunks.
decompressString(byte[]) - Method in interface org.elasticsearch.util.io.compression.Compressor
 
decompressString(byte[]) - Method in class org.elasticsearch.util.io.compression.GZIPCompressor
 
decompressString(byte[]) - Method in class org.elasticsearch.util.io.compression.LzfCompressor
 
decompressString(byte[]) - Method in class org.elasticsearch.util.io.compression.ZipCompressor
 
Decorators - Class in org.elasticsearch.util.gnu.trove
This is a static utility class that provides functions for simplifying creation of decorators.
decrement() - Method in class org.elasticsearch.util.concurrent.highscalelib.ConcurrentAutoTable
ConcurrentAutoTable.add(long) with -1
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.index.query.IndexQueryParserService.Defaults
 
DEFAULT_CAPACITY - Static variable in class org.elasticsearch.util.gnu.trove.TByteArrayList
the default capacity for new lists
DEFAULT_CAPACITY - Static variable in class org.elasticsearch.util.gnu.trove.TByteStack
 
DEFAULT_CAPACITY - Static variable in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
the default capacity for new lists
DEFAULT_CAPACITY - Static variable in class org.elasticsearch.util.gnu.trove.TDoubleStack
 
DEFAULT_CAPACITY - Static variable in class org.elasticsearch.util.gnu.trove.TFloatArrayList
the default capacity for new lists
DEFAULT_CAPACITY - Static variable in class org.elasticsearch.util.gnu.trove.TFloatStack
 
DEFAULT_CAPACITY - Static variable in class org.elasticsearch.util.gnu.trove.TIntArrayList
the default capacity for new lists
DEFAULT_CAPACITY - Static variable in class org.elasticsearch.util.gnu.trove.TIntStack
 
DEFAULT_CAPACITY - Static variable in class org.elasticsearch.util.gnu.trove.TLongArrayList
the default capacity for new lists
DEFAULT_CAPACITY - Static variable in class org.elasticsearch.util.gnu.trove.TLongStack
 
DEFAULT_CAPACITY - Static variable in class org.elasticsearch.util.gnu.trove.TShortArrayList
the default capacity for new lists
DEFAULT_CAPACITY - Static variable in class org.elasticsearch.util.gnu.trove.TShortStack
 
DEFAULT_INDICES_LOCATION - Static variable in class org.elasticsearch.index.store.fs.FsStores
 
DEFAULT_INITIAL_CAPACITY - Static variable in class org.elasticsearch.util.gnu.trove.THash
the default initial capacity for the hash table.
DEFAULT_INSTANCE - Static variable in class org.elasticsearch.util.inject.internal.SourceProvider
 
DEFAULT_LOAD_FACTOR - Static variable in class org.elasticsearch.util.gnu.trove.THash
the load above which rehashing occurs.
DEFAULT_MIN_SCORE - Static variable in class org.elasticsearch.action.count.CountRequest
 
DEFAULT_NUM_LARGE_SEGMENTS - Static variable in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy
 
DEFAULT_PERCENT_TERMS_TO_MATCH - Static variable in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
DEFAULT_TIMEOUT - Static variable in class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
defaultAnalyzer() - Method in class org.elasticsearch.index.analysis.AnalysisService
 
DefaultBindingScopingVisitor<V> - Class in org.elasticsearch.util.inject.spi
No-op visitor for subclassing.
DefaultBindingScopingVisitor() - Constructor for class org.elasticsearch.util.inject.spi.DefaultBindingScopingVisitor
 
DefaultBindingTargetVisitor<T,V> - Class in org.elasticsearch.util.inject.spi
No-op visitor for subclassing.
DefaultBindingTargetVisitor() - Constructor for class org.elasticsearch.util.inject.spi.DefaultBindingTargetVisitor
 
defaultDatePrinter - Static variable in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
DefaultElementVisitor<V> - Class in org.elasticsearch.util.inject.spi
No-op visitor for subclassing.
DefaultElementVisitor() - Constructor for class org.elasticsearch.util.inject.spi.DefaultElementVisitor
 
defaultField(String) - Method in class org.elasticsearch.index.query.xcontent.QueryStringQueryBuilder
The default field to run against when no prefix field is specified.
defaultForkJoinWorkerThreadFactory - Static variable in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Creates a new ForkJoinWorkerThread.
defaultIndexAnalyzer() - Method in class org.elasticsearch.index.analysis.AnalysisService
 
defaultIndexQueryParser() - Method in class org.elasticsearch.index.query.IndexQueryParserService
 
defaultIndexSimilarity() - Method in class org.elasticsearch.index.similarity.SimilarityService
 
defaultMapper() - Method in class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper
 
defaultOperator(FieldQueryBuilder.Operator) - Method in class org.elasticsearch.index.query.xcontent.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.xcontent.QueryStringQueryBuilder
Sets the boolean operator of the query parser used to parse the query string.
defaultReturnValue(int) - Method in class org.elasticsearch.util.trove.ExtTIntIntHashMap
 
defaultReturnValue(float) - Method in class org.elasticsearch.util.trove.ExtTObjectFloatHashMap
 
defaultReturnValue(int) - Method in class org.elasticsearch.util.trove.ExtTObjectIntHasMap
 
defaultReuseAddress() - Static method in class org.elasticsearch.util.network.NetworkUtils
 
defaultSearchAnalyzer() - 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
 
DefaultShardsRoutingStrategy - Class in org.elasticsearch.cluster.routing.strategy
 
DefaultShardsRoutingStrategy() - Constructor for class org.elasticsearch.cluster.routing.strategy.DefaultShardsRoutingStrategy
 
DefaultSimilarityProvider - Class in org.elasticsearch.index.similarity
 
DefaultSimilarityProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.similarity.DefaultSimilarityProvider
 
delay(TimeValue) - 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
 
delegate() - Method in class org.elasticsearch.util.collect.ForwardingCollection
 
delegate() - Method in class org.elasticsearch.util.collect.ForwardingConcurrentMap
 
delegate() - Method in class org.elasticsearch.util.collect.ForwardingIterator
 
delegate() - Method in class org.elasticsearch.util.collect.ForwardingList
 
delegate() - Method in class org.elasticsearch.util.collect.ForwardingListIterator
 
delegate() - Method in class org.elasticsearch.util.collect.ForwardingMap
 
delegate() - Method in class org.elasticsearch.util.collect.ForwardingMapEntry
 
delegate() - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
delegate() - Method in class org.elasticsearch.util.collect.ForwardingMultiset
 
delegate() - Method in class org.elasticsearch.util.collect.ForwardingObject
Returns the backing delegate instance that methods are forwarded to.
delegate() - Method in class org.elasticsearch.util.collect.ForwardingQueue
 
delegate() - Method in class org.elasticsearch.util.collect.ForwardingSet
 
delegate() - Method in class org.elasticsearch.util.collect.ForwardingSortedMap
 
delegate() - Method in class org.elasticsearch.util.collect.ForwardingSortedSet
 
delegate() - Method in class org.elasticsearch.util.collect.ImmutableClassToInstanceMap
 
delegate - Variable in class org.elasticsearch.util.lucene.IndexCommitDelegate
 
DELETE - Static variable in class org.elasticsearch.action.TransportActions.Admin.Indices
 
DELETE - Static variable in class org.elasticsearch.action.TransportActions
 
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.node.NodeClient
 
delete(DeleteRequest, ActionListener<DeleteResponse>) - Method in class org.elasticsearch.client.node.NodeClient
 
delete(DeleteIndexRequest) - Method in class org.elasticsearch.client.node.NodeIndicesAdminClient
 
delete(DeleteIndexRequest, ActionListener<DeleteIndexResponse>) - Method in class org.elasticsearch.client.node.NodeIndicesAdminClient
 
delete(DeleteRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
delete(DeleteRequest, ActionListener<DeleteResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
delete(DeleteIndexRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
delete(DeleteIndexRequest, ActionListener<DeleteIndexResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
delete(DeleteRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
delete(DeleteRequest, ActionListener<DeleteResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
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(String, String) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
delete(Term) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
delete(String, String) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
delete(Term) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
delete() - Method in class org.elasticsearch.util.lucene.IndexCommitDelegate
 
delete(String, String) - Static method in class org.elasticsearch.util.Strings
Delete all occurrences of the given substring.
DELETE_BY_QUERY - Static variable in class org.elasticsearch.action.TransportActions
 
deleteAny(String, String) - Static method in class org.elasticsearch.util.Strings
Delete any character in a given String.
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.node.NodeClient
 
deleteByQuery(DeleteByQueryRequest, ActionListener<DeleteByQueryResponse>) - Method in class org.elasticsearch.client.node.NodeClient
 
deleteByQuery(DeleteByQueryRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
deleteByQuery(DeleteByQueryRequest, ActionListener<DeleteByQueryResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
deleteByQuery(DeleteByQueryRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
deleteByQuery(DeleteByQueryRequest, ActionListener<DeleteByQueryResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
deleteByQuery(byte[], String, String...) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
deleteByQuery(byte[], String, String...) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
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(String...) - Static method in class org.elasticsearch.client.Requests
Creates a delete by query request.
DeleteByQueryResponse - Class in org.elasticsearch.action.deletebyquery
The response of delete by query action.
deleteByQueryShards(ClusterState) - Method in interface org.elasticsearch.index.routing.OperationRouting
Returns the shards grouped by shard
deleteByQueryShards(ClusterState) - Method in class org.elasticsearch.index.routing.plain.PlainOperationRouting
 
deleteContent() - Method in interface org.elasticsearch.index.store.Store
Just deletes the content of the store.
deleteContent() - Method in class org.elasticsearch.index.store.support.AbstractStore
 
deletedDocs() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus.Docs
 
deletedDocs() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus.Docs
 
deletedDocs() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus.Docs
 
deletedDocs() - Method in class org.elasticsearch.action.terms.TermsResponse
The number of deleted docs.
DeleteFailedEngineException - Exception in org.elasticsearch.index.engine
 
DeleteFailedEngineException(ShardId, Engine.Delete, Throwable) - Constructor for exception org.elasticsearch.index.engine.DeleteFailedEngineException
 
deleteFile(String) - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectory
 
deleteFile(String) - Method in class org.elasticsearch.index.store.memory.HeapDirectory
 
deleteFile(String) - Method in class org.elasticsearch.util.lucene.store.SwitchDirectory
 
deleteFiles(Directory) - Static method in class org.elasticsearch.util.lucene.Directories
Deletes all the files from a directory.
deleteIndex(String, TimeValue) - Method in class org.elasticsearch.cluster.metadata.MetaDataService
 
deleteIndex(String) - Method in interface org.elasticsearch.indices.IndicesService
 
deleteIndex(String) - Method in class org.elasticsearch.indices.InternalIndicesService
 
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) - Static method in class org.elasticsearch.client.Requests
Creates a delete index request.
DeleteIndexResponse - Class in org.elasticsearch.action.admin.indices.delete
A response for a delete index action.
deleteRecursively(File) - Static method in class org.elasticsearch.util.io.FileSystemUtils
 
deleteRecursively(File, boolean) - Static method in class org.elasticsearch.util.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(String) - Static method in class org.elasticsearch.client.Requests
Creates a delete request against a specific index.
DeleteResponse - Class in org.elasticsearch.action.delete
The response of the delete action.
deleteShards(ClusterState, String, String) - Method in interface org.elasticsearch.index.routing.OperationRouting
 
deleteShards(ClusterState, String, String) - Method in class org.elasticsearch.index.routing.plain.PlainOperationRouting
 
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.util.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.util.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.util.inject.spi
A variable that can be resolved by an injector.
description() - Method in interface org.elasticsearch.plugins.Plugin
The description of the plugin.
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
 
determineThreadName(String, String) - Method in interface org.elasticsearch.util.ThreadNameDeterminer
Overrides the thread name proposed by ThreadRenamingRunnable.
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
 
difference(Map<? extends K, ? extends V>, Map<? extends K, ? extends V>) - Static method in class org.elasticsearch.util.collect.Maps
Computes the difference between two maps.
difference(Set<E>, Set<?>) - Static method in class org.elasticsearch.util.collect.Sets
Returns an unmodifiable view of the difference of two sets.
Directories - Class in org.elasticsearch.util.lucene
A set of utilities for Lucene Directory.
directory() - Method in class org.elasticsearch.index.store.fs.MmapFsStore
 
directory() - Method in class org.elasticsearch.index.store.fs.NioFsStore
 
directory() - Method in class org.elasticsearch.index.store.fs.SimpleFsStore
 
directory() - Method in class org.elasticsearch.index.store.memory.ByteBufferStore
 
directory() - Method in class org.elasticsearch.index.store.memory.HeapStore
 
directory() - Method in class org.elasticsearch.index.store.ram.RamStore
 
directory() - Method in interface org.elasticsearch.index.store.Store
The Lucene Directory this store is using.
disableConsoleLogging() - Static method in class org.elasticsearch.util.logging.Loggers
 
disableCoord(boolean) - Method in class org.elasticsearch.index.query.xcontent.BoolQueryBuilder
Disables Similarity#coord(int,int) in scoring.
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
 
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
 
DiscoveryNodesProvider - Interface in org.elasticsearch.discovery.zen
 
DiscoveryService - Class in org.elasticsearch.discovery
 
DiscoveryService(Settings, Discovery) - Constructor for class org.elasticsearch.discovery.DiscoveryService
 
disMaxClauses(DisjunctionMaxQuery) - Static method in class org.elasticsearch.util.lucene.search.Queries
 
disMaxQuery() - Static method in class org.elasticsearch.index.query.xcontent.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.xcontent
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.xcontent.DisMaxQueryBuilder
 
DisMaxQueryParser - Class in org.elasticsearch.index.query.xcontent
 
DisMaxQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.DisMaxQueryParser
 
dispatchRequest(HttpRequest, HttpChannel) - Method in interface org.elasticsearch.http.HttpServerAdapter
 
dispatchRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.RestController
 
DjbHashFunction - Class in org.elasticsearch.index.routing.hash.djb
 
DjbHashFunction() - Constructor for class org.elasticsearch.index.routing.hash.djb.DjbHashFunction
 
DO_BREAK_LINES - Static variable in class org.elasticsearch.util.Base64
Do break lines when encoding.
doBooleanValue() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
doBooleanValue() - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentParser
 
doBooleanValue() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
doc() - Method in class org.elasticsearch.index.engine.Engine.Create
 
doc() - Method in class org.elasticsearch.index.engine.Engine.Index
 
doc() - Method in class org.elasticsearch.index.mapper.ParsedDocument
 
doc() - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
 
doc(XContentObjectMapper.Builder) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
doc(int) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
doc(int, FieldSelector) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
doc() - Static method in class org.elasticsearch.util.lucene.DocumentBuilder
 
docFreq(Object) - Method in class org.elasticsearch.action.terms.FieldTermsFreq
Returns the document frequency of a term, -1 if the term does not exists.
docFreq() - Method in class org.elasticsearch.action.terms.TermFreq
The document frequency of the term (in how many documents this term exists).
docFreq(Term) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
docFreqs(Term[]) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
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.internal.InternalSearchHit
 
docId(IndexReader, Term) - Static method in class org.elasticsearch.util.lucene.Lucene
 
docIds() - Method in class org.elasticsearch.search.fetch.FetchSearchRequest
 
docIds(IndexReader, Term, int) - Static method in class org.elasticsearch.util.lucene.Lucene
 
docIdSet() - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
docIdSet() - Method in class org.elasticsearch.util.lucene.docidset.DocIdSetCollector
 
DocIdSetCollector - Class in org.elasticsearch.util.lucene.docidset
 
DocIdSetCollector(Collector, IndexReader) - Constructor for class org.elasticsearch.util.lucene.docidset.DocIdSetCollector
 
DocIdSets - Class in org.elasticsearch.util.lucene.docidset
 
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
 
doClose() - Method in class org.elasticsearch.cluster.routing.RoutingService
 
doClose() - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
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.none.NoneGateway
 
doClose() - Method in class org.elasticsearch.http.HttpServer
 
doClose() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
doClose() - Method in class org.elasticsearch.indices.cluster.IndicesClusterStateService
 
doClose() - Method in class org.elasticsearch.indices.InternalIndicesService
 
doClose() - Method in class org.elasticsearch.monitor.jvm.JvmMonitorService
 
doClose() - Method in class org.elasticsearch.monitor.memory.alpha.AlphaMemoryMonitor
 
doClose() - Method in class org.elasticsearch.monitor.memory.MemoryMonitorService
 
doClose() - Method in class org.elasticsearch.monitor.MonitorService
 
doClose() - Method in class org.elasticsearch.rest.RestController
 
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
 
doClose() - Method in class org.elasticsearch.util.component.AbstractLifecycleComponent
 
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.xcontent.MergeContext
 
docMapper() - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
 
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.status.IndexShardStatus
 
docs() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
docs() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
DocumentBuilder - Class in org.elasticsearch.util.lucene
 
DocumentFieldMappers - Class in org.elasticsearch.index.mapper
 
DocumentFieldMappers(DocumentMapper, Iterable<FieldMapper>) - Constructor for class org.elasticsearch.index.mapper.DocumentFieldMappers
 
DocumentMapper - Interface in org.elasticsearch.index.mapper
 
documentMapper(String) - Method in class org.elasticsearch.index.mapper.MapperService
 
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
 
DocumentMapperNotFoundException - Exception in org.elasticsearch.index.mapper
 
DocumentMapperNotFoundException(String) - Constructor for exception org.elasticsearch.index.mapper.DocumentMapperNotFoundException
 
DocumentMapperNotFoundException(String, Throwable) - Constructor for exception org.elasticsearch.index.mapper.DocumentMapperNotFoundException
 
DocumentMapperParser - Interface in org.elasticsearch.index.mapper
 
documentMapperParser() - Method in class org.elasticsearch.index.mapper.MapperService
 
doDoubleValue() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
doDoubleValue() - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentParser
 
doDoubleValue() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
doExecute(DeleteRequest, ActionListener<DeleteResponse>) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
doExecute(IndexRequest, ActionListener<IndexResponse>) - Method in class org.elasticsearch.action.index.TransportIndexAction
 
doExecute(MoreLikeThisRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.action.mlt.TransportMoreLikeThisAction
 
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.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(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.BaseAction
 
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.TransportSingleOperationAction
 
doFloatValue() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
doFloatValue() - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentParser
 
doFloatValue() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
doIntValue() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
doIntValue() - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentParser
 
doIntValue() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
doLongValue() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
doLongValue() - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentParser
 
doLongValue() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
done() - Method in class org.elasticsearch.action.support.AbstractListenableActionFuture
 
done() - Method in class org.elasticsearch.util.concurrent.AbstractFuture
 
DONT_GUNZIP - Static variable in class org.elasticsearch.util.Base64
Specify that gzipped data should not be automatically gunzipped.
doShortValue() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
doShortValue() - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentParser
 
doShortValue() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
doStart() - Method in class org.elasticsearch.cluster.routing.RoutingService
 
doStart() - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
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.fs.FsGateway
 
doStart() - Method in class org.elasticsearch.gateway.GatewayService
 
doStart() - Method in class org.elasticsearch.gateway.none.NoneGateway
 
doStart() - Method in class org.elasticsearch.http.HttpServer
 
doStart() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
doStart() - Method in class org.elasticsearch.indices.cluster.IndicesClusterStateService
 
doStart() - Method in class org.elasticsearch.indices.InternalIndicesService
 
doStart() - Method in class org.elasticsearch.monitor.jvm.JvmMonitorService
 
doStart() - Method in class org.elasticsearch.monitor.memory.alpha.AlphaMemoryMonitor
 
doStart() - Method in class org.elasticsearch.monitor.memory.MemoryMonitorService
 
doStart() - Method in class org.elasticsearch.monitor.MonitorService
 
doStart() - Method in class org.elasticsearch.rest.RestController
 
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
 
doStart() - Method in class org.elasticsearch.util.component.AbstractLifecycleComponent
 
doStop() - Method in class org.elasticsearch.cluster.routing.RoutingService
 
doStop() - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
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.fs.FsGateway
 
doStop() - Method in class org.elasticsearch.gateway.GatewayService
 
doStop() - Method in class org.elasticsearch.gateway.none.NoneGateway
 
doStop() - Method in class org.elasticsearch.http.HttpServer
 
doStop() - Method in class org.elasticsearch.http.netty.NettyHttpServerTransport
 
doStop() - Method in class org.elasticsearch.indices.cluster.IndicesClusterStateService
 
doStop() - Method in class org.elasticsearch.indices.InternalIndicesService
 
doStop() - Method in class org.elasticsearch.monitor.jvm.JvmMonitorService
 
doStop() - Method in class org.elasticsearch.monitor.memory.alpha.AlphaMemoryMonitor
 
doStop() - Method in class org.elasticsearch.monitor.memory.MemoryMonitorService
 
doStop() - Method in class org.elasticsearch.monitor.MonitorService
 
doStop() - Method in class org.elasticsearch.rest.RestController
 
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
 
doStop() - Method in class org.elasticsearch.util.component.AbstractLifecycleComponent
 
doubleField(String) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
doubleToBytes(double) - Static method in class org.elasticsearch.util.Numbers
Converts a double to a byte array.
doubleValue() - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentParser
 
doubleValue() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
doWithNode(DiscoveryNode) - Method in interface org.elasticsearch.client.transport.TransportClientNodesService.NodeCallback
 
download(URL, File, HttpDownloadHelper.DownloadProgress) - Method in class org.elasticsearch.util.http.HttpDownloadHelper
 
downloadPlugin(String) - Method in class org.elasticsearch.plugins.PluginManager
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.BaseFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.BaseQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.BoolFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.BoolQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.ConstantScoreQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.CustomBoostFactorQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.DisMaxQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.FieldQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.FilteredQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisFieldQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.MatchAllQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.MoreLikeThisFieldQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.MoreLikeThisQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.PrefixFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.PrefixQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.QueryFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.QueryStringQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.SpanFirstQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.SpanNearQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.SpanNotQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.SpanOrQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.SpanTermQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.TermFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.TermQueryBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.TermsFilterBuilder
 
doXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.WildcardQueryBuilder
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper
 
doXContentBody(XContentBuilder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper
 
drainTasksTo(Collection<? super ForkJoinTask<?>>) - Method in class org.elasticsearch.util.concurrent.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 org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
 
drainTo(Collection<? super E>, int) - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
 
DummyTransportAddress - Class in org.elasticsearch.util.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.util.inject.internal.Errors
 
duplicateScopeAnnotations(Class<? extends Annotation>, Class<? extends Annotation>) - Method in class org.elasticsearch.util.inject.internal.Errors
 
duplicateScopes(Scope, Class<? extends Annotation>, Scope) - Method in class org.elasticsearch.util.inject.internal.Errors
 
DutchAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
DutchAnalyzerProvider(Index, Settings, 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(boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.Builder
 
DYNAMIC - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.Defaults
 
DynamicExecutors - Class in org.elasticsearch.util.concurrent
Factory and utility methods for handling DynamicThreadPoolExecutor.
DynamicThreadPoolExecutor - Class in org.elasticsearch.util.concurrent
An ExecutorService that executes each submitted task using one of possibly several pooled threads, normally configured using DynamicExecutors factory methods.
DynamicThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.elasticsearch.util.concurrent.DynamicThreadPoolExecutor
 
DynamicThreadPoolExecutor.DynamicQueue<E> - Class in org.elasticsearch.util.concurrent
Much like a SynchronousQueue which acts as a rendezvous channel.
DynamicThreadPoolExecutor.DynamicQueue() - Constructor for class org.elasticsearch.util.concurrent.DynamicThreadPoolExecutor.DynamicQueue
Creates a DynamicQueue with a capacity of Integer.MAX_VALUE.
DynamicThreadPoolExecutor.DynamicQueue(int) - Constructor for class org.elasticsearch.util.concurrent.DynamicThreadPoolExecutor.DynamicQueue
Creates a DynamicQueue with the given (fixed) capacity.
DynamicThreadPoolExecutor.ForceQueuePolicy - Class in org.elasticsearch.util.concurrent
A handler for rejected tasks that adds the specified element to this queue, waiting if necessary for space to become available.
DynamicThreadPoolExecutor.ForceQueuePolicy() - Constructor for class org.elasticsearch.util.concurrent.DynamicThreadPoolExecutor.ForceQueuePolicy
 
DynamicThreadPoolExecutor.TimedBlockingPolicy - Class in org.elasticsearch.util.concurrent
A handler for rejected tasks that inserts the specified element into this queue, waiting if necessary up to the specified wait time for space to become available.
DynamicThreadPoolExecutor.TimedBlockingPolicy(long) - Constructor for class org.elasticsearch.util.concurrent.DynamicThreadPoolExecutor.TimedBlockingPolicy
 

E

EAGER_SINGLETON - Static variable in class org.elasticsearch.util.inject.internal.Scoping
 
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
 
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.
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 org.elasticsearch.util.collect.ForwardingQueue
 
Element - Interface in org.elasticsearch.util.inject.spi
A core component of a module or injector.
elements() - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
elements() - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Returns an enumeration of the values in this table.
elements() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Returns an enumeration of the values in this table.
elements() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Returns an enumeration of the values in this table.
elements() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Returns an enumeration of the values in this table.
elements() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Returns an enumeration of the values in this table.
elements - Variable in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
Elements - Class in org.elasticsearch.util.inject.spi
Exposes elements of a module so they can be inspected, validated or rewritten.
Elements() - Constructor for class org.elasticsearch.util.inject.spi.Elements
 
elementsEqual(Iterable<?>, Iterable<?>) - Static method in class org.elasticsearch.util.collect.Iterables
Determines whether two iterables contain equal elements in the same order.
elementsEqual(Iterator<?>, Iterator<?>) - Static method in class org.elasticsearch.util.collect.Iterators
Determines whether two iterators contain equal elements in the same order.
elementSet() - Method in class org.elasticsearch.util.collect.ForwardingMultiset
 
elementSet() - Method in class org.elasticsearch.util.collect.ImmutableMultiset
 
elementSet() - Method in interface org.elasticsearch.util.collect.Multiset
Returns the set of distinct elements contained in this multiset.
elementSet() - Method in class org.elasticsearch.util.collect.TreeMultiset
Returns the set of distinct elements contained in this multiset.
ElementVisitor<V> - Interface in org.elasticsearch.util.inject.spi
Visit elements.
EMPTY - Static variable in interface org.elasticsearch.index.mapper.DocumentMapper.ParseListener
 
EMPTY - Static variable in class org.elasticsearch.rest.Utf8RestResponse
 
EMPTY_ARRAY - Static variable in class org.elasticsearch.action.search.ShardSearchFailure
 
EMPTY_ARRAY - Static variable in interface org.elasticsearch.index.mapper.xcontent.XContentMapper
 
EMPTY_ARRAY - Static variable in class org.elasticsearch.util.Bytes
 
EMPTY_ARRAY - Static variable in class org.elasticsearch.util.Strings
 
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.util.inject.util.Modules
 
EMPTY_NODES - Static variable in class org.elasticsearch.cluster.node.DiscoveryNodes
 
EMPTY_PARAMS - Static variable in interface org.elasticsearch.util.xcontent.ToXContent
 
EMPTY_ROUTING_TABLE - Static variable in class org.elasticsearch.cluster.routing.RoutingTable
 
EMPTY_SETTINGS - Static variable in class org.elasticsearch.util.settings.ImmutableSettings.Builder
 
EMPTY_TYPE_ARRAY - Static variable in class org.elasticsearch.util.inject.internal.MoreTypes
 
emptyDelta() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
emptyIterator() - Static method in class org.elasticsearch.util.collect.Iterators
Returns the empty iterator.
enableConsoleLogging() - Static method in class org.elasticsearch.util.logging.Loggers
 
enabled() - Method in interface org.elasticsearch.index.mapper.SourceFieldMapper
Returns true if the source field mapper is enabled or not.
enabled(boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper.Builder
 
ENABLED - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper.Defaults
 
enabled() - Method in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper
 
enabled(boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.Builder
 
ENABLED - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.Defaults
 
enabled(boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper.Builder
 
ENABLED - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper.Defaults
 
enabled() - Method in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper
 
enabledDocIdSet() - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
enablePositionIncrements() - Method in class org.elasticsearch.index.analysis.StopTokenFilterFactory
 
enablePositionIncrements(boolean) - Method in class org.elasticsearch.index.query.xcontent.FieldQueryBuilder
Set to true to enable position increments in result query.
enablePositionIncrements(boolean) - Method in class org.elasticsearch.index.query.xcontent.QueryStringQueryBuilder
Set to true to enable position increments in result query.
ENCODE - Static variable in class org.elasticsearch.util.Base64
Specify encoding in first bit.
encode(ByteBuffer, ByteBuffer) - Static method in class org.elasticsearch.util.Base64
Performs Base64 encoding on the raw ByteBuffer, writing it to the encoded ByteBuffer.
encode(ByteBuffer, CharBuffer) - Static method in class org.elasticsearch.util.Base64
Performs Base64 encoding on the raw ByteBuffer, writing it to the encoded CharBuffer.
encode(byte[], int) - Static method in class org.elasticsearch.util.io.compression.lzf.LZFEncoder
Method for compressing given input data using LZF encoding and block structure (compatible with lzf command line utility).
encode(String, int) - Static method in class org.elasticsearch.util.jline.ANSI.Renderer
 
encodeBytes(byte[]) - Static method in class org.elasticsearch.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int) - Static method in class org.elasticsearch.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int, int) - Static method in class org.elasticsearch.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int, int, int) - Static method in class org.elasticsearch.util.Base64
Encodes a byte array into Base64 notation.
encodeBytesToBytes(byte[]) - Static method in class org.elasticsearch.util.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.util.Base64
Similar to Base64.encodeBytes(byte[], int, int, int) but returns a byte array instead of instantiating a String.
encodeChunk(byte[], int, int) - Method in class org.elasticsearch.util.io.compression.lzf.ChunkEncoder
Method for compressing (or not) individual chunks
encodeFileToFile(String, String) - Static method in class org.elasticsearch.util.Base64
Reads infile and encodes it to outfile.
encodeFromFile(String) - Static method in class org.elasticsearch.util.Base64
Convenience method for reading a binary file and base64-encoding it.
encodeObject(Serializable) - Static method in class org.elasticsearch.util.Base64
Serializes an object and returns the Base64-encoded version of that serialized object.
encodeObject(Serializable, int) - Static method in class org.elasticsearch.util.Base64
Serializes an object and returns the Base64-encoded version of that serialized object.
encodeToFile(byte[], String) - Static method in class org.elasticsearch.util.Base64
Convenience method for encoding data to a file.
end() - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.CachedNumericTokenStream
 
END_TOKEN - Static variable in class org.elasticsearch.util.jline.ANSI.Renderer
 
endArray() - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
endDownload() - Method in interface org.elasticsearch.util.http.HttpDownloadHelper.DownloadProgress
end a download
endDownload() - Method in class org.elasticsearch.util.http.HttpDownloadHelper.NullProgress
end a download
endDownload() - Method in class org.elasticsearch.util.http.HttpDownloadHelper.VerboseProgress
end a download
endObject() - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
endOfData() - Method in class org.elasticsearch.util.collect.AbstractIterator
Implementations of computeNext must invoke this method when there are no elements left in the iteration.
endsWithIgnoreCase(String, String) - Static method in class org.elasticsearch.util.Strings
Test if the given String ends with the specified suffix, ignoring upper/lower case.
Engine - Interface in org.elasticsearch.index.engine
 
engine() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
Engine.Create - Class in org.elasticsearch.index.engine
 
Engine.Create(Document, Analyzer, String, String, byte[]) - Constructor for class org.elasticsearch.index.engine.Engine.Create
 
Engine.Delete - Class in org.elasticsearch.index.engine
 
Engine.Delete(Term) - Constructor for class org.elasticsearch.index.engine.Engine.Delete
 
Engine.DeleteByQuery - Class in org.elasticsearch.index.engine
 
Engine.DeleteByQuery(Query, byte[], String, String...) - Constructor for class org.elasticsearch.index.engine.Engine.DeleteByQuery
 
Engine.Flush - Class in org.elasticsearch.index.engine
 
Engine.Flush() - Constructor for class org.elasticsearch.index.engine.Engine.Flush
 
Engine.Index - Class in org.elasticsearch.index.engine
 
Engine.Index(Term, Document, Analyzer, String, String, byte[]) - Constructor for class org.elasticsearch.index.engine.Engine.Index
 
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.SnapshotHandler<T> - Interface in org.elasticsearch.index.engine
 
ENGINE_TYPE - Static variable in class org.elasticsearch.index.engine.EngineModule.EngineSettings
 
EngineAlreadyStartedException - Exception in org.elasticsearch.index.engine
 
EngineAlreadyStartedException(ShardId) - Constructor for exception org.elasticsearch.index.engine.EngineAlreadyStartedException
 
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
 
EngineModule.EngineSettings - Class in org.elasticsearch.index.engine
 
EngineModule.EngineSettings() - Constructor for class org.elasticsearch.index.engine.EngineModule.EngineSettings
 
ensureCapacity(int) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Grow the internal array as needed to accommodate the specified number of elements.
ensureCapacity(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Grow the internal array as needed to accommodate the specified number of elements.
ensureCapacity(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Grow the internal array as needed to accommodate the specified number of elements.
ensureCapacity(int) - Method in class org.elasticsearch.util.gnu.trove.THash
Ensure that this hashtable has sufficient capacity to hold desiredCapacity additional elements without requiring a rehash.
ensureCapacity(int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Grow the internal array as needed to accommodate the specified number of elements.
ensureCapacity(int) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Grow the internal array as needed to accommodate the specified number of elements.
ensureCapacity(int) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Grow the internal array as needed to accommodate the specified number of elements.
entries() - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
entries() - Method in class org.elasticsearch.util.collect.ImmutableMultimap
Returns an immutable collection of all key-value pairs in the multimap.
entries() - Method in class org.elasticsearch.util.collect.ImmutableSetMultimap
Returns an immutable collection of all key-value pairs in the multimap.
entries() - Method in class org.elasticsearch.util.collect.LinkedHashMultimap
Returns a set of all key-value pairs.
entries() - Method in class org.elasticsearch.util.collect.LinkedListMultimap
Returns a collection of all key-value pairs.
entries() - Method in interface org.elasticsearch.util.collect.Multimap
Returns a collection of all key-value pairs.
entries() - Method in interface org.elasticsearch.util.collect.SetMultimap
Returns a collection of all key-value pairs.
entries() - Method in class org.elasticsearch.util.lucene.all.AllEntries
 
entriesDiffering() - Method in interface org.elasticsearch.util.collect.MapDifference
Returns an unmodifiable map describing keys that appear in both maps, but with different values.
entriesInCommon() - Method in interface org.elasticsearch.util.collect.MapDifference
Returns an unmodifiable map containing the entries that appear in both maps; that is, the intersection of the two maps.
entriesOnlyOnLeft() - Method in interface org.elasticsearch.util.collect.MapDifference
Returns an unmodifiable map containing the entries from the left map whose keys are not present in the right map.
entriesOnlyOnRight() - Method in interface org.elasticsearch.util.collect.MapDifference
Returns an unmodifiable map containing the entries from the right map whose keys are not present in the left map.
entrySet() - Method in class org.elasticsearch.util.collect.ConcurrentHashMultiset
 
entrySet() - Method in class org.elasticsearch.util.collect.ForwardingMap
 
entrySet() - Method in class org.elasticsearch.util.collect.ForwardingMultiset
 
entrySet() - Method in class org.elasticsearch.util.collect.ImmutableBiMap
 
entrySet() - Method in class org.elasticsearch.util.collect.ImmutableMap
Returns an immutable set of the mappings in this map.
entrySet() - Method in class org.elasticsearch.util.collect.ImmutableMultiset
 
entrySet() - Method in class org.elasticsearch.util.collect.ImmutableSortedMap
Returns an immutable set of the mappings in this map, sorted by the key ordering.
entrySet() - Method in interface org.elasticsearch.util.collect.Multiset
Returns a view of the contents of this multiset, grouped into Multiset.Entry instances, each providing an element of the multiset and the count of that element.
entrySet() - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
entrySet() - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Returns a Set view of the mappings contained in this map.
entrySet() - Method in class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
entrySet() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Returns a Set view of the mappings contained in this map.
entrySet() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Returns a Set view of the mappings contained in this map.
entrySet() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Returns a Set view of the mappings contained in this map.
entrySet() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Returns a Set view of the mappings contained in this map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Returns a Set view on the entries of the map.
entrySet() - Method in class org.elasticsearch.util.gnu.trove.THashMap
Returns a Set view on the entries of the map.
EnumBiMap<K extends java.lang.Enum<K>,V extends java.lang.Enum<V>> - Class in org.elasticsearch.util.collect
A BiMap backed by two EnumMap instances.
EnumHashBiMap<K extends java.lang.Enum<K>,V> - Class in org.elasticsearch.util.collect
A BiMap backed by an EnumMap instance for keys-to-values, and a HashMap instance for values-to-keys.
EnumMultiset<E extends java.lang.Enum<E>> - Class in org.elasticsearch.util.collect
Multiset implementation backed by an EnumMap.
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
 
equal(Object, Object) - Static method in class org.elasticsearch.util.base.Objects
Determines whether two possibly-null objects are equal.
equals(Object) - Method in class org.elasticsearch.cluster.ClusterName
 
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.index.Index
 
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.search.SearchShardTarget
 
equals(Object) - Method in interface org.elasticsearch.util.base.Function
Indicates whether some other object is equal to this Function.
equals(Object) - Method in interface org.elasticsearch.util.base.Predicate
Indicates whether some other object is equal to this Predicate.
equals(Object) - Method in class org.elasticsearch.util.collect.ForwardingList
 
equals(Object) - Method in class org.elasticsearch.util.collect.ForwardingMap
 
equals(Object) - Method in class org.elasticsearch.util.collect.ForwardingMapEntry
 
equals(Object) - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
equals(Object) - Method in class org.elasticsearch.util.collect.ForwardingMultiset
 
equals(Object) - Method in class org.elasticsearch.util.collect.ForwardingSet
 
equals(Object) - Method in class org.elasticsearch.util.collect.ImmutableBiMap
 
equals(Object) - Method in class org.elasticsearch.util.collect.ImmutableMap
 
equals(Object) - Method in class org.elasticsearch.util.collect.ImmutableMultimap
 
equals(Object) - Method in class org.elasticsearch.util.collect.ImmutableMultiset
 
equals(Object) - Method in class org.elasticsearch.util.collect.ImmutableSet
 
equals(Object) - Method in class org.elasticsearch.util.collect.LinkedListMultimap
Compares the specified object to this multimap for equality.
equals(Object) - Method in interface org.elasticsearch.util.collect.ListMultimap
Compares the specified object to this multimap for equality.
equals(Object) - Method in interface org.elasticsearch.util.collect.MapDifference
Compares the specified object with this instance for equality.
equals(Object) - Method in interface org.elasticsearch.util.collect.MapDifference.ValueDifference
Two instances are considered equal if their MapDifference.ValueDifference.leftValue() values are equal and their MapDifference.ValueDifference.rightValue() values are also equal.
equals(Object) - Method in interface org.elasticsearch.util.collect.Multimap
Compares the specified object with this multimap for equality.
equals(Object) - Method in interface org.elasticsearch.util.collect.Multiset.Entry
equals(Object) - Method in interface org.elasticsearch.util.collect.Multiset
Compares the specified object with this multiset for equality.
equals(Object) - Method in interface org.elasticsearch.util.collect.SetMultimap
Compares the specified object to this multimap for equality.
equals(Object) - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteHashSetDecorator
Compares this set with another set for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleHashSetDecorator
Compares this set with another set for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatHashSetDecorator
Compares this set with another set for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntHashSetDecorator
Compares this set with another set for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongHashSetDecorator
Compares this set with another set for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortHashSetDecorator
Compares this set with another set for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Compares this list to another list, value by value.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TByteHashSet
Compares this set with another set for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Compares this list to another list, value by value.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Compares this set with another set for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Compares this list to another list, value by value.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TFloatHashSet
Compares this set with another set for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.THashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.THashSet
 
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Compares this list to another list, value by value.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TIntHashSet
Compares this set with another set for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Compares this list to another list, value by value.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TLongHashSet
Compares this set with another set for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Compares this map with another map for equality of their stored entries.
equals(T, T) - Method in class org.elasticsearch.util.gnu.trove.TObjectHash
This is the default implementation of TObjectHashingStrategy: it delegates equality comparisons to the first parameter's equals() method.
equals(T, T) - Method in interface org.elasticsearch.util.gnu.trove.TObjectHashingStrategy
Compares o1 and o2 for equality.
equals(T, T) - Method in class org.elasticsearch.util.gnu.trove.TObjectIdentityHashingStrategy
Compares object references for equality.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Compares this list to another list, value by value.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TShortHashSet
Compares this set with another set for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Compares this map with another map for equality of their stored entries.
equals(Object) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Compares this map with another map for equality of their stored entries.
equals(Type, Type) - Static method in class org.elasticsearch.util.inject.internal.MoreTypes
Returns true if a and b are equal.
equals(Object) - Method in class org.elasticsearch.util.inject.internal.MoreTypes.GenericArrayTypeImpl
 
equals(Object) - Method in class org.elasticsearch.util.inject.internal.MoreTypes.ParameterizedTypeImpl
 
equals(Object) - Method in class org.elasticsearch.util.inject.internal.MoreTypes.WildcardTypeImpl
 
equals(Object) - Method in class org.elasticsearch.util.inject.internal.ProviderMethodsModule
 
equals(Object) - Method in class org.elasticsearch.util.inject.Key
 
equals(Object) - Method in class org.elasticsearch.util.inject.spi.Dependency
 
equals(Object) - Method in class org.elasticsearch.util.inject.spi.InjectionPoint
 
equals(Object) - Method in class org.elasticsearch.util.inject.spi.Message
 
equals(Object) - Method in class org.elasticsearch.util.inject.TypeLiteral
 
equals(Object) - Method in class org.elasticsearch.util.lucene.all.AllTermQuery
 
equals(Object) - Method in class org.elasticsearch.util.lucene.IndexCommitDelegate
 
equals(Object) - Method in class org.elasticsearch.util.lucene.search.CustomBoostFactorQuery
 
equals(Object) - Method in class org.elasticsearch.util.lucene.search.TermFilter
 
equals(Object) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
equals(Object) - Method in class org.elasticsearch.util.SizeValue
 
equals(Object) - Method in class org.elasticsearch.util.TimeValue
 
equals(Object) - Method in class org.elasticsearch.util.transport.InetSocketTransportAddress
 
equals(Object) - Method in class org.elasticsearch.util.transport.LocalTransportAddress
 
equals(Object) - Method in class org.elasticsearch.util.UUID
Compares this object to the specified object.
equalTo(T) - Static method in class org.elasticsearch.util.base.Predicates
Returns a predicate that evaluates to true if the object being tested equals() the given target or both are null.
error(String) - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
 
error(String, Throwable) - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
 
error(String, Object...) - Method in interface org.elasticsearch.util.logging.ESLogger
Logs an ERROR level message.
error(String, Throwable, Object...) - Method in interface org.elasticsearch.util.logging.ESLogger
Logs an ERROR level message.
error(String, Object...) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
error(String, Throwable, Object...) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
ErrorHandler - Interface in org.elasticsearch.util.inject.internal
Handles errors in the Injector.
errorInjectingConstructor(Throwable) - Method in class org.elasticsearch.util.inject.internal.Errors
 
errorInjectingMethod(Throwable) - Method in class org.elasticsearch.util.inject.internal.Errors
 
errorInProvider(RuntimeException) - Method in class org.elasticsearch.util.inject.internal.Errors
 
errorInUserCode(Throwable, String, Object...) - Method in class org.elasticsearch.util.inject.internal.Errors
 
errorInUserInjector(MembersInjector<?>, TypeLiteral<?>, RuntimeException) - Method in class org.elasticsearch.util.inject.internal.Errors
 
errorNotifyingInjectionListener(InjectionListener<?>, TypeLiteral<?>, RuntimeException) - Method in class org.elasticsearch.util.inject.internal.Errors
 
errorNotifyingTypeListener(TypeListenerBinding, TypeLiteral<?>, Throwable) - Method in class org.elasticsearch.util.inject.internal.Errors
 
Errors - Class in org.elasticsearch.util.inject.internal
A collection of error messages.
Errors() - Constructor for class org.elasticsearch.util.inject.internal.Errors
 
Errors(Object) - Constructor for class org.elasticsearch.util.inject.internal.Errors
 
ErrorsException - Exception in org.elasticsearch.util.inject.internal
Indicates that a result could not be returned while preparing or resolving a binding.
ErrorsException(Errors) - Constructor for exception org.elasticsearch.util.inject.internal.ErrorsException
 
ESLogger - Interface in org.elasticsearch.util.logging
 
ESLoggerFactory - Class in org.elasticsearch.util.logging
 
ESLoggerFactory() - Constructor for class org.elasticsearch.util.logging.ESLoggerFactory
 
estabResets() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
estimate_get() - Method in class org.elasticsearch.util.concurrent.highscalelib.ConcurrentAutoTable
A cheaper ConcurrentAutoTable.get().
estimatedFlushableMemorySize() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
 
estimatedFlushableMemorySize() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
estimatedFlushableMemorySize() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
estimatedFlushableSize() - Method in class org.elasticsearch.indices.IndicesMemoryCleaner.MemoryCleanResult
 
estimatedNumberType() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
estimatedNumberType() - Method in interface org.elasticsearch.util.xcontent.XContentParser
Is the number type estimated or not (i.e.
estimatedNumberType() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
estimatedTimeInMillis() - Method in class org.elasticsearch.timer.TimerService
 
estimateFlushableMemorySize() - Method in interface org.elasticsearch.index.engine.Engine
Returns the estimated flushable memory size.
estimateFlushableMemorySize() - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
estimateFlushableMemorySize() - Method in interface org.elasticsearch.index.shard.service.IndexShard
Returns the estimated flushable memory size.
estimateFlushableMemorySize() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
Returns the estimated flushable memory size.
estimateMemorySize() - Method in class org.elasticsearch.index.translog.memory.MemoryTranslog
 
estimateMemorySize() - Method in interface org.elasticsearch.index.translog.Translog
The estimated memory size this translog is taking.
estimateRamSize(IndexWriter) - Static method in class org.elasticsearch.util.lucene.IndexWriters
 
estimateSize() - Method in class org.elasticsearch.index.store.ram.RamStore
 
estimateSize() - Method in interface org.elasticsearch.index.store.Store
The estimated size this store is using.
estimateSize() - Method in class org.elasticsearch.index.store.support.AbstractStore
 
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
 
estimateSize(Directory) - Static method in class org.elasticsearch.util.lucene.Directories
Returns the estimated size of a Directory.
exact() - Method in class org.elasticsearch.action.terms.TermsRequest
Should the doc frequencies be exact frequencies.
exact(boolean) - Method in class org.elasticsearch.action.terms.TermsRequest
Should the doc frequencies be exact frequencies.
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(XContentSpanQueryBuilder) - Method in class org.elasticsearch.index.query.xcontent.SpanNotQueryBuilder
 
exec() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Immediately performs the base action of this task.
exec() - Method in class org.elasticsearch.util.concurrent.jsr166y.RecursiveAction
Implements execution conventions for RecursiveActions.
exec() - Method in class org.elasticsearch.util.concurrent.jsr166y.RecursiveTask
Implements execution conventions for RecursiveTask.
execute(Request) - Method in interface org.elasticsearch.action.Action
 
execute(Request, ActionListener<Response>) - Method in interface org.elasticsearch.action.Action
 
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(Request) - Method in class org.elasticsearch.action.support.BaseAction
 
execute(Request, ActionListener<Response>) - Method in class org.elasticsearch.action.support.BaseAction
 
execute(DiscoveryNode, Request) - Method in interface org.elasticsearch.client.transport.action.ClientTransportAction
 
execute(DiscoveryNode, Request, ActionListener<Response>) - Method in interface org.elasticsearch.client.transport.action.ClientTransportAction
 
execute(DiscoveryNode, Request) - Method in class org.elasticsearch.client.transport.action.support.BaseClientTransportAction
 
execute(DiscoveryNode, Request, ActionListener<Response>) - Method in class org.elasticsearch.client.transport.action.support.BaseClientTransportAction
 
execute(TransportClientNodesService.NodeCallback<T>) - Method in class org.elasticsearch.client.transport.TransportClientNodesService
 
execute(ClusterState) - Method in interface org.elasticsearch.cluster.ClusterStateUpdateTask
 
execute(IndexShard) - Method in class org.elasticsearch.index.translog.Translog.Create
 
execute(IndexShard) - Method in class org.elasticsearch.index.translog.Translog.Delete
 
execute(IndexShard) - Method in class org.elasticsearch.index.translog.Translog.DeleteByQuery
 
execute(IndexShard) - Method in class org.elasticsearch.index.translog.Translog.Index
 
execute(IndexShard) - Method in interface org.elasticsearch.index.translog.Translog.Operation
 
execute(SearchContext) - Method in class org.elasticsearch.search.dfs.DfsPhase
 
execute(SearchContext) - Method in class org.elasticsearch.search.facets.FacetsPhase
 
execute(SearchContext) - Method in class org.elasticsearch.search.fetch.FetchPhase
 
execute(SearchContext) - Method in class org.elasticsearch.search.highlight.HighlightPhase
 
execute(SearchContext) - Method in class org.elasticsearch.search.query.QueryPhase
 
execute(SearchContext) - Method in interface org.elasticsearch.search.SearchPhase
 
execute(Runnable) - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
execute(Runnable) - Method in interface org.elasticsearch.threadpool.ThreadPool
 
execute(ForkJoinTask<?>) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Arranges for (asynchronous) execution of the given task.
execute(Runnable) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
 
execute(Runnable) - Method in class org.elasticsearch.util.concurrent.ScalingThreadPoolExecutor
 
execute(byte, byte) - Method in interface org.elasticsearch.util.gnu.trove.TByteByteProcedure
Executes this procedure.
execute(byte, double) - Method in interface org.elasticsearch.util.gnu.trove.TByteDoubleProcedure
Executes this procedure.
execute(byte, float) - Method in interface org.elasticsearch.util.gnu.trove.TByteFloatProcedure
Executes this procedure.
execute(byte) - Method in interface org.elasticsearch.util.gnu.trove.TByteFunction
Execute this function with value
execute(byte, int) - Method in interface org.elasticsearch.util.gnu.trove.TByteIntProcedure
Executes this procedure.
execute(byte, long) - Method in interface org.elasticsearch.util.gnu.trove.TByteLongProcedure
Executes this procedure.
execute(byte, T) - Method in interface org.elasticsearch.util.gnu.trove.TByteObjectProcedure
Executes this procedure.
execute(byte) - Method in interface org.elasticsearch.util.gnu.trove.TByteProcedure
Executes this procedure.
execute(byte, short) - Method in interface org.elasticsearch.util.gnu.trove.TByteShortProcedure
Executes this procedure.
execute(double, byte) - Method in interface org.elasticsearch.util.gnu.trove.TDoubleByteProcedure
Executes this procedure.
execute(double, double) - Method in interface org.elasticsearch.util.gnu.trove.TDoubleDoubleProcedure
Executes this procedure.
execute(double, float) - Method in interface org.elasticsearch.util.gnu.trove.TDoubleFloatProcedure
Executes this procedure.
execute(double) - Method in interface org.elasticsearch.util.gnu.trove.TDoubleFunction
Execute this function with value
execute(double, int) - Method in interface org.elasticsearch.util.gnu.trove.TDoubleIntProcedure
Executes this procedure.
execute(double, long) - Method in interface org.elasticsearch.util.gnu.trove.TDoubleLongProcedure
Executes this procedure.
execute(double, T) - Method in interface org.elasticsearch.util.gnu.trove.TDoubleObjectProcedure
Executes this procedure.
execute(double) - Method in interface org.elasticsearch.util.gnu.trove.TDoubleProcedure
Executes this procedure.
execute(double, short) - Method in interface org.elasticsearch.util.gnu.trove.TDoubleShortProcedure
Executes this procedure.
execute(float, byte) - Method in interface org.elasticsearch.util.gnu.trove.TFloatByteProcedure
Executes this procedure.
execute(float, double) - Method in interface org.elasticsearch.util.gnu.trove.TFloatDoubleProcedure
Executes this procedure.
execute(float, float) - Method in interface org.elasticsearch.util.gnu.trove.TFloatFloatProcedure
Executes this procedure.
execute(float) - Method in interface org.elasticsearch.util.gnu.trove.TFloatFunction
Execute this function with value
execute(float, int) - Method in interface org.elasticsearch.util.gnu.trove.TFloatIntProcedure
Executes this procedure.
execute(float, long) - Method in interface org.elasticsearch.util.gnu.trove.TFloatLongProcedure
Executes this procedure.
execute(float, T) - Method in interface org.elasticsearch.util.gnu.trove.TFloatObjectProcedure
Executes this procedure.
execute(float) - Method in interface org.elasticsearch.util.gnu.trove.TFloatProcedure
Executes this procedure.
execute(float, short) - Method in interface org.elasticsearch.util.gnu.trove.TFloatShortProcedure
Executes this procedure.
execute(int, byte) - Method in interface org.elasticsearch.util.gnu.trove.TIntByteProcedure
Executes this procedure.
execute(int, double) - Method in interface org.elasticsearch.util.gnu.trove.TIntDoubleProcedure
Executes this procedure.
execute(int, float) - Method in interface org.elasticsearch.util.gnu.trove.TIntFloatProcedure
Executes this procedure.
execute(int) - Method in interface org.elasticsearch.util.gnu.trove.TIntFunction
Execute this function with value
execute(int, int) - Method in interface org.elasticsearch.util.gnu.trove.TIntIntProcedure
Executes this procedure.
execute(int, long) - Method in interface org.elasticsearch.util.gnu.trove.TIntLongProcedure
Executes this procedure.
execute(int, T) - Method in interface org.elasticsearch.util.gnu.trove.TIntObjectProcedure
Executes this procedure.
execute(int) - Method in interface org.elasticsearch.util.gnu.trove.TIntProcedure
Executes this procedure.
execute(int, short) - Method in interface org.elasticsearch.util.gnu.trove.TIntShortProcedure
Executes this procedure.
execute(long, byte) - Method in interface org.elasticsearch.util.gnu.trove.TLongByteProcedure
Executes this procedure.
execute(long, double) - Method in interface org.elasticsearch.util.gnu.trove.TLongDoubleProcedure
Executes this procedure.
execute(long, float) - Method in interface org.elasticsearch.util.gnu.trove.TLongFloatProcedure
Executes this procedure.
execute(long) - Method in interface org.elasticsearch.util.gnu.trove.TLongFunction
Execute this function with value
execute(long, int) - Method in interface org.elasticsearch.util.gnu.trove.TLongIntProcedure
Executes this procedure.
execute(long, long) - Method in interface org.elasticsearch.util.gnu.trove.TLongLongProcedure
Executes this procedure.
execute(long, T) - Method in interface org.elasticsearch.util.gnu.trove.TLongObjectProcedure
Executes this procedure.
execute(long) - Method in interface org.elasticsearch.util.gnu.trove.TLongProcedure
Executes this procedure.
execute(long, short) - Method in interface org.elasticsearch.util.gnu.trove.TLongShortProcedure
Executes this procedure.
execute(K, byte) - Method in interface org.elasticsearch.util.gnu.trove.TObjectByteProcedure
Executes this procedure.
execute(K, double) - Method in interface org.elasticsearch.util.gnu.trove.TObjectDoubleProcedure
Executes this procedure.
execute(K, float) - Method in interface org.elasticsearch.util.gnu.trove.TObjectFloatProcedure
Executes this procedure.
execute(T) - Method in interface org.elasticsearch.util.gnu.trove.TObjectFunction
Execute this function with value
execute(K, int) - Method in interface org.elasticsearch.util.gnu.trove.TObjectIntProcedure
Executes this procedure.
execute(K, long) - Method in interface org.elasticsearch.util.gnu.trove.TObjectLongProcedure
Executes this procedure.
execute(K, V) - Method in interface org.elasticsearch.util.gnu.trove.TObjectObjectProcedure
Executes this procedure.
execute(T) - Method in interface org.elasticsearch.util.gnu.trove.TObjectProcedure
Executes this procedure.
execute(K, short) - Method in interface org.elasticsearch.util.gnu.trove.TObjectShortProcedure
Executes this procedure.
execute(short, byte) - Method in interface org.elasticsearch.util.gnu.trove.TShortByteProcedure
Executes this procedure.
execute(short, double) - Method in interface org.elasticsearch.util.gnu.trove.TShortDoubleProcedure
Executes this procedure.
execute(short, float) - Method in interface org.elasticsearch.util.gnu.trove.TShortFloatProcedure
Executes this procedure.
execute(short) - Method in interface org.elasticsearch.util.gnu.trove.TShortFunction
Execute this function with value
execute(short, int) - Method in interface org.elasticsearch.util.gnu.trove.TShortIntProcedure
Executes this procedure.
execute(short, long) - Method in interface org.elasticsearch.util.gnu.trove.TShortLongProcedure
Executes this procedure.
execute(short, T) - Method in interface org.elasticsearch.util.gnu.trove.TShortObjectProcedure
Executes this procedure.
execute(short) - Method in interface org.elasticsearch.util.gnu.trove.TShortProcedure
Executes this procedure.
execute(short, short) - Method in interface org.elasticsearch.util.gnu.trove.TShortShortProcedure
Executes this procedure.
execute(T) - Method in interface org.elasticsearch.util.SafeArray.Procedure
Executes this procedure.
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
 
executorService - Variable in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
exists() - Method in class org.elasticsearch.action.get.GetResponse
Does the document exists.
expectedSuccessfulOps - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
expectedTotalOps - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
expiration(long, TimeUnit) - Method in class org.elasticsearch.util.collect.MapMaker
Specifies that each entry should be automatically removed from the map once a fixed duration has passed since the entry's creation.
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() - Method in class org.elasticsearch.search.internal.SearchContext
 
explain(boolean) - Method in class org.elasticsearch.search.internal.SearchContext
 
explain(int) - Method in class org.elasticsearch.util.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
ExplainParseElement - Class in org.elasticsearch.search.fetch
 
ExplainParseElement() - Constructor for class org.elasticsearch.search.fetch.ExplainParseElement
 
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.
explicit(List<T>) - Static method in class org.elasticsearch.util.collect.Ordering
Returns an ordering that compares objects according to the order in which they appear in the given list.
explicit(T, T...) - Static method in class org.elasticsearch.util.collect.Ordering
Returns an ordering that compares objects according to the order in which they are given to this method.
expose(Key<?>) - Method in interface org.elasticsearch.util.inject.PrivateBinder
Makes the binding for key available to the enclosing environment
expose(Class<?>) - Method in interface org.elasticsearch.util.inject.PrivateBinder
Makes a binding for type available to the enclosing environment.
expose(TypeLiteral<?>) - Method in interface org.elasticsearch.util.inject.PrivateBinder
Makes a binding for type available to the enclosing environment.
expose(Key<T>) - Method in class org.elasticsearch.util.inject.PrivateModule
Makes the binding for key available to other modules and the injector.
expose(Class<?>) - Method in class org.elasticsearch.util.inject.PrivateModule
Makes a binding for type available to other modules and the injector.
expose(TypeLiteral<?>) - Method in class org.elasticsearch.util.inject.PrivateModule
Makes a binding for type available to other modules and the injector.
Exposed - Annotation Type in org.elasticsearch.util.inject
Acccompanies a @Provides method annotation in a private module to indicate that the provided binding is exposed.
ExposedBinding<T> - Interface in org.elasticsearch.util.inject.spi
A binding to a key exposed from an enclosed private environment.
ExposedBindingImpl<T> - Class in org.elasticsearch.util.inject.internal
 
ExposedBindingImpl(Injector, Object, Key<T>, InternalFactory<T>, PrivateElements) - Constructor for class org.elasticsearch.util.inject.internal.ExposedBindingImpl
 
ExposedBindingImpl(Object, Key<T>, Scoping, PrivateElements) - Constructor for class org.elasticsearch.util.inject.internal.ExposedBindingImpl
 
exposedButNotBound(Key<?>) - Method in class org.elasticsearch.util.inject.internal.Errors
 
ExposureBuilder<T> - Class in org.elasticsearch.util.inject.internal
For private binder's expose() method.
ExposureBuilder(Binder, Object, Key<T>) - Constructor for class org.elasticsearch.util.inject.internal.ExposureBuilder
 
externalValue(Object) - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
 
externalValue() - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
 
externalValueSet() - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
 
extra - Variable in class org.elasticsearch.index.analysis.NumericTokenizer
 
extractTerms(Set<Term>) - Method in class org.elasticsearch.util.lucene.search.CustomBoostFactorQuery
 
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, 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(byte[], int, int) - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
extraSourceLength() - Method in class org.elasticsearch.action.search.SearchRequest
 
extraSourceLength() - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
extraSourceOffset() - Method in class org.elasticsearch.action.search.SearchRequest
 
extraSourceOffset() - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
ExtTIntArrayList - Class in org.elasticsearch.util.trove
 
ExtTIntArrayList() - Constructor for class org.elasticsearch.util.trove.ExtTIntArrayList
 
ExtTIntArrayList(int) - Constructor for class org.elasticsearch.util.trove.ExtTIntArrayList
 
ExtTIntArrayList(int[]) - Constructor for class org.elasticsearch.util.trove.ExtTIntArrayList
 
ExtTIntIntHashMap - Class in org.elasticsearch.util.trove
 
ExtTIntIntHashMap() - Constructor for class org.elasticsearch.util.trove.ExtTIntIntHashMap
 
ExtTIntIntHashMap(int) - Constructor for class org.elasticsearch.util.trove.ExtTIntIntHashMap
 
ExtTIntIntHashMap(int, float) - Constructor for class org.elasticsearch.util.trove.ExtTIntIntHashMap
 
ExtTIntIntHashMap(TIntHashingStrategy) - Constructor for class org.elasticsearch.util.trove.ExtTIntIntHashMap
 
ExtTIntIntHashMap(int, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.trove.ExtTIntIntHashMap
 
ExtTIntIntHashMap(int, float, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.trove.ExtTIntIntHashMap
 
ExtTObjectFloatHashMap<T> - Class in org.elasticsearch.util.trove
 
ExtTObjectFloatHashMap() - Constructor for class org.elasticsearch.util.trove.ExtTObjectFloatHashMap
 
ExtTObjectFloatHashMap(int) - Constructor for class org.elasticsearch.util.trove.ExtTObjectFloatHashMap
 
ExtTObjectFloatHashMap(int, float) - Constructor for class org.elasticsearch.util.trove.ExtTObjectFloatHashMap
 
ExtTObjectFloatHashMap(TObjectHashingStrategy<T>) - Constructor for class org.elasticsearch.util.trove.ExtTObjectFloatHashMap
 
ExtTObjectFloatHashMap(int, TObjectHashingStrategy<T>) - Constructor for class org.elasticsearch.util.trove.ExtTObjectFloatHashMap
 
ExtTObjectFloatHashMap(int, float, TObjectHashingStrategy<T>) - Constructor for class org.elasticsearch.util.trove.ExtTObjectFloatHashMap
 
ExtTObjectIntHasMap<T> - Class in org.elasticsearch.util.trove
 
ExtTObjectIntHasMap() - Constructor for class org.elasticsearch.util.trove.ExtTObjectIntHasMap
 
ExtTObjectIntHasMap(int) - Constructor for class org.elasticsearch.util.trove.ExtTObjectIntHasMap
 
ExtTObjectIntHasMap(int, float) - Constructor for class org.elasticsearch.util.trove.ExtTObjectIntHasMap
 
ExtTObjectIntHasMap(TObjectHashingStrategy<T>) - Constructor for class org.elasticsearch.util.trove.ExtTObjectIntHasMap
 
ExtTObjectIntHasMap(int, TObjectHashingStrategy<T>) - Constructor for class org.elasticsearch.util.trove.ExtTObjectIntHasMap
 
ExtTObjectIntHasMap(int, float, TObjectHashingStrategy<T>) - Constructor for class org.elasticsearch.util.trove.ExtTObjectIntHasMap
 

F

facet(String, XContentQueryBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceFacetsBuilder
Adds a query facet (which results in a count facet returned).
facet(String, XContentQueryBuilder, boolean) - Method in class org.elasticsearch.search.builder.SearchSourceFacetsBuilder
Adds a query facet (which results in a count facet returned) with an option to be global on the index or bounded by the search query.
Facet - Interface in org.elasticsearch.search.facets
A search facet.
facet(String) - Method in class org.elasticsearch.search.facets.Facets
A facet of the specified name.
Facet.Type - Enum in org.elasticsearch.search.facets
 
FacetPhaseExecutionException - Exception in org.elasticsearch.search.facets
 
FacetPhaseExecutionException(String, String, Throwable) - Constructor for exception org.elasticsearch.search.facets.FacetPhaseExecutionException
 
facets() - Method in class org.elasticsearch.action.search.SearchResponse
The search facets.
facets() - Static method in class org.elasticsearch.search.builder.SearchSourceBuilder
A static factory method to construct new search facets.
facets(SearchSourceFacetsBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Adds facets to perform as part of the search.
Facets - Class in org.elasticsearch.search.facets
Facets of search action.
Facets(List<Facet>) - Constructor for class org.elasticsearch.search.facets.Facets
Constructs a new facets.
facets() - Method in class org.elasticsearch.search.facets.Facets
The list of Facets.
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(Facets) - Method in class org.elasticsearch.search.query.QuerySearchResult
 
facetsAsMap() - Method in class org.elasticsearch.search.facets.Facets
Returns the Facets keyed by map.
FacetsParseElement - Class in org.elasticsearch.search.facets
facets : { query_execution : "collect|idset", facet1: { query : { ...
FacetsParseElement() - Constructor for class org.elasticsearch.search.facets.FacetsParseElement
 
FacetsPhase - Class in org.elasticsearch.search.facets
 
FacetsPhase() - Constructor for class org.elasticsearch.search.facets.FacetsPhase
 
FactoryProvider<F> - Class in org.elasticsearch.util.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.util.inject.internal
Lazily creates (and caches) values for keys.
FailableCache() - Constructor for class org.elasticsearch.util.inject.internal.FailableCache
 
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
 
FailedNodeException - Exception in org.elasticsearch.action
 
FailedNodeException(String, String, Throwable) - Constructor for exception org.elasticsearch.action.FailedNodeException
 
failedShards() - Method in class org.elasticsearch.action.admin.cluster.ping.replication.IndexReplicationPingResponse
 
failedShards() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.IndexGatewaySnapshotResponse
The number of failed shards the gateway snapshot operation was performed 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
 
failures() - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
 
failures() - Method in exception org.elasticsearch.index.mapper.MergeMappingException
 
FastByteArrayInputStream - Class in org.elasticsearch.util.io
 
FastByteArrayInputStream(byte[]) - Constructor for class org.elasticsearch.util.io.FastByteArrayInputStream
Creates a ByteArrayInputStream so that it uses buf as its buffer array.
FastByteArrayInputStream(byte[], int, int) - Constructor for class org.elasticsearch.util.io.FastByteArrayInputStream
Creates ByteArrayInputStream that uses buf as its buffer array.
FastByteArrayOutputStream - Class in org.elasticsearch.util.io
Similar to ByteArrayOutputStream just not synced.
FastByteArrayOutputStream() - Constructor for class org.elasticsearch.util.io.FastByteArrayOutputStream
Creates a new byte array output stream.
FastByteArrayOutputStream(int) - Constructor for class org.elasticsearch.util.io.FastByteArrayOutputStream
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
FastByteArrayOutputStream.Cached - Class in org.elasticsearch.util.io
A thread local based cache of FastByteArrayOutputStream.
FastByteArrayOutputStream.Cached() - Constructor for class org.elasticsearch.util.io.FastByteArrayOutputStream.Cached
 
FastCharArrayReader - Class in org.elasticsearch.util.io
 
FastCharArrayReader(char[]) - Constructor for class org.elasticsearch.util.io.FastCharArrayReader
Creates a CharArrayReader from the specified array of chars.
FastCharArrayReader(char[], int, int) - Constructor for class org.elasticsearch.util.io.FastCharArrayReader
Creates a CharArrayReader from the specified array of chars.
FastCharArrayWriter - Class in org.elasticsearch.util.io
A similar class to CharArrayWriter allowing to get the underlying char[] buffer.
FastCharArrayWriter() - Constructor for class org.elasticsearch.util.io.FastCharArrayWriter
Creates a new CharArrayWriter.
FastCharArrayWriter(int) - Constructor for class org.elasticsearch.util.io.FastCharArrayWriter
Creates a new CharArrayWriter with the specified initial size.
FastCharArrayWriter.Cached - Class in org.elasticsearch.util.io
A thread local based cache of FastByteArrayOutputStream.
FastCharArrayWriter.Cached() - Constructor for class org.elasticsearch.util.io.FastCharArrayWriter.Cached
 
FastDataOutputStream - Class in org.elasticsearch.util.io
 
FastDataOutputStream(OutputStream) - Constructor for class org.elasticsearch.util.io.FastDataOutputStream
Creates a new data output stream to write data to the specified underlying output stream.
FastStringReader - Class in org.elasticsearch.util.io
A character stream whose source is a string that is not thread safe
FastStringReader(String) - Constructor for class org.elasticsearch.util.io.FastStringReader
Creates a new string reader.
fd() - Method in class org.elasticsearch.monitor.process.ProcessStats
 
FetchPhase - Class in org.elasticsearch.search.fetch
 
FetchPhase(HighlightPhase) - 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
 
FG_BLACK - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
FG_BLUE - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
FG_CYAN - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
FG_GREEN - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
FG_MAGENTA - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
FG_RED - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
FG_WHITE - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
FG_YELLOW - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
field(String) - Method in class org.elasticsearch.action.get.GetResponse
 
field(String) - Method in class org.elasticsearch.action.terms.TermsResponse
The FieldTermsFreq for the specified field name, null if there is none.
field(String) - Method in class org.elasticsearch.index.query.xcontent.QueryStringQueryBuilder
Adds a field to run the query string against.
field(String, float) - Method in class org.elasticsearch.index.query.xcontent.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.builder.SearchSourceHighlightBuilder
Adds a field to be highlighted with default fragment size of 100 characters, and default number of fragments of 5.
field(String, int) - Method in class org.elasticsearch.search.builder.SearchSourceHighlightBuilder
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.builder.SearchSourceHighlightBuilder
Adds a field to be highlighted with a provided fragment size (in characters), and a provided (maximum) number of fragments.
field() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.ParsedHighlightField
 
field(String, String) - Static method in class org.elasticsearch.util.lucene.DocumentBuilder
 
field(String, String, Field.Store, Field.Index) - Static method in class org.elasticsearch.util.lucene.DocumentBuilder
 
field(String, String, Field.Store, Field.Index, Field.TermVector) - Static method in class org.elasticsearch.util.lucene.DocumentBuilder
 
field(String, byte[], Field.Store) - Static method in class org.elasticsearch.util.lucene.DocumentBuilder
 
field(String, byte[], int, int, Field.Store) - Static method in class org.elasticsearch.util.lucene.DocumentBuilder
 
field(String) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, char[], int, int) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, String) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, Integer) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, int) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, Long) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, long) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, Float) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, float) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, Double) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, double) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, Object) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, boolean) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, byte[]) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, ReadableInstant) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, ReadableInstant, DateTimeFormatter) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, Date) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
field(String, Date, DateTimeFormatter) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
FieldBuilder - Class in org.elasticsearch.util.lucene
 
fieldCaseConversion - Variable in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
fieldCaseConversion(XContentBuilder.FieldCaseConversion) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
fieldFilter(String) - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
fieldFilter(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
fieldFilter(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
Numeric field level filter are basically range queries with same value and included.
FieldMapper<T> - Interface in org.elasticsearch.index.mapper
 
fieldMapper(FieldMapper) - Method in interface org.elasticsearch.index.mapper.FieldMapperListener
 
fieldMapper(String) - Method in class org.elasticsearch.index.query.support.MapperQueryParser
 
fieldMapper(String) - Method in class org.elasticsearch.index.query.xcontent.QueryParseContext
 
FieldMapper.Names - Class in org.elasticsearch.index.mapper
 
FieldMapper.Names(String, String, String, String) - Constructor for class org.elasticsearch.index.mapper.FieldMapper.Names
 
FieldMapperListener - Interface in org.elasticsearch.index.mapper
 
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(FieldMapper[]) - Constructor for class org.elasticsearch.index.mapper.FieldMappers
 
FieldMappers(ImmutableList<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
 
FieldMappersFieldSelector() - Constructor for class org.elasticsearch.index.mapper.FieldMappersFieldSelector
 
fieldName() - Method in class org.elasticsearch.action.terms.FieldTermsFreq
The field name.
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
 
fieldNames(String[]) - Method in class org.elasticsearch.search.internal.SearchContext
 
fieldQuery(String) - Method in interface org.elasticsearch.index.mapper.FieldMapper
A field query for the specified value.
fieldQuery(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper
 
fieldQuery(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
fieldQuery(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
Numeric field level query are basically range queries with same value and included.
fieldQuery(String, String) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A query that executes the query string against a field.
fieldQuery(String, int) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A query that executes the query string against a field.
fieldQuery(String, long) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A query that executes the query string against a field.
fieldQuery(String, float) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A query that executes the query string against a field.
fieldQuery(String, double) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A query that executes the query string against a field.
FieldQueryBuilder - Class in org.elasticsearch.index.query.xcontent
A query that executes the query string against a field.
FieldQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.xcontent.FieldQueryBuilder
A query that executes the query string against a field.
FieldQueryBuilder(String, int) - Constructor for class org.elasticsearch.index.query.xcontent.FieldQueryBuilder
A query that executes the query string against a field.
FieldQueryBuilder(String, long) - Constructor for class org.elasticsearch.index.query.xcontent.FieldQueryBuilder
A query that executes the query string against a field.
FieldQueryBuilder(String, float) - Constructor for class org.elasticsearch.index.query.xcontent.FieldQueryBuilder
A query that executes the query string against a field.
FieldQueryBuilder(String, double) - Constructor for class org.elasticsearch.index.query.xcontent.FieldQueryBuilder
A query that executes the query string against a field.
FieldQueryBuilder.Operator - Enum in org.elasticsearch.index.query.xcontent
 
FieldQueryParser - Class in org.elasticsearch.index.query.xcontent
 
FieldQueryParser(Index, Settings, AnalysisService) - Constructor for class org.elasticsearch.index.query.xcontent.FieldQueryParser
 
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() - 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() - Method in class org.elasticsearch.action.terms.TermsRequest
The fields within each document which terms will be iterated over and returned with the document frequencies.
fields(String...) - Method in class org.elasticsearch.action.terms.TermsRequest
The fields within each document which terms will be iterated over and returned with the document frequencies.
fields() - Method in class org.elasticsearch.action.terms.TermsResponse
All the FieldTermsFreq.
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() - 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 interface org.elasticsearch.search.SearchHit
A map of hit fields (from field name to hit fields) if additional fields were required to be loaded.
fields() - Method in class org.elasticsearch.util.lucene.all.AllEntries
 
fieldsAsMap() - Method in class org.elasticsearch.action.terms.TermsResponse
The pair of field name to FieldTermsFreq as map for simpler usage.
fieldSelector() - Method in interface org.elasticsearch.index.mapper.SourceFieldMapper
A field selector that loads just the source field.
fieldSelector() - Method in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper
 
FieldsParseElement - Class in org.elasticsearch.search.fetch
 
FieldsParseElement() - Constructor for class org.elasticsearch.search.fetch.FieldsParseElement
 
FieldTermsFreq - Class in org.elasticsearch.action.terms
All the TermFreqs that occur in a specific field.
fileExists(String) - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectory
 
fileExists(String) - Method in class org.elasticsearch.index.store.memory.HeapDirectory
 
fileExists(String) - Method in class org.elasticsearch.util.lucene.store.SwitchDirectory
 
fileLength(String) - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectory
 
fileLength(String) - Method in class org.elasticsearch.index.store.memory.HeapDirectory
 
fileLength(String) - Method in class org.elasticsearch.util.lucene.store.SwitchDirectory
 
fileModified(String) - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectory
 
fileModified(String) - Method in class org.elasticsearch.index.store.memory.HeapDirectory
 
fileModified(String) - Method in class org.elasticsearch.util.lucene.store.SwitchDirectory
 
files() - Method in class org.elasticsearch.monitor.dump.AbstractDump
 
files() - Method in interface org.elasticsearch.monitor.dump.Dump
 
FileSystemUtils - Class in org.elasticsearch.util.io
 
fill(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Fills every slot in the list with the specified value.
fill(int, int, byte) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Fills a range in the list with the specified value.
fill(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Fills every slot in the list with the specified value.
fill(int, int, double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Fills a range in the list with the specified value.
fill(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Fills every slot in the list with the specified value.
fill(int, int, float) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Fills a range in the list with the specified value.
fill(int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Fills every slot in the list with the specified value.
fill(int, int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Fills a range in the list with the specified value.
fill(long) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Fills every slot in the list with the specified value.
fill(int, int, long) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Fills a range in the list with the specified value.
fill(short) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Fills every slot in the list with the specified value.
fill(int, int, short) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Fills a range in the list with the specified value.
fillInStackTrace() - Method in exception org.elasticsearch.transport.NotSerializableTransportException
 
fillInStackTrace() - Method in exception org.elasticsearch.transport.RemoteTransportException
 
fillInStackTrace() - Method in exception org.elasticsearch.transport.SendRequestTransportException
 
fillStack() - Method in exception org.elasticsearch.transport.RemoteTransportException
 
filter() - Method in class org.elasticsearch.index.cache.IndexCache
 
filter(Collection<E>, Predicate<? super E>) - Static method in class org.elasticsearch.util.collect.Collections2
Returns the elements of unfiltered that satisfy a predicate.
filter(Iterable<T>, Predicate<? super T>) - Static method in class org.elasticsearch.util.collect.Iterables
Returns the elements of unfiltered that satisfy a predicate.
filter(Iterable<?>, Class<T>) - Static method in class org.elasticsearch.util.collect.Iterables
Returns all instances of class type in unfiltered.
filter(Iterator<T>, Predicate<? super T>) - Static method in class org.elasticsearch.util.collect.Iterators
Returns the elements of unfiltered that satisfy a predicate.
filter(Iterator<?>, Class<T>) - Static method in class org.elasticsearch.util.collect.Iterators
Returns all instances of class type in unfiltered.
filter(Set<E>, Predicate<? super E>) - Static method in class org.elasticsearch.util.collect.Sets
Returns the elements of unfiltered that satisfy a predicate.
filter(ImmutableSettings.Builder) - Method in interface org.elasticsearch.util.settings.SettingsFilter.Filter
 
FILTER_CACHE_TYPE - Static variable in class org.elasticsearch.index.cache.filter.FilterCacheModule.FilterCacheSettings
 
FILTER_PREFIX - Static variable in class org.elasticsearch.index.query.xcontent.XContentIndexQueryParser.Defaults
 
FilterBuilders - Class in org.elasticsearch.index.query.xcontent
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
Should the filter cache be cleared or not.
FilterCache - Interface in org.elasticsearch.index.cache.filter
 
filterCache() - Method in class org.elasticsearch.search.internal.SearchContext
 
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
 
filtered(XContentQueryBuilder, XContentFilterBuilder) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A query that applies a filter to the results of another query.
FilteredQueryBuilder - Class in org.elasticsearch.index.query.xcontent
A query that applies a filter to the results of another query.
FilteredQueryBuilder(XContentQueryBuilder, XContentFilterBuilder) - Constructor for class org.elasticsearch.index.query.xcontent.FilteredQueryBuilder
A query that applies a filter to the results of another query.
FilteredQueryParser - Class in org.elasticsearch.index.query.xcontent
 
FilteredQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.FilteredQueryParser
 
filterEntries(Map<K, V>, Predicate<? super Map.Entry<K, V>>) - Static method in class org.elasticsearch.util.collect.Maps
Returns a map containing the mappings in unfiltered that satisfy a predicate.
filterKeys(Map<K, V>, Predicate<? super K>) - Static method in class org.elasticsearch.util.collect.Maps
Returns a map containing the mappings in unfiltered whose keys satisfy a predicate.
filterParser(String) - Method in class org.elasticsearch.index.query.xcontent.XContentQueryParserRegistry
 
filterSettings(Settings) - Method in class org.elasticsearch.util.settings.SettingsFilter
 
filterValues(Map<K, V>, Predicate<? super V>) - Static method in class org.elasticsearch.util.collect.Maps
Returns a map containing the mappings in unfiltered whose values satisfy a predicate.
FinalizablePhantomReference<T> - Class in org.elasticsearch.util.base
Phantom reference with a finalizeReferent() method which a background thread invokes after the garbage collector reclaims the referent.
FinalizablePhantomReference(T, FinalizableReferenceQueue) - Constructor for class org.elasticsearch.util.base.FinalizablePhantomReference
Constructs a new finalizable phantom reference.
FinalizableReference - Interface in org.elasticsearch.util.base
Implemented by references that have code to run after garbage collection of their referents.
FinalizableReferenceQueue - Class in org.elasticsearch.util.base
A reference queue with an associated background thread that dequeues references and invokes FinalizableReference.finalizeReferent() on them.
FinalizableReferenceQueue() - Constructor for class org.elasticsearch.util.base.FinalizableReferenceQueue
Constructs a new queue.
FinalizableSoftReference<T> - Class in org.elasticsearch.util.base
Soft reference with a finalizeReferent() method which a background thread invokes after the garbage collector reclaims the referent.
FinalizableSoftReference(T, FinalizableReferenceQueue) - Constructor for class org.elasticsearch.util.base.FinalizableSoftReference
Constructs a new finalizable soft reference.
FinalizableWeakReference<T> - Class in org.elasticsearch.util.base
Weak reference with a finalizeReferent() method which a background thread invokes after the garbage collector reclaims the referent.
FinalizableWeakReference(T, FinalizableReferenceQueue) - Constructor for class org.elasticsearch.util.base.FinalizableWeakReference
Constructs a new finalizable weak reference.
Finalizer - Class in org.elasticsearch.util.base.internal
Thread that finalizes referents.
finalizeReferent() - Method in interface org.elasticsearch.util.base.FinalizableReference
Invoked on a background thread after the referent has been garbage collected unless security restrictions prevented starting a background thread, in which case this method is invoked when new references are created.
find(Iterable<T>, Predicate<? super T>) - Static method in class org.elasticsearch.util.collect.Iterables
Returns the first element in iterable that satisfies the given predicate.
find(Iterator<T>, Predicate<? super T>) - Static method in class org.elasticsearch.util.collect.Iterators
Returns the first element in iterator that satisfies the given predicate.
findBindingAnnotation(Errors, Member, Annotation[]) - Static method in class org.elasticsearch.util.inject.internal.Annotations
Returns the binding annotation on member, or null if there isn't one.
findBindingsByType(TypeLiteral<T>) - Method in interface org.elasticsearch.util.inject.Injector
Returns all explicit bindings for type.
findByAddress(TransportAddress) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
findDeadlockedThreads() - Method in class org.elasticsearch.monitor.dump.thread.ThreadDumpContributor
 
findDeadlocks() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer
 
findMerges(SegmentInfos) - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy
 
findMergesForOptimize(SegmentInfos, int, Set<SegmentInfo>) - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy
 
findMergesToExpungeDeletes(SegmentInfos) - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy
 
findScopeAnnotation(Errors, Class<?>) - Static method in class org.elasticsearch.util.inject.internal.Annotations
Returns the scope annotation on type, or null if none is specified.
findScopeAnnotation(Errors, Annotation[]) - Static method in class org.elasticsearch.util.inject.internal.Annotations
Returns the scoping annotation, or null if there isn't one.
finish() - Method in interface org.elasticsearch.monitor.dump.Dump
 
finish() - Method in class org.elasticsearch.monitor.dump.SimpleDump
 
finishConstruction() - Method in class org.elasticsearch.util.inject.internal.ConstructionContext
 
first() - Method in class org.elasticsearch.util.collect.ForwardingSortedSet
 
firstKey() - Method in class org.elasticsearch.util.collect.ForwardingSortedMap
 
firstKey() - Method in class org.elasticsearch.util.collect.ImmutableSortedMap
 
firstMaster() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
firstMaster() - Method in interface org.elasticsearch.discovery.Discovery
Is the discovery of this node caused this node to be the first master in the cluster.
firstMaster() - Method in class org.elasticsearch.discovery.DiscoveryService
 
firstMaster() - Method in class org.elasticsearch.discovery.local.LocalDiscovery
 
firstMaster() - Method in class org.elasticsearch.discovery.zen.ZenDiscovery
 
firstPhaseName() - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
fixNegativeQueryIfNeeded(Query) - Static method in class org.elasticsearch.util.lucene.search.Queries
 
floatField(String) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
floatToBytes(float) - Static method in class org.elasticsearch.util.Numbers
Converts a float to a byte array.
floatValue() - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentParser
 
floatValue() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
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 - Static variable in class org.elasticsearch.action.TransportActions.Admin.Indices
 
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.node.NodeIndicesAdminClient
 
flush(FlushRequest, ActionListener<FlushResponse>) - Method in class org.elasticsearch.client.node.NodeIndicesAdminClient
 
flush(FlushRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
flush(FlushRequest, ActionListener<FlushResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
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.index.store.memory.ByteBufferIndexOutput
 
flush() - Method in class org.elasticsearch.index.store.memory.HeapIndexOutput
 
flush() - Method in class org.elasticsearch.util.io.FastCharArrayWriter
Flush the stream.
flush() - Method in class org.elasticsearch.util.io.FastDataOutputStream
Flushes this data output stream.
flush() - Method in class org.elasticsearch.util.io.stream.BytesStreamOutput
 
flush() - Method in class org.elasticsearch.util.io.stream.DataOutputStreamOutput
 
flush() - Method in class org.elasticsearch.util.io.stream.HandlesStreamOutput
 
flush() - Method in class org.elasticsearch.util.io.stream.OutputStreamStreamOutput
 
flush() - Method in class org.elasticsearch.util.io.stream.StreamOutput
Forces any buffered output to be written.
flush() - Method in class org.elasticsearch.util.io.StringBuilderWriter
Flushing this writer has no effect.
flush() - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
flush() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
flush() - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
flush() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
flushBase64() - Method in class org.elasticsearch.util.Base64.OutputStream
Method added by PHIL.
FlushFailedEngineException - Exception in org.elasticsearch.index.engine
 
FlushFailedEngineException(ShardId, 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.
FlushResponse - Class in org.elasticsearch.action.admin.indices.flush
A response to flush action.
forAnnotation(Class<? extends Annotation>) - Static method in class org.elasticsearch.util.inject.internal.Scoping
 
forArray(T...) - Static method in class org.elasticsearch.util.collect.Iterators
Returns an iterator containing the elements of array in order.
forceClose() - Method in interface org.elasticsearch.util.concurrent.resource.AcquirableResource
Forces the resource to be closed, regardless of the number of acquirers.
forceClose() - Method in class org.elasticsearch.util.concurrent.resource.BlockingAcquirableResource
 
forceClose() - Method in class org.elasticsearch.util.concurrent.resource.NonBlockingAcquirableResource
 
forcePut(K, V) - Method in interface org.elasticsearch.util.collect.BiMap
An alternate form of put that silently removes any existing entry with the value value before proceeding with the BiMap.put(K, V) operation.
forcePut(K, V) - Method in class org.elasticsearch.util.collect.EnumHashBiMap
 
forcePut(K, V) - Method in class org.elasticsearch.util.collect.HashBiMap
 
forcePut(K, V) - Method in class org.elasticsearch.util.collect.ImmutableBiMap
Guaranteed to throw an exception and leave the bimap unmodified.
forceSync(String) - Method in interface org.elasticsearch.index.store.support.ForceSyncDirectory
Similar to Directory.sync(String) but forces it even if its disabled.
forceSync(String) - Method in class org.elasticsearch.util.lucene.store.SwitchDirectory
 
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 org.elasticsearch.util.concurrent.jsr166y.Phaser
Forces this barrier to enter termination state.
forConstructorOf(TypeLiteral<?>) - Static method in class org.elasticsearch.util.inject.spi.InjectionPoint
Returns a new injection point for the injectable constructor of type.
forConstructorOf(Class<?>) - Static method in class org.elasticsearch.util.inject.spi.InjectionPoint
Returns a new injection point for the injectable constructor of type.
forEach(SafeArray.Procedure<T>) - Method in class org.elasticsearch.util.concurrent.ConcurrentSafeArray
 
forEach(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Applies the procedure to each value in the list in ascending (front to back) order.
forEach(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteHash
Executes procedure for each element in the set.
forEach(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Applies the procedure to each value in the list in ascending (front to back) order.
forEach(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHash
Executes procedure for each element in the set.
forEach(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Applies the procedure to each value in the list in ascending (front to back) order.
forEach(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatHash
Executes procedure for each element in the set.
forEach(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Applies the procedure to each value in the list in ascending (front to back) order.
forEach(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntHash
Executes procedure for each element in the set.
forEach(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Applies the procedure to each value in the list in ascending (front to back) order.
forEach(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongHash
Executes procedure for each element in the set.
forEach(TObjectProcedure<T>) - Method in class org.elasticsearch.util.gnu.trove.TObjectHash
Executes procedure for each element in the set.
forEach(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Applies the procedure to each value in the list in ascending (front to back) order.
forEach(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortHash
Executes procedure for each element in the set.
forEach(SafeArray.Procedure<T>) - Method in interface org.elasticsearch.util.SafeArray
Applies the procedure to each value in the list in ascending (front to back) order.
forEachDescending(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Applies the procedure to each value in the list in descending (back to front) order.
forEachDescending(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Applies the procedure to each value in the list in descending (back to front) order.
forEachDescending(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Applies the procedure to each value in the list in descending (back to front) order.
forEachDescending(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Applies the procedure to each value in the list in descending (back to front) order.
forEachDescending(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Applies the procedure to each value in the list in descending (back to front) order.
forEachDescending(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Applies the procedure to each value in the list in descending (back to front) order.
forEachEntry(TByteByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TByteDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TByteFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TByteIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TByteLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TByteObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TByteShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TDoubleByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TDoubleDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TDoubleFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TDoubleIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TDoubleLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TDoubleObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TDoubleShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TFloatByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TFloatDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TFloatFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TFloatIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TFloatLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TFloatObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TFloatShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TObjectObjectProcedure<K, V>) - Method in class org.elasticsearch.util.gnu.trove.THashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TIntByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TIntDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TIntFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TIntIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TIntLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TIntObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TIntShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TLongByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TLongDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TLongFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TLongIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TLongLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TLongObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TLongShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TObjectByteProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TObjectDoubleProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TObjectFloatProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TObjectIntProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TObjectLongProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TObjectShortProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TShortByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TShortDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TShortFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TShortIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TShortLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TShortObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Executes procedure for each key/value entry in the map.
forEachEntry(TShortShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Executes procedure for each key/value entry in the map.
forEachKey(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Executes procedure for each key in the map.
forEachKey(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Executes procedure for each key in the map.
forEachKey(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Executes procedure for each key in the map.
forEachKey(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Executes procedure for each key in the map.
forEachKey(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Executes procedure for each key in the map.
forEachKey(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Executes procedure for each key in the map.
forEachKey(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Executes procedure for each key in the map.
forEachKey(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Executes procedure for each key in the map.
forEachKey(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Executes procedure for each key in the map.
forEachKey(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Executes procedure for each key in the map.
forEachKey(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Executes procedure for each key in the map.
forEachKey(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Executes procedure for each key in the map.
forEachKey(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Executes procedure for each key in the map.
forEachKey(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Executes procedure for each key in the map.
forEachKey(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Executes procedure for each key in the map.
forEachKey(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Executes procedure for each key in the map.
forEachKey(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Executes procedure for each key in the map.
forEachKey(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Executes procedure for each key in the map.
forEachKey(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Executes procedure for each key in the map.
forEachKey(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Executes procedure for each key in the map.
forEachKey(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Executes procedure for each key in the map.
forEachKey(TObjectProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.THashMap
Executes procedure for each key in the map.
forEachKey(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Executes procedure for each key in the map.
forEachKey(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Executes procedure for each key in the map.
forEachKey(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Executes procedure for each key in the map.
forEachKey(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Executes procedure for each key in the map.
forEachKey(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Executes procedure for each key in the map.
forEachKey(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Executes procedure for each key in the map.
forEachKey(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Executes procedure for each key in the map.
forEachKey(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Executes procedure for each key in the map.
forEachKey(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Executes procedure for each key in the map.
forEachKey(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Executes procedure for each key in the map.
forEachKey(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Executes procedure for each key in the map.
forEachKey(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Executes procedure for each key in the map.
forEachKey(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Executes procedure for each key in the map.
forEachKey(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Executes procedure for each key in the map.
forEachKey(TObjectProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Executes procedure for each key in the map.
forEachKey(TObjectProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Executes procedure for each key in the map.
forEachKey(TObjectProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Executes procedure for each key in the map.
forEachKey(TObjectProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Executes procedure for each key in the map.
forEachKey(TObjectProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Executes procedure for each key in the map.
forEachKey(TObjectProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Executes procedure for each key in the map.
forEachKey(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Executes procedure for each key in the map.
forEachKey(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Executes procedure for each key in the map.
forEachKey(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Executes procedure for each key in the map.
forEachKey(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Executes procedure for each key in the map.
forEachKey(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Executes procedure for each key in the map.
forEachKey(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Executes procedure for each key in the map.
forEachKey(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Executes procedure for each key in the map.
forEachValue(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Executes procedure for each value in the map.
forEachValue(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Executes procedure for each value in the map.
forEachValue(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Executes procedure for each value in the map.
forEachValue(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Executes procedure for each value in the map.
forEachValue(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Executes procedure for each value in the map.
forEachValue(TObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Executes procedure for each value in the map.
forEachValue(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Executes procedure for each value in the map.
forEachValue(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Executes procedure for each value in the map.
forEachValue(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Executes procedure for each value in the map.
forEachValue(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Executes procedure for each value in the map.
forEachValue(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Executes procedure for each value in the map.
forEachValue(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Executes procedure for each value in the map.
forEachValue(TObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Executes procedure for each value in the map.
forEachValue(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Executes procedure for each value in the map.
forEachValue(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Executes procedure for each value in the map.
forEachValue(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Executes procedure for each value in the map.
forEachValue(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Executes procedure for each value in the map.
forEachValue(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Executes procedure for each value in the map.
forEachValue(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Executes procedure for each value in the map.
forEachValue(TObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Executes procedure for each value in the map.
forEachValue(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Executes procedure for each value in the map.
forEachValue(TObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.THashMap
Executes procedure for each value in the map.
forEachValue(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Executes procedure for each value in the map.
forEachValue(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Executes procedure for each value in the map.
forEachValue(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Executes procedure for each value in the map.
forEachValue(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Executes procedure for each value in the map.
forEachValue(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Executes procedure for each value in the map.
forEachValue(TObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Executes procedure for each value in the map.
forEachValue(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Executes procedure for each value in the map.
forEachValue(TObjectProcedure<T>) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Executes procedure for each entry in the list.
forEachValue(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Executes procedure for each value in the map.
forEachValue(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Executes procedure for each value in the map.
forEachValue(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Executes procedure for each value in the map.
forEachValue(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Executes procedure for each value in the map.
forEachValue(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Executes procedure for each value in the map.
forEachValue(TObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Executes procedure for each value in the map.
forEachValue(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Executes procedure for each value in the map.
forEachValue(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Executes procedure for each value in the map.
forEachValue(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Executes procedure for each value in the map.
forEachValue(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Executes procedure for each value in the map.
forEachValue(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Executes procedure for each value in the map.
forEachValue(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Executes procedure for each value in the map.
forEachValue(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Executes procedure for each value in the map.
forEachValue(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Executes procedure for each value in the map.
forEachValue(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Executes procedure for each value in the map.
forEachValue(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Executes procedure for each value in the map.
forEachValue(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Executes procedure for each value in the map.
forEachValue(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Executes procedure for each value in the map.
forEachValue(TObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Executes procedure for each value in the map.
forEachValue(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Executes procedure for each value in the map.
forEnumeration(Enumeration<T>) - Static method in class org.elasticsearch.util.collect.Iterators
Adapts an Enumeration to the Iterator interface.
forInjectionPoints(Set<InjectionPoint>) - Static method in class org.elasticsearch.util.inject.spi.Dependency
Returns the dependencies from the given injection points.
forInstance(Scope) - Static method in class org.elasticsearch.util.inject.internal.Scoping
 
forInstanceMethodsAndFields(TypeLiteral<?>) - Static method in class org.elasticsearch.util.inject.spi.InjectionPoint
Returns all instance method and field injection points on type.
forInstanceMethodsAndFields(Class<?>) - Static method in class org.elasticsearch.util.inject.spi.InjectionPoint
Returns all instance method and field injection points on type.
fork() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Arranges to asynchronously execute this task.
ForkJoinPool - Class in org.elasticsearch.util.concurrent.jsr166y
An ExecutorService for running ForkJoinTasks.
ForkJoinPool() - Constructor for class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Creates a ForkJoinPool with parallelism equal to Runtime.availableProcessors(), and using the default thread factory.
ForkJoinPool(int) - Constructor for class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Creates a ForkJoinPool with the indicated parallelism level and using the default thread factory.
ForkJoinPool(ForkJoinPool.ForkJoinWorkerThreadFactory) - Constructor for class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Creates a ForkJoinPool with parallelism equal to Runtime.availableProcessors(), and using the given thread factory.
ForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory) - Constructor for class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Creates a ForkJoinPool with the given parallelism and thread factory.
ForkJoinPool.ForkJoinWorkerThreadFactory - Interface in org.elasticsearch.util.concurrent.jsr166y
Factory for creating new ForkJoinWorkerThreads.
ForkJoinPool.ManagedBlocker - Interface in org.elasticsearch.util.concurrent.jsr166y
Interface for extending managed parallelism for tasks running in ForkJoinPools.
ForkJoinTask<V> - Class in org.elasticsearch.util.concurrent.jsr166y
Abstract base class for tasks that run within a ForkJoinPool.
ForkJoinTask() - Constructor for class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
 
ForkJoinWorkerThread - Class in org.elasticsearch.util.concurrent.jsr166y
A thread managed by a ForkJoinPool.
ForkJoinWorkerThread(ForkJoinPool) - Constructor for class org.elasticsearch.util.concurrent.jsr166y.ForkJoinWorkerThread
Creates a ForkJoinWorkerThread operating in the given pool.
forMap(Map<K, V>) - Static method in class org.elasticsearch.util.base.Functions
Returns a function which performs a map lookup.
forMap(Map<K, ? extends V>, V) - Static method in class org.elasticsearch.util.base.Functions
Returns a function which performs a map lookup with a default value.
forMap(Map<K, V>) - Static method in class org.elasticsearch.util.collect.Multimaps
Returns a multimap view of the specified map.
format(String, Object...) - Static method in class org.elasticsearch.util.inject.internal.Errors
 
format(String, Collection<Message>) - Static method in class org.elasticsearch.util.inject.internal.Errors
Returns the formatted message for an exception with the specified messages.
format() - Method in class org.elasticsearch.util.joda.FormatDateTimeFormatter
 
format(String, Object...) - Static method in class org.elasticsearch.util.logging.support.LoggerMessageFormat
 
format(String, String, Object...) - Static method in class org.elasticsearch.util.logging.support.LoggerMessageFormat
 
format(double) - Static method in class org.elasticsearch.util.Percent
 
format() - Method in class org.elasticsearch.util.TimeValue
 
format(PeriodType) - Method in class org.elasticsearch.util.TimeValue
 
format1Decimals(double, String) - Static method in class org.elasticsearch.util.Strings
Format the double value with a single decimal points, trimming trailing '.0'.
FormatDateTimeFormatter - Class in org.elasticsearch.util.joda
A simple wrapper around DateTimeFormatter that retains the format that was used to create it.
FormatDateTimeFormatter(String, DateTimeFormatter) - Constructor for class org.elasticsearch.util.joda.FormatDateTimeFormatter
 
FormatDateTimeFormatter(String, DateTimeFormatter, DateTimeFormatter) - Constructor for class org.elasticsearch.util.joda.FormatDateTimeFormatter
 
formatInjectionPoint(Formatter, Dependency<?>, InjectionPoint) - Static method in class org.elasticsearch.util.inject.internal.Errors
 
formatSource(Formatter, Object) - Static method in class org.elasticsearch.util.inject.internal.Errors
 
forMember(Member) - Static method in enum org.elasticsearch.util.inject.internal.BytecodeGen.Visibility
 
forMember(Member) - Static method in class org.elasticsearch.util.inject.internal.StackTraceElements
 
forModule(Module) - Static method in class org.elasticsearch.util.inject.internal.ProviderMethodsModule
Returns a module which creates bindings for provider methods from the given module.
forName(String) - Static method in class org.elasticsearch.util.jline.ANSI.Code
Returns the ANSI code for the given symbolic name.
forObject(Object) - Static method in class org.elasticsearch.util.inject.internal.ProviderMethodsModule
Returns a module which creates bindings for provider methods from the given object.
forPattern(String) - Static method in class org.elasticsearch.util.joda.Joda
Parses a joda based pattern, including some named ones (similar to the built in Joda ISO ones).
forPredicate(Predicate<T>) - Static method in class org.elasticsearch.util.base.Functions
Creates a function that returns the same boolean output as the given predicate for all inputs.
forStaticMethodsAndFields(TypeLiteral) - Static method in class org.elasticsearch.util.inject.spi.InjectionPoint
Returns all static method and field injection points on type.
forStaticMethodsAndFields(Class<?>) - Static method in class org.elasticsearch.util.inject.spi.InjectionPoint
Returns all static method and field injection points on type.
forType(Class<?>) - Static method in enum org.elasticsearch.util.inject.internal.BytecodeGen.Visibility
 
forType(Class<?>) - Static method in class org.elasticsearch.util.inject.internal.StackTraceElements
 
ForwardingCollection<E> - Class in org.elasticsearch.util.collect
A collection which forwards all its method calls to another collection.
ForwardingCollection() - Constructor for class org.elasticsearch.util.collect.ForwardingCollection
 
ForwardingConcurrentMap<K,V> - Class in org.elasticsearch.util.collect
A concurrent map which forwards all its method calls to another concurrent map.
ForwardingConcurrentMap() - Constructor for class org.elasticsearch.util.collect.ForwardingConcurrentMap
 
ForwardingIterator<T> - Class in org.elasticsearch.util.collect
An iterator which forwards all its method calls to another iterator.
ForwardingIterator() - Constructor for class org.elasticsearch.util.collect.ForwardingIterator
 
ForwardingList<E> - Class in org.elasticsearch.util.collect
A list which forwards all its method calls to another list.
ForwardingList() - Constructor for class org.elasticsearch.util.collect.ForwardingList
 
ForwardingListIterator<E> - Class in org.elasticsearch.util.collect
A list iterator which forwards all its method calls to another list iterator.
ForwardingListIterator() - Constructor for class org.elasticsearch.util.collect.ForwardingListIterator
 
ForwardingMap<K,V> - Class in org.elasticsearch.util.collect
A map which forwards all its method calls to another map.
ForwardingMap() - Constructor for class org.elasticsearch.util.collect.ForwardingMap
 
ForwardingMapEntry<K,V> - Class in org.elasticsearch.util.collect
A map entry which forwards all its method calls to another map entry.
ForwardingMapEntry() - Constructor for class org.elasticsearch.util.collect.ForwardingMapEntry
 
ForwardingMultimap<K,V> - Class in org.elasticsearch.util.collect
A multimap which forwards all its method calls to another multimap.
ForwardingMultimap() - Constructor for class org.elasticsearch.util.collect.ForwardingMultimap
 
ForwardingMultiset<E> - Class in org.elasticsearch.util.collect
A multiset which forwards all its method calls to another multiset.
ForwardingMultiset() - Constructor for class org.elasticsearch.util.collect.ForwardingMultiset
 
ForwardingObject - Class in org.elasticsearch.util.collect
An abstract base class for implementing the decorator pattern.
ForwardingObject() - Constructor for class org.elasticsearch.util.collect.ForwardingObject
Sole constructor.
ForwardingQueue<E> - Class in org.elasticsearch.util.collect
A queue which forwards all its method calls to another queue.
ForwardingQueue() - Constructor for class org.elasticsearch.util.collect.ForwardingQueue
 
ForwardingSet<E> - Class in org.elasticsearch.util.collect
A set which forwards all its method calls to another set.
ForwardingSet() - Constructor for class org.elasticsearch.util.collect.ForwardingSet
 
ForwardingSortedMap<K,V> - Class in org.elasticsearch.util.collect
A sorted map which forwards all its method calls to another sorted map.
ForwardingSortedMap() - Constructor for class org.elasticsearch.util.collect.ForwardingSortedMap
 
ForwardingSortedSet<E> - Class in org.elasticsearch.util.collect
A sorted set which forwards all its method calls to another sorted set.
ForwardingSortedSet() - Constructor for class org.elasticsearch.util.collect.ForwardingSortedSet
 
fragmentCharSize() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.ParsedHighlightField
 
fragments() - Method in class org.elasticsearch.search.highlight.HighlightField
The highlighted fragments.
free() - Method in class org.elasticsearch.monitor.os.OsStats.Mem
 
free() - Method in class org.elasticsearch.monitor.os.OsStats.Swap
 
FREE - Static variable in class org.elasticsearch.util.gnu.trove.TObjectHash
 
FREE - Static variable in class org.elasticsearch.util.gnu.trove.TPrimitiveHash
flag indicating that a slot in the hashtable is available
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, 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
 
freqComparator() - Static method in class org.elasticsearch.action.terms.TermFreq
A frequency based comparator with higher frequencies first.
freqs() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
 
frequency(Iterable<?>, Object) - Static method in class org.elasticsearch.util.collect.Iterables
Returns the number of elements in the specified iterable that equal the specified object.
frequency(Iterator<?>, Object) - Static method in class org.elasticsearch.util.collect.Iterators
Returns the number of elements in the specified iterator that equal the specified object.
from() - Method in class org.elasticsearch.action.terms.TermsRequest
The lower bound term from which the iteration will start.
from(Object) - Method in class org.elasticsearch.action.terms.TermsRequest
The lower bound term from which the iteration will start.
from(String) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The from part of the filter query.
from(int) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The from part of the filter query.
from(long) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The from part of the filter query.
from(float) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The from part of the filter query.
from(double) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The from part of the filter query.
from(Object) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
from(String) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
from(int) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
from(long) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
from(float) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
from(double) - Method in class org.elasticsearch.index.query.xcontent.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.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
 
from(Comparator<T>) - Static method in class org.elasticsearch.util.collect.Ordering
Returns an ordering for a pre-existing comparator.
from(Ordering<T>) - Static method in class org.elasticsearch.util.collect.Ordering
Deprecated. no need to use this
fromBytes(byte[], Settings, DiscoveryNode) - Static method in class org.elasticsearch.cluster.ClusterState.Builder
 
fromBytes(byte[]) - Static method in class org.elasticsearch.util.Unicode
 
fromBytes(byte[], int, int) - Static method in class org.elasticsearch.util.Unicode
 
fromBytesAsUtf16(byte[]) - Static method in class org.elasticsearch.util.Unicode
 
fromBytesAsUtf16(byte[], int, int) - Static method in class org.elasticsearch.util.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.ThreadingModel
 
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.facets.Facet.Type
 
fromInclusive() - Method in class org.elasticsearch.action.terms.TermsRequest
Should the first from (if set using TermsRequest.from(Object) be inclusive or not.
fromInclusive(boolean) - Method in class org.elasticsearch.action.terms.TermsRequest
Should the first from (if set using TermsRequest.from(Object) be inclusive or not.
FromParseElement - Class in org.elasticsearch.search.query
 
FromParseElement() - Constructor for class org.elasticsearch.search.query.FromParseElement
 
fromProperties(Properties) - Static method in class org.elasticsearch.util.collect.Maps
Creates an ImmutableMap<String, String> from a Properties instance.
fromRestContentType(String) - Static method in enum org.elasticsearch.util.xcontent.XContentType
 
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, TermsRequest.SortType) - Static method in enum org.elasticsearch.action.terms.TermsRequest.SortType
Parses the sort type from a string.
fromString(String) - Static method in class org.elasticsearch.util.UUID
Creates a UUID from the string standard representation as described in the UUID.toString() method.
fromStringAsBytes(String) - Static method in class org.elasticsearch.util.Unicode
 
fromStringAsUtf8(String) - Static method in class org.elasticsearch.util.Unicode
 
fromValue(byte) - Static method in enum org.elasticsearch.action.admin.cluster.health.ClusterHealthStatus
 
fromValue(byte) - Static method in enum org.elasticsearch.action.terms.TermsRequest.SortType
Parses the sort type from its TermsRequest.SortType.value().
fromValue(byte) - Static method in enum org.elasticsearch.cluster.metadata.AliasAction.Type
 
fromValue(byte) - Static method in enum org.elasticsearch.cluster.routing.ShardRoutingState
 
fromXContent(XContentParser, Settings) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
fromXContent(XContentParser, Settings) - Static method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
fsDirectory() - Method in class org.elasticsearch.index.store.fs.AbstractFsStore
 
fsDirectory() - Method in class org.elasticsearch.index.store.fs.MmapFsStore
 
fsDirectory() - Method in class org.elasticsearch.index.store.fs.NioFsStore
 
fsDirectory() - Method in class org.elasticsearch.index.store.fs.SimpleFsStore
 
FsGateway - Class in org.elasticsearch.gateway.fs
 
FsGateway(Settings, 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
 
FsIndexGateway - Class in org.elasticsearch.index.gateway.fs
 
FsIndexGateway(Index, Settings, Environment, 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, FsIndexGateway, IndexShard, Store, RecoveryThrottler) - Constructor for class org.elasticsearch.index.gateway.fs.FsIndexShardGateway
 
FsStores - Class in org.elasticsearch.index.store.fs
 
FsStores() - Constructor for class org.elasticsearch.index.store.fs.FsStores
 
FULL - Static variable in class org.elasticsearch.util.gnu.trove.TPrimitiveHash
flag indicating that a slot in the hashtable is occupied
full() - Static method in class org.elasticsearch.Version
 
fullDelete() - Method in class org.elasticsearch.index.store.fs.AbstractFsStore
 
fullDelete() - Method in interface org.elasticsearch.index.store.Store
Deletes the store completely.
fullDelete() - Method in class org.elasticsearch.index.store.support.AbstractStore
 
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 MapperService.SmartNameFieldMappers of all the FieldMappers that are registered under the give fullName across all the different DocumentMapper types.
fullPathAsText(String) - Method in class org.elasticsearch.index.mapper.xcontent.ContentPath
 
Function<F,T> - Interface in org.elasticsearch.util.base
A transformation from one object to another.
Functions - Class in org.elasticsearch.util.base
Useful functions.
FutureListener<T> - Interface in org.elasticsearch.threadpool
 
Futures - Class in org.elasticsearch.util.concurrent
 
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
 
fuzzyLikeThisFieldQuery(String) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A fuzzy like this query that finds documents that are "like" the provided FuzzyLikeThisFieldQueryBuilder.likeText(String).
FuzzyLikeThisFieldQueryBuilder - Class in org.elasticsearch.index.query.xcontent
 
FuzzyLikeThisFieldQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.xcontent.FuzzyLikeThisFieldQueryBuilder
A fuzzy more like this query on the provided field.
FuzzyLikeThisFieldQueryParser - Class in org.elasticsearch.index.query.xcontent
{ fuzzy_like_This_field : { field1 : { maxNumTerms : 12, boost : 1.1, likeText : "..." } }
FuzzyLikeThisFieldQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.FuzzyLikeThisFieldQueryParser
 
fuzzyLikeThisQuery(String...) - Static method in class org.elasticsearch.index.query.xcontent.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.xcontent.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.xcontent
 
FuzzyLikeThisQueryBuilder() - Constructor for class org.elasticsearch.index.query.xcontent.FuzzyLikeThisQueryBuilder
Constructs a new fuzzy like this query which uses the "_all" field.
FuzzyLikeThisQueryBuilder(String...) - Constructor for class org.elasticsearch.index.query.xcontent.FuzzyLikeThisQueryBuilder
Sets the field names that will be used when generating the 'Fuzzy Like This' query.
FuzzyLikeThisQueryParser - Class in org.elasticsearch.index.query.xcontent
{ fuzzy_like_this : { maxNumTerms : 12, boost : 1.1, fields : ["field1", "field2"] likeText : "..." } }
FuzzyLikeThisQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.FuzzyLikeThisQueryParser
 
fuzzyMinSim(float) - Method in class org.elasticsearch.index.query.xcontent.FieldQueryBuilder
Set the minimum similarity for fuzzy queries.
fuzzyMinSim(float) - Method in class org.elasticsearch.index.query.xcontent.QueryStringQueryBuilder
Set the minimum similarity for fuzzy queries.
fuzzyPrefixLength(int) - Method in class org.elasticsearch.index.query.xcontent.FieldQueryBuilder
Set the prefix length for fuzzy queries.
fuzzyPrefixLength(int) - Method in class org.elasticsearch.index.query.xcontent.QueryStringQueryBuilder
Set the minimum similarity for fuzzy queries.

G

Gateway - Interface in org.elasticsearch.gateway
 
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
 
gatewayHome() - Method in class org.elasticsearch.gateway.fs.FsGateway
 
GatewayModule - Class in org.elasticsearch.gateway
 
GatewayModule(Settings) - Constructor for class org.elasticsearch.gateway.GatewayModule
 
GatewayService - Class in org.elasticsearch.gateway
 
GatewayService(Settings, Gateway, ClusterService, DiscoveryService, ThreadPool, MetaDataService) - 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.node.NodeIndicesAdminClient
 
gatewaySnapshot(GatewaySnapshotRequest, ActionListener<GatewaySnapshotResponse>) - Method in class org.elasticsearch.client.node.NodeIndicesAdminClient
 
gatewaySnapshot(GatewaySnapshotRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
gatewaySnapshot(GatewaySnapshotRequest, ActionListener<GatewaySnapshotResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
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.
GatewaySnapshotResponse - Class in org.elasticsearch.action.admin.indices.gateway.snapshot
Reponse for the gateway snapshot action.
gb() - Method in class org.elasticsearch.util.SizeValue
 
gbFrac() - Method in class org.elasticsearch.util.SizeValue
 
gc() - Method in class org.elasticsearch.monitor.jvm.JvmStats
 
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
 
generator - Variable in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
GermanAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
GermanAnalyzerProvider(Index, Settings, 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 - Static variable in class org.elasticsearch.action.TransportActions
 
get(GetRequest) - Method in interface org.elasticsearch.client.Client
Gets the JSON source that was indexed from an index with a type and id.
get(GetRequest, ActionListener<GetResponse>) - Method in interface org.elasticsearch.client.Client
Gets the JSON source that was indexed from an index with a type and id.
get(GetRequest) - Method in class org.elasticsearch.client.node.NodeClient
 
get(GetRequest, ActionListener<GetResponse>) - Method in class org.elasticsearch.client.node.NodeClient
 
get(GetRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
get(GetRequest, ActionListener<GetResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
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() - 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.BrazilianAnalyzerProvider
 
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.DutchAnalyzerProvider
 
get() - Method in class org.elasticsearch.index.analysis.FrenchAnalyzerProvider
 
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.KeywordAnalyzerProvider
 
get() - Method in class org.elasticsearch.index.analysis.PersianAnalyzerProvider
 
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.StandardAnalyzerProvider
 
get() - Method in class org.elasticsearch.index.analysis.StopAnalyzerProvider
 
get() - Method in class org.elasticsearch.index.analysis.ThaiAnalyzerProvider
 
get() - Method in class org.elasticsearch.index.analysis.WhitespaceAnalyzerProvider
 
get(String, String) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
get(String, String) - 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 interface org.elasticsearch.util.base.Supplier
Retrieves an instance of the appropriate type.
get(int) - Method in class org.elasticsearch.util.collect.ForwardingList
 
get(Object) - Method in class org.elasticsearch.util.collect.ForwardingMap
 
get(K) - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
get(Object) - Method in class org.elasticsearch.util.collect.ImmutableBiMap
 
get(K) - Method in class org.elasticsearch.util.collect.ImmutableListMultimap
Returns an immutable list of the values for the given key.
get(Object) - Method in class org.elasticsearch.util.collect.ImmutableMap
 
get(K) - Method in class org.elasticsearch.util.collect.ImmutableMultimap
Returns an immutable collection of the values for the given key.
get(K) - Method in class org.elasticsearch.util.collect.ImmutableSetMultimap
Returns an immutable set of the values for the given key.
get(Object) - Method in class org.elasticsearch.util.collect.ImmutableSortedMap
 
get(Iterable<T>, int) - Static method in class org.elasticsearch.util.collect.Iterables
Returns the element at the specified position in an iterable.
get(Iterator<T>, int) - Static method in class org.elasticsearch.util.collect.Iterators
Advances iterator position + 1 times, returning the element at the positionth position.
get(K) - Method in class org.elasticsearch.util.collect.LinkedListMultimap
Returns a collection view of all values associated with a key.
get(K) - Method in interface org.elasticsearch.util.collect.ListMultimap
Returns a collection view of all values associated with a key.
get(K) - Method in interface org.elasticsearch.util.collect.Multimap
Returns a collection view of all values associated with a key.
get(K) - Method in interface org.elasticsearch.util.collect.SetMultimap
Returns a collection view of all values associated with a key.
get(K) - Method in interface org.elasticsearch.util.collect.SortedSetMultimap
Returns a collection view of all values associated with a key.
get(long, TimeUnit) - Method in class org.elasticsearch.util.concurrent.AbstractFuture
 
get() - Method in class org.elasticsearch.util.concurrent.AbstractFuture
 
get(long) - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
get(Object) - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
get(Object) - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
get(long) - Method in interface org.elasticsearch.util.concurrent.ConcurrentMapLong
 
get(int) - Method in class org.elasticsearch.util.concurrent.ConcurrentSafeArray
 
get(Object) - Method in class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
get() - Method in class org.elasticsearch.util.concurrent.highscalelib.ConcurrentAutoTable
Current value of the counter.
get(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
get(long) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
get(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Auto-boxing version of NonBlockingHashMapLong.get(long).
get(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
get(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
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 org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
 
get(long, TimeUnit) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
 
get(Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Retrieves the value for key
get(Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Retrieves the value for key
get(Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Retrieves the value for key
get(Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Retrieves the value for key
get(Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Retrieves the value for key
get(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Retrieves the value for key
get(Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Retrieves the value for key
get(Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Retrieves the value for key
get(Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Retrieves the value for key
get(Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Retrieves the value for key
get(Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Retrieves the value for key
get(Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Retrieves the value for key
get(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Retrieves the value for key
get(Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Retrieves the value for key
get(Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Retrieves the value for key
get(Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Retrieves the value for key
get(Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Retrieves the value for key
get(Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Retrieves the value for key
get(Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Retrieves the value for key
get(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Retrieves the value for key
get(Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Retrieves the value for key
get(Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Retrieves the value for key
get(Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Retrieves the value for key
get(Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Retrieves the value for key
get(Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Retrieves the value for key
get(Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Retrieves the value for key
get(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Retrieves the value for key
get(Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Retrieves the value for key
get(Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Retrieves the value for key
get(Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Retrieves the value for key
get(Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Retrieves the value for key
get(Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Retrieves the value for key
get(Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Retrieves the value for key
get(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Retrieves the value for key
get(Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Retrieves the value for key
get(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Retrieves the value for key
get(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Retrieves the value for key
get(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Retrieves the value for key
get(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Retrieves the value for key
get(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Retrieves the value for key
get(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Retrieves the value for key
get(Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Retrieves the value for key
get(Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Retrieves the value for key
get(Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Retrieves the value for key
get(Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Retrieves the value for key
get(Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Retrieves the value for key
get(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Retrieves the value for key
get(Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Retrieves the value for key
get(int) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Returns the value at the specified offset.
get(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
retrieves the value for key
get(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
retrieves the value for key
get(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
retrieves the value for key
get(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
retrieves the value for key
get(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
retrieves the value for key
get(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
retrieves the value for key
get(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
retrieves the value for key
get(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Returns the value at the specified offset.
get(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
retrieves the value for key
get(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
retrieves the value for key
get(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
retrieves the value for key
get(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
retrieves the value for key
get(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
retrieves the value for key
get(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
retrieves the value for key
get(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
retrieves the value for key
get(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Returns the value at the specified offset.
get(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
retrieves the value for key
get(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
retrieves the value for key
get(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
retrieves the value for key
get(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
retrieves the value for key
get(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
retrieves the value for key
get(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
retrieves the value for key
get(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
retrieves the value for key
get(Object) - Method in class org.elasticsearch.util.gnu.trove.THashMap
retrieves the value for key
get(int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Returns the value at the specified offset.
get(int) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
retrieves the value for key
get(int) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
retrieves the value for key
get(int) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
retrieves the value for key
get(int) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
retrieves the value for key
get(int) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
retrieves the value for key
get(int) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
retrieves the value for key
get(int) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
retrieves the value for key
get(int) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
get(int) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Returns the value at the specified offset.
get(long) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
retrieves the value for key
get(long) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
retrieves the value for key
get(long) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
retrieves the value for key
get(long) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
retrieves the value for key
get(long) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
retrieves the value for key
get(long) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
retrieves the value for key
get(long) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
retrieves the value for key
get(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
retrieves the value for key
get(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
retrieves the value for key
get(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
retrieves the value for key
get(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
retrieves the value for key
get(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
retrieves the value for key
get(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
retrieves the value for key
get(int) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Returns the value at the specified offset.
get(short) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
retrieves the value for key
get(short) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
retrieves the value for key
get(short) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
retrieves the value for key
get(short) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
retrieves the value for key
get(short) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
retrieves the value for key
get(short) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
retrieves the value for key
get(short) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
retrieves the value for key
get() - Method in class org.elasticsearch.util.inject.assistedinject.FactoryProvider
 
get(K, Errors) - Method in class org.elasticsearch.util.inject.internal.FailableCache
 
get(Errors, InternalContext, Dependency<?>) - Method in interface org.elasticsearch.util.inject.internal.InternalFactory
Creates an object to be injected.
get() - Method in class org.elasticsearch.util.inject.internal.ProviderMethod
 
get() - Method in class org.elasticsearch.util.inject.internal.SourceProvider
Returns the calling line of code.
get(Class<T>) - Static method in class org.elasticsearch.util.inject.Key
Gets a key for an injection type.
get(Class<T>, Class<? extends Annotation>) - Static method in class org.elasticsearch.util.inject.Key
Gets a key for an injection type and an annotation type.
get(Class<T>, Annotation) - Static method in class org.elasticsearch.util.inject.Key
Gets a key for an injection type and an annotation.
get(Type) - Static method in class org.elasticsearch.util.inject.Key
Gets a key for an injection type.
get(Type, Class<? extends Annotation>) - Static method in class org.elasticsearch.util.inject.Key
Gets a key for an injection type and an annotation type.
get(Type, Annotation) - Static method in class org.elasticsearch.util.inject.Key
Gets a key for an injection type and an annotation.
get(TypeLiteral<T>) - Static method in class org.elasticsearch.util.inject.Key
Gets a key for an injection type.
get(TypeLiteral<T>, Class<? extends Annotation>) - Static method in class org.elasticsearch.util.inject.Key
Gets a key for an injection type and an annotation type.
get(TypeLiteral<T>, Annotation) - Static method in class org.elasticsearch.util.inject.Key
Gets a key for an injection type and an annotation.
get() - Method in interface org.elasticsearch.util.inject.Provider
Provides an instance of T.
get(Key<T>) - Static method in class org.elasticsearch.util.inject.spi.Dependency
Returns a new dependency that is not attached to an injection point.
get(Type) - Static method in class org.elasticsearch.util.inject.TypeLiteral
Gets type literal for the given Type instance.
get(Class<T>) - Static method in class org.elasticsearch.util.inject.TypeLiteral
Gets type literal for the given Class instance.
get() - Method in class org.elasticsearch.util.io.BooleanStreamable
 
get() - Method in class org.elasticsearch.util.io.stream.LongStreamable
 
get() - Method in class org.elasticsearch.util.io.stream.StringStreamable
 
get(K) - Method in class org.elasticsearch.util.MapBuilder
 
get(int) - Method in interface org.elasticsearch.util.SafeArray
 
get(String) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Returns a setting value based on the setting key.
get(String) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
get(String, String) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
get(String) - Method in interface org.elasticsearch.util.settings.Settings
Returns the setting value associated with the setting key.
get(String, String) - Method in interface org.elasticsearch.util.settings.Settings
Returns the setting value associated with the setting key.
get() - Method in class org.elasticsearch.util.ThreadLocals.CleanableValue
 
get(int) - Method in class org.elasticsearch.util.trove.ExtTIntIntHashMap
 
get(T) - Method in class org.elasticsearch.util.trove.ExtTObjectFloatHashMap
 
get(T) - Method in class org.elasticsearch.util.trove.ExtTObjectIntHasMap
 
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.util.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.util.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.util.TimeValue).
getActiveCount() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPool
 
getActiveCount() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPoolManagement
 
getActiveCount() - Method in class org.elasticsearch.threadpool.cached.CachedThreadPool
 
getActiveCount() - Method in class org.elasticsearch.threadpool.cached.CachedThreadPoolManagement
 
getActiveCount() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPool
 
getActiveCount() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPoolManagement
 
getActiveCount() - Method in interface org.elasticsearch.threadpool.ThreadPool
Returns the approximate number of threads that are actively executing tasks.
getActiveCount() - Method in class org.elasticsearch.threadpool.ThreadPoolStats
Returns the approximate number of threads that are actively executing tasks.
getActiveCount() - Method in class org.elasticsearch.util.concurrent.DynamicThreadPoolExecutor
 
getActiveCount() - Method in class org.elasticsearch.util.concurrent.ScalingThreadPoolExecutor
Returns the approximate number of threads that are actively executing tasks.
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
 
getActiveThreadCount() - Method in class org.elasticsearch.util.concurrent.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.util.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.monitor.network.NetworkInfo.Interface
 
getAddress() - Method in class org.elasticsearch.transport.TransportInfo
 
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.util.network.NetworkUtils
 
getAllAvailableInterfaces() - Static method in class org.elasticsearch.util.network.NetworkUtils
 
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.util.lucene.search.MoreLikeThisQuery
 
getAnnotation() - Method in class org.elasticsearch.util.inject.Key
Gets the annotation.
getAnnotationType() - Method in class org.elasticsearch.util.inject.Key
Gets the annotation type.
getAnnotationType() - Method in class org.elasticsearch.util.inject.spi.ScopeBinding
 
getArrivedParties() - Method in class org.elasticsearch.util.concurrent.jsr166y.Phaser
Returns the number of registered parties that have arrived at the current phase of this barrier.
getAsArray(String) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getAsArray(String, String[]) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getAsArray(String, String[]) - Method in interface org.elasticsearch.util.settings.Settings
The values associated with a setting prefix as an array.
getAsArray(String) - Method in interface org.elasticsearch.util.settings.Settings
 
getAsBoolean(String, Boolean) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getAsBoolean(String, Boolean) - Method in interface org.elasticsearch.util.settings.Settings
Returns the setting value (as boolean) associated with the setting key.
getAsClass(String, Class<? extends T>) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getAsClass(String, Class<? extends T>, String, String) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getAsClass(String, Class<? extends T>) - Method in interface org.elasticsearch.util.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.util.settings.Settings
Returns the setting value (as a class) associated with the setting key.
getAsDouble(String, Double) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getAsDouble(String, Double) - Method in interface org.elasticsearch.util.settings.Settings
Returns the setting value (as double) associated with the setting key.
getAsFloat(String, Float) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getAsFloat(String, Float) - Method in interface org.elasticsearch.util.settings.Settings
Returns the setting value (as float) associated with the setting key.
getAsInt(String, Integer) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getAsInt(String, Integer) - Method in interface org.elasticsearch.util.settings.Settings
Returns the setting value (as int) associated with the setting key.
getAsLong(String, Long) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getAsLong(String, Long) - Method in interface org.elasticsearch.util.settings.Settings
Returns the setting value (as long) associated with the setting key.
getAsMap() - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getAsMap() - Method in interface org.elasticsearch.util.settings.Settings
The settings as a Map.
getAsSize(String, SizeValue) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getAsSize(String, SizeValue) - Method in interface org.elasticsearch.util.settings.Settings
Returns the setting value (as size) associated with the setting key.
getAsTime(String, TimeValue) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getAsTime(String, TimeValue) - Method in interface org.elasticsearch.util.settings.Settings
Returns the setting value (as time) associated with the setting key.
getAsyncMode() - Method in class org.elasticsearch.util.concurrent.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.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
 
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.action.admin.cluster.node.info.NodeInfo
The attributes of the node.
getAttributes() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
The node attributes.
getAttributes(String[]) - Method in class org.elasticsearch.jmx.ResourceDMBean
 
getAutoCompactionFactor() - Method in class org.elasticsearch.util.gnu.trove.THash
 
getBindHost() - Method in class org.elasticsearch.transport.netty.NettyTransportManagement
 
getBinding(Injector, Key<?>) - Static method in class org.elasticsearch.util.guice.Injectors
Returns the binding for the given key or null if there is no such binding
getBinding(Key<T>) - Method in interface org.elasticsearch.util.inject.Injector
Returns the binding for the given injection key.
getBinding(Class<T>) - Method in interface org.elasticsearch.util.inject.Injector
Returns the binding for the given type.
getBinding() - Method in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
getBindings() - Method in interface org.elasticsearch.util.inject.Injector
Returns all explicit bindings.
getBindingsOf(Injector, Matcher<Class>) - Static method in class org.elasticsearch.util.guice.Injectors
Returns a collection of all of the bindings matching the given matcher
getBindingsOf(Injector, Class<?>) - Static method in class org.elasticsearch.util.guice.Injectors
Returns a collection of all bindings of the given base type
getBooleanQuery(List<BooleanClause>, boolean) - Method in class org.elasticsearch.index.query.support.MapperQueryParser
 
getBoostFactor() - Method in class org.elasticsearch.util.lucene.search.CustomBoostFactorQuery
 
getBoostTermsFactor() - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
getBootClassPath() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
getBoundAddress() - Method in class org.elasticsearch.transport.TransportServiceManagement
 
getBuilder() - Method in class org.elasticsearch.util.io.StringBuilderWriter
Return the underlying builder.
getByPrefix(String) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getByPrefix(String) - Method in interface org.elasticsearch.util.settings.Settings
A settings that are filtered (and key is removed) with the specified prefix.
getBytes() - Method in class org.elasticsearch.util.SizeValue
 
getCacheSize() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
getCause() - Method in interface org.elasticsearch.ElasticSearchWrapperException
 
getCause() - Method in class org.elasticsearch.util.inject.spi.Message
Returns the throwable that caused this message, or null if this message was not caused by a throwable.
getChild(String) - Method in class org.elasticsearch.util.path.PathTrie.TrieNode
 
getClassLoader(Class<?>) - Static method in class org.elasticsearch.util.inject.internal.BytecodeGen
Returns the class loader to host generated classes for type.
getClassLoader() - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getClassLoader() - Method in interface org.elasticsearch.util.settings.Settings
The class loader associated with this settings.
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.support.nodes.NodesOperationResponse
 
getCollectionCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
getCollectionTime() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
getComponentSettings(Class) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getComponentSettings(String, Class) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getComponentSettings(Class) - Method in interface org.elasticsearch.util.settings.Settings
Component settings for a specific component.
getComponentSettings(String, Class) - Method in interface org.elasticsearch.util.settings.Settings
Component settings for a specific component.
getConcreteAllIndices() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
getConnectTimeout() - Method in class org.elasticsearch.transport.netty.NettyTransportManagement
 
getConstructionContext(Object) - Method in class org.elasticsearch.util.inject.internal.InternalContext
 
getConstructor() - Method in interface org.elasticsearch.util.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.monitor.jvm.JvmStats.Threads
 
getCount() - Method in class org.elasticsearch.search.facets.CountFacet
The count of the facet.
getCount() - Method in interface org.elasticsearch.util.collect.Multiset.Entry
Returns the count of the associated element in the underlying multiset.
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
 
getCurrentReference() - Method in class org.elasticsearch.util.inject.internal.ConstructionContext
 
getCurrEstab() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getData() - Method in class org.elasticsearch.util.io.compression.lzf.LZFChunk
 
getDataNodes() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
getDays() - Method in class org.elasticsearch.util.TimeValue
 
getDaysFrac() - Method in class org.elasticsearch.util.TimeValue
 
getDeclaringClass() - Method in class org.elasticsearch.util.inject.internal.MoreTypes.MemberImpl
 
getDefaultClassLoader() - Static method in class org.elasticsearch.util.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.util.inject.spi.MembersInjectorLookup
Returns the delegate members injector, or null if it has not yet been initialized.
getDelegate() - Method in class org.elasticsearch.util.inject.spi.ProviderLookup
Returns the delegate provider, or null if it has not yet been initialized.
getDeletedDocs() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus.Docs
 
getDeletedDocs() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus.Docs
 
getDeletedDocs() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus.Docs
 
getDependencies() - Method in class org.elasticsearch.util.inject.assistedinject.FactoryProvider
 
getDependencies() - Method in class org.elasticsearch.util.inject.internal.ExposedBindingImpl
 
getDependencies() - Method in class org.elasticsearch.util.inject.internal.InstanceBindingImpl
 
getDependencies() - Method in class org.elasticsearch.util.inject.internal.ProviderInstanceBindingImpl
 
getDependencies() - Method in class org.elasticsearch.util.inject.internal.ProviderMethod
 
getDependencies() - Method in interface org.elasticsearch.util.inject.spi.ConvertedConstantBinding
Returns a singleton set containing only the converted key.
getDependencies() - Method in interface org.elasticsearch.util.inject.spi.HasDependencies
Returns the known dependencies for this type.
getDependencies() - Method in class org.elasticsearch.util.inject.spi.InjectionPoint
Returns the dependencies for this injection point.
getDependency() - Method in class org.elasticsearch.util.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.
getDirectory() - Method in class org.elasticsearch.util.lucene.IndexCommitDelegate
 
getDocFreq() - Method in class org.elasticsearch.action.terms.TermFreq
The document frequency of the term (in how many documents this term exists).
getDocIdSet(IndexReader) - Method in class org.elasticsearch.util.lucene.search.TermFilter
 
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
 
getElement() - Method in interface org.elasticsearch.util.collect.Multiset.Entry
Returns the multiset element corresponding to this entry.
getElements() - Method in class org.elasticsearch.util.inject.internal.PrivateElementsImpl
 
getElements(Module...) - Static method in class org.elasticsearch.util.inject.spi.Elements
Records the elements executed by modules.
getElements(Stage, Module...) - Static method in class org.elasticsearch.util.inject.spi.Elements
Records the elements executed by modules.
getElements(Iterable<? extends Module>) - Static method in class org.elasticsearch.util.inject.spi.Elements
Records the elements executed by modules.
getElements(Stage, Iterable<? extends Module>) - Static method in class org.elasticsearch.util.inject.spi.Elements
Records the elements executed by modules.
getElements() - Method in interface org.elasticsearch.util.inject.spi.PrivateElements
Returns the configuration information in this private environment.
getElementsMutable() - Method in class org.elasticsearch.util.inject.internal.PrivateElementsImpl
 
getErrorMessages() - Method in exception org.elasticsearch.util.inject.ConfigurationException
Returns messages for the errors that caused this exception.
getErrorMessages() - Method in exception org.elasticsearch.util.inject.CreationException
Returns messages for the errors that caused this exception.
getErrorMessages() - Method in exception org.elasticsearch.util.inject.ProvisionException
Returns messages for the errors that caused this exception.
getErrors() - Method in exception org.elasticsearch.util.inject.internal.ErrorsException
 
getEstabResets() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getEstimatedFlushableMemorySize() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
 
getEstimatedFlushableMemorySize() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
getEstimatedFlushableMemorySize() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
getException() - Method in class org.elasticsearch.util.concurrent.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.util.inject.TypeLiteral
Returns the resolved generic exception types thrown by constructor.
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.
getExposedKeys() - Method in class org.elasticsearch.util.inject.internal.PrivateElementsImpl
 
getExposedKeys() - Method in interface org.elasticsearch.util.inject.spi.PrivateElements
Returns the unique exposed keys for these private elements.
getExposedSource(Key<?>) - Method in class org.elasticsearch.util.inject.internal.PrivateElementsImpl
 
getExposedSource(Key<?>) - Method in interface org.elasticsearch.util.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.util.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 class org.elasticsearch.search.facets.Facets
Returns the Facets keyed by map.
getFactory() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Returns the factory used for constructing new workers.
getFailedShards() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.IndexGatewaySnapshotResponse
The number of failed shards the gateway snapshot operation was performed 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.
getFd() - Method in class org.elasticsearch.monitor.process.ProcessStats
 
GetField - Class in org.elasticsearch.action.get
 
GetField(String, List<Object>) - Constructor for class org.elasticsearch.action.get.GetField
 
getFieldName() - Method in class org.elasticsearch.action.terms.FieldTermsFreq
The field name.
getFieldQuery(String, String) - Method in class org.elasticsearch.index.query.support.MapperQueryParser
 
getFieldQuery(String, String) - Method in class org.elasticsearch.index.query.support.MultiFieldMapperQueryParser
 
getFieldQuery(String, String, int) - Method in class org.elasticsearch.index.query.support.MultiFieldMapperQueryParser
 
getFields() - Method in class org.elasticsearch.action.get.GetResponse
 
getFields() - Method in class org.elasticsearch.action.terms.TermsResponse
 
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.
getFieldType(Field) - Method in class org.elasticsearch.util.inject.TypeLiteral
Returns the resolved generic type of field.
getFilename(String) - Static method in class org.elasticsearch.util.Strings
Extract the filename from the given path, e.g.
getFilenameExtension(String) - Static method in class org.elasticsearch.util.Strings
Extract the filename extension from the given path, e.g.
getFileNames() - Method in class org.elasticsearch.util.lucene.IndexCommitDelegate
 
getFilePointer() - Method in class org.elasticsearch.index.store.memory.ByteBufferIndexInput
 
getFilePointer() - Method in class org.elasticsearch.index.store.memory.ByteBufferIndexOutput
 
getFilePointer() - Method in class org.elasticsearch.index.store.memory.HeapIndexInput
 
getFilePointer() - Method in class org.elasticsearch.index.store.memory.HeapIndexOutput
 
getFiles() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotIndexCommit
 
getFirst() - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Returns the head of the list
getFirstNonLoopbackAddress(NetworkUtils.StackType) - Static method in class org.elasticsearch.util.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.util.network.NetworkUtils
Returns the first non-loopback address on the given interface on the current host.
getFollow() - Method in class org.elasticsearch.util.logging.log4j.ConsoleAppender
Gets whether the appender honors reassignments of System.out or System.err made after configuration.
getFragments() - Method in class org.elasticsearch.search.highlight.HighlightField
The highlighted fragments.
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
 
getFullObjectName() - Method in class org.elasticsearch.jmx.ResourceDMBean
 
getFuzzyQuery(String, String, float) - Method in class org.elasticsearch.index.query.support.MapperQueryParser
 
getFuzzyQuery(String, String, float) - Method in class org.elasticsearch.index.query.support.MultiFieldMapperQueryParser
 
getGb() - Method in class org.elasticsearch.util.SizeValue
 
getGbFrac() - Method in class org.elasticsearch.util.SizeValue
 
getGc() - Method in class org.elasticsearch.monitor.jvm.JvmStats
 
getGeneration() - Method in class org.elasticsearch.util.lucene.IndexCommitDelegate
 
getGenericComponentType() - Method in class org.elasticsearch.util.inject.internal.MoreTypes.GenericArrayTypeImpl
 
getGenericSupertype(Type, Class<?>, Class<?>) - Static method in class org.elasticsearch.util.inject.internal.MoreTypes
Returns the generic supertype for supertype.
getGlobalSettings() - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getGlobalSettings() - Method in interface org.elasticsearch.util.settings.Settings
The global settings if these settings are group settings.
getGroupName() - Method in class org.elasticsearch.jmx.ResourceDMBean
 
getGroups(String) - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
getGroups(String) - Method in interface org.elasticsearch.util.settings.Settings
Returns group settings for the given setting prefix.
getHeapCommitted() - Method in class org.elasticsearch.monitor.jvm.JvmStats.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).
getHours() - Method in class org.elasticsearch.util.TimeValue
 
getHoursFrac() - Method in class org.elasticsearch.util.TimeValue
 
getId() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
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.index.IndexResponse
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
 
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.gateway.snapshot.IndexGatewaySnapshotResponse
The index the gateway snapshot has performed on.
getIndex() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
getIndex() - Method in class org.elasticsearch.action.delete.DeleteResponse
The index the document was deleted from.
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.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.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
 
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
 
getIndices() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
getIndices() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.GatewaySnapshotResponse
A map of index level responses of the gateway snapshot operation.
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.util.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.util.lucene.LoggerInfoStream
Creates a new LoggerInfoStream based on the provided name by appending to it the LoggerInfoStream.SUFFIX.
getInheritableThreadLocalsField() - Static method in class org.elasticsearch.util.base.internal.Finalizer
 
getInjectableMembers() - Method in interface org.elasticsearch.util.inject.spi.ConstructorBinding
Returns all instance method and field injection points on type.
getInjectionPoint() - Method in class org.elasticsearch.util.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.util.inject.internal.InstanceBindingImpl
 
getInjectionPoints() - Method in class org.elasticsearch.util.inject.internal.ProviderInstanceBindingImpl
 
getInjectionPoints() - Method in class org.elasticsearch.util.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.util.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.util.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.util.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.util.inject.internal.BindingImpl
 
getInjector() - Method in class org.elasticsearch.util.inject.internal.PrivateElementsImpl
 
getInjector() - Method in interface org.elasticsearch.util.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(Class<T>) - Method in interface org.elasticsearch.util.collect.ClassToInstanceMap
Returns the value the specified class is mapped to, or null if no entry for this class is present.
getInstance(Class<T>) - Method in class org.elasticsearch.util.collect.ImmutableClassToInstanceMap
 
getInstance(Class<T>) - Method in class org.elasticsearch.util.collect.MutableClassToInstanceMap
 
getInstance(Injector, Class<T>, String) - Static method in class org.elasticsearch.util.guice.Injectors
Returns an instance of the given type with the Named annotation value.
getInstance(Key<T>) - Method in interface org.elasticsearch.util.inject.Injector
Returns the appropriate instance for the given injection key; equivalent to getProvider(key).get().
getInstance(Class<T>) - Method in interface org.elasticsearch.util.inject.Injector
Returns the appropriate instance for the given injection type; equivalent to getProvider(type).get().
getInstance() - Method in class org.elasticsearch.util.inject.internal.InstanceBindingImpl
 
getInstance() - Method in class org.elasticsearch.util.inject.internal.ProviderMethod
 
getInstance() - Method in class org.elasticsearch.util.inject.spi.InjectionRequest
 
getInstance() - Method in interface org.elasticsearch.util.inject.spi.InstanceBinding
Returns the user-supplied instance.
getInstancesOf(Injector, Class<T>) - Static method in class org.elasticsearch.util.guice.Injectors
Returns a collection of all instances of the given base type
getInstancesOf(Injector, Matcher<Class>) - Static method in class org.elasticsearch.util.guice.Injectors
Returns a collection of all instances matching the given matcher
getInternalFactory() - Method in class org.elasticsearch.util.inject.internal.BindingImpl
 
getIpStackType() - Static method in class org.elasticsearch.util.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.util.network.NetworkUtils
 
getIPv6Localhost() - Static method in class org.elasticsearch.util.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.util.SizeValue
 
getKbFrac() - Method in class org.elasticsearch.util.SizeValue
 
getKeepAlive() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPoolManagement
 
getKeepAlive() - Method in class org.elasticsearch.threadpool.cached.CachedThreadPoolManagement
 
getKeepAlive() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPoolManagement
 
getKeepAliveInSeconds() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPoolManagement
 
getKeepAliveInSeconds() - Method in class org.elasticsearch.threadpool.cached.CachedThreadPoolManagement
 
getKeepAliveInSeconds() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPoolManagement
 
getKey() - Method in class org.elasticsearch.util.collect.ForwardingMapEntry
 
getKey() - Method in interface org.elasticsearch.util.inject.Binding
Returns the key for this binding.
getKey(TypeLiteral<?>, Member, Annotation[], Errors) - Static method in class org.elasticsearch.util.inject.internal.Annotations
Gets a key for the given type, member and annotations.
getKey() - Method in class org.elasticsearch.util.inject.internal.BindingImpl
 
getKey() - Method in class org.elasticsearch.util.inject.internal.ExposureBuilder
 
getKey() - Method in class org.elasticsearch.util.inject.internal.ProviderMethod
 
getKey() - Method in class org.elasticsearch.util.inject.spi.Dependency
Returns the key to the binding that satisfies this dependency.
getKey() - Method in class org.elasticsearch.util.inject.spi.ProviderLookup
 
getKeyType(Key<?>) - Static method in class org.elasticsearch.util.guice.Injectors
Returns the key type of the given key
getLast(Iterable<T>) - Static method in class org.elasticsearch.util.collect.Iterables
Returns the last element of iterable.
getLast(Iterator<T>) - Static method in class org.elasticsearch.util.collect.Iterators
Advances iterator to the end, returning the last element.
getLast() - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Returns the tail of the list.
getLeastSignificantBits() - Method in class org.elasticsearch.util.UUID
Returns the least significant 64 bits of this UUID's 128 bit value.
getLikeText() - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
getLinkedKey() - Method in class org.elasticsearch.util.inject.internal.LinkedBindingImpl
 
getLinkedKey() - Method in interface org.elasticsearch.util.inject.spi.LinkedKeyBinding
Returns the linked key used to resolve injections.
getListener() - Method in class org.elasticsearch.util.inject.spi.TypeListenerBinding
Returns the registered listener.
getLoadAverage() - Method in class org.elasticsearch.monitor.os.OsStats
 
getLocalAddress() - Static method in class org.elasticsearch.util.network.NetworkUtils
 
getLocalhost(NetworkUtils.StackType) - Static method in class org.elasticsearch.util.network.NetworkUtils
 
getLocalNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
getLocalNodeId() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
getLogger(String, String) - Static method in class org.elasticsearch.util.logging.ESLoggerFactory
 
getLogger(String) - Static method in class org.elasticsearch.util.logging.ESLoggerFactory
 
getLogger(Class, Settings, ShardId, String...) - Static method in class org.elasticsearch.util.logging.Loggers
 
getLogger(Class, Settings, Index, String...) - Static method in class org.elasticsearch.util.logging.Loggers
 
getLogger(Class, Settings, String...) - Static method in class org.elasticsearch.util.logging.Loggers
 
getLogger(String, Settings, String...) - Static method in class org.elasticsearch.util.logging.Loggers
 
getLogger(ESLogger, String) - Static method in class org.elasticsearch.util.logging.Loggers
 
getLogger(String) - Static method in class org.elasticsearch.util.logging.Loggers
 
getLogger(Class) - Static method in class org.elasticsearch.util.logging.Loggers
 
getLogger(Class, String...) - Static method in class org.elasticsearch.util.logging.Loggers
 
getLogger(String, String...) - Static method in class org.elasticsearch.util.logging.Loggers
 
getLowerBounds() - Method in class org.elasticsearch.util.inject.internal.MoreTypes.WildcardTypeImpl
 
getMacAddress() - Method in class org.elasticsearch.monitor.network.NetworkInfo.Interface
 
getMaintainsParallelism() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Returns true if this pool dynamically maintains its target parallelism level.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMap() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Returns a reference to the map wrapped by this decorator.
getMappings() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
getMasterNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
getMasterNodeId() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
getMax() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPoolManagement
 
getMax() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPoolManagement
 
getMaxDoc() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus.Docs
 
getMaxDoc() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus.Docs
 
getMaxDoc() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus.Docs
 
getMaxDoc() - Method in class org.elasticsearch.action.terms.TermsResponse
The total maximum number of documents (including deletions).
getMaxDoc() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
getMaxDocFreq() - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
getMaximumPoolSize() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Returns the maximum number of threads allowed to exist in the pool.
getMaxMergeDocs() - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy.MergePolicyParams
 
getMaxNumberOfShardsPerNode() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
getMaxQueryTerms() - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
getMaxSmallSegments() - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy
 
getMaxSmallSegments() - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy.MergePolicyParams
 
getMaxThreads() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPool
 
getMaxThreads() - Method in class org.elasticsearch.threadpool.cached.CachedThreadPool
 
getMaxThreads() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPool
 
getMaxThreads() - Method in interface org.elasticsearch.threadpool.ThreadPool
The maximum number of threads in the thread pool.
getMaxThreads() - Method in class org.elasticsearch.threadpool.ThreadPoolInfo
The maximum number of threads in the thread pool.
getMaxWordLen() - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
getMb() - Method in class org.elasticsearch.util.SizeValue
 
getMBeanInfo() - Method in class org.elasticsearch.jmx.ResourceDMBean
 
getMbFrac() - Method in class org.elasticsearch.util.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.util.inject.spi.InjectionPoint
Returns the injected constructor, field, or method.
getMembersInjector(Class<T>) - Method in class org.elasticsearch.util.inject.AbstractModule
 
getMembersInjector(TypeLiteral<T>) - Method in class org.elasticsearch.util.inject.AbstractModule
 
getMembersInjector(TypeLiteral<T>) - Method in interface org.elasticsearch.util.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.util.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.util.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.util.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.util.inject.PrivateModule
 
getMembersInjector(TypeLiteral<T>) - Method in class org.elasticsearch.util.inject.PrivateModule
 
getMembersInjector() - Method in class org.elasticsearch.util.inject.spi.MembersInjectorLookup
Returns the looked up members injector.
getMembersInjector(TypeLiteral<T>) - Method in interface org.elasticsearch.util.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.util.inject.spi.TypeEncounter
Returns the members injector used to inject dependencies into methods and fields on instances of the given type T.
getMergeFactor() - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy.MergePolicyParams
 
getMessage() - Method in exception org.elasticsearch.action.ActionRequestValidationException
 
getMessage() - Method in exception org.elasticsearch.util.inject.ConfigurationException
 
getMessage() - Method in exception org.elasticsearch.util.inject.CreationException
 
getMessage() - Method in exception org.elasticsearch.util.inject.ProvisionException
 
getMessage() - Method in class org.elasticsearch.util.inject.spi.Message
Gets the error message text.
getMessages() - Method in class org.elasticsearch.util.inject.internal.Errors
 
getMessagesFromThrowable(Throwable) - Static method in class org.elasticsearch.util.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.util.inject.internal.ProviderMethod
 
getMhz() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
getMicros() - Method in class org.elasticsearch.util.TimeValue
 
getMicrosFrac() - Method in class org.elasticsearch.util.TimeValue
 
getMillis() - Method in class org.elasticsearch.util.TimeValue
 
getMillisFrac() - Method in class org.elasticsearch.util.TimeValue
 
getMin() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPoolManagement
 
getMin() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPoolManagement
 
getMinDocFreq() - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
getMinTermFrequency() - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
getMinThreads() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPool
 
getMinThreads() - Method in class org.elasticsearch.threadpool.cached.CachedThreadPool
 
getMinThreads() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPool
 
getMinThreads() - Method in interface org.elasticsearch.threadpool.ThreadPool
The minimum number of threads in the thread pool.
getMinThreads() - Method in class org.elasticsearch.threadpool.ThreadPoolInfo
The minimum number of threads in the thread pool.
getMinutes() - Method in class org.elasticsearch.util.TimeValue
 
getMinutesFrac() - Method in class org.elasticsearch.util.TimeValue
 
getMinWordLen() - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
getModel() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
getModifiers() - Method in class org.elasticsearch.util.inject.internal.MoreTypes.MemberImpl
 
getModule(Iterable<? extends Element>) - Static method in class org.elasticsearch.util.inject.spi.Elements
Returns the module composed of elements.
getMoreLikeFields() - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
getMostSignificantBits() - Method in class org.elasticsearch.util.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.apache.lucene.search.PublicBooleanFilter
 
getName() - Method in class org.elasticsearch.action.get.GetField
 
getName() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
The name of the node.
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.GarbageCollector
 
getName() - Method in class org.elasticsearch.monitor.network.NetworkInfo.Interface
 
getName() - Method in class org.elasticsearch.search.facets.CountFacet
 
getName() - Method in interface org.elasticsearch.search.facets.Facet
The "logical" name of the search facet.
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.util.inject.internal.MoreTypes.MemberImpl
 
getName() - Method in interface org.elasticsearch.util.logging.ESLogger
 
getName() - Method in class org.elasticsearch.util.logging.jdk.JdkESLogger
 
getName() - Method in class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
getName() - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
getNanos() - Method in class org.elasticsearch.util.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.
getNext() - Method in interface org.elasticsearch.util.gnu.trove.TLinkable
Returns the linked list node after this one.
getNext() - Method in class org.elasticsearch.util.gnu.trove.TLinkableAdapter
Returns the linked list node after this one.
getNext(T) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Return the node following the given node.
getNode() - Method in class org.elasticsearch.action.support.nodes.NodeOperationResponse
The node this information relates to.
getNodeId() - Method in class org.elasticsearch.search.SearchShardTarget
 
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
 
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
 
getNonHeapUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
 
getNotFilters() - Method in class org.apache.lucene.search.PublicBooleanFilter
 
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
 
getNumDeletedDocs() - Method in class org.elasticsearch.action.terms.TermsResponse
The number of deleted docs.
getNumDocs() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus.Docs
 
getNumDocs() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus.Docs
 
getNumDocs() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus.Docs
 
getNumDocs() - Method in class org.elasticsearch.action.terms.TermsResponse
The total number of documents.
getNumDocs() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
getNumLargeSegments() - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy
 
getNumLargeSegments() - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy.MergePolicyParams
 
getObjectName() - Method in class org.elasticsearch.jmx.ResourceDMBean
 
getOffsetGap(Fieldable) - Method in class org.elasticsearch.index.analysis.NamedAnalyzer
 
getOffsetGap(Fieldable) - Method in class org.elasticsearch.util.lucene.all.AllAnalyzer
 
getOnlyCause(Collection<Message>) - Static method in class org.elasticsearch.util.inject.internal.Errors
Returns the cause throwable if there is exactly one cause in messages.
getOnlyElement(Iterable<T>) - Static method in class org.elasticsearch.util.collect.Iterables
Returns the single element contained in iterable.
getOnlyElement(Iterable<T>, T) - Static method in class org.elasticsearch.util.collect.Iterables
Returns the single element contained in iterable, or defaultValue if the iterable is empty.
getOnlyElement(Iterator<T>) - Static method in class org.elasticsearch.util.collect.Iterators
Returns the single element contained in iterator.
getOnlyElement(Iterator<T>, T) - Static method in class org.elasticsearch.util.collect.Iterators
Returns the single element contained in iterator, or defaultValue if the iterator is empty.
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.
getOutRsts() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getOutSegs() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getOwnerType() - Method in class org.elasticsearch.util.inject.internal.MoreTypes.ParameterizedTypeImpl
 
getPackageName(Class) - Static method in class org.elasticsearch.util.Classes
Determine the name of the package of the given class: e.g.
getPackageNameNoDomain(Class) - Static method in class org.elasticsearch.util.Classes
 
getParallelism() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Returns the targeted parallelism level of this pool.
getParameterIndex() - Method in class org.elasticsearch.util.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.util.inject.TypeLiteral
Returns the resolved generic parameter types of methodOrConstructor.
getParent() - Method in class org.elasticsearch.util.concurrent.jsr166y.Phaser
Returns the parent of this phaser, or null if none.
getParent() - Method in interface org.elasticsearch.util.inject.Injector
Returns this injector's parent, or null if this is a top-level injector.
getPartialExpunge() - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy
 
getPartialExpunge() - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy.MergePolicyParams
 
getPartialValue() - Method in exception org.elasticsearch.util.inject.ConfigurationException
Returns a value that was only partially computed due to this exception.
getPassiveOpens() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getPayloadScore() - Method in class org.elasticsearch.util.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
The score for the payload
getPeakCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Threads
 
getPercent() - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
Get the Process cpu usage.
getPercentTermsToMatch() - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
getPhase() - Method in class org.elasticsearch.util.concurrent.jsr166y.Phaser
Returns the current phase number.
getPid() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
The process id.
getPool() - Static method in class org.elasticsearch.util.concurrent.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 org.elasticsearch.util.concurrent.jsr166y.ForkJoinWorkerThread
Returns the pool hosting this thread.
getPoolIndex() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinWorkerThread
Returns the index number of this thread in its pool.
getPoolSize() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPool
 
getPoolSize() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPoolManagement
 
getPoolSize() - Method in class org.elasticsearch.threadpool.cached.CachedThreadPool
 
getPoolSize() - Method in class org.elasticsearch.threadpool.cached.CachedThreadPoolManagement
 
getPoolSize() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPool
 
getPoolSize() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPoolManagement
 
getPoolSize() - Method in interface org.elasticsearch.threadpool.ThreadPool
Returns the current number of threads in the pool.
getPoolSize() - Method in class org.elasticsearch.threadpool.ThreadPoolStats
Returns the current number of threads in the pool.
getPoolSize() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Returns the number of worker threads that have started but not yet terminated.
getPoolSize() - Method in class org.elasticsearch.util.concurrent.ScalingThreadPoolExecutor
Returns the current number of threads in the pool.
getPort() - Method in class org.elasticsearch.transport.netty.NettyTransportManagement
 
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.util.lucene.all.AllAnalyzer
 
getPrefix() - Method in interface org.elasticsearch.util.logging.ESLogger
 
getPrefix() - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
getPrefixQuery(String, String) - Method in class org.elasticsearch.index.query.support.MapperQueryParser
 
getPrefixQuery(String, String) - Method in class org.elasticsearch.index.query.support.MultiFieldMapperQueryParser
 
getPrevious() - Method in interface org.elasticsearch.util.gnu.trove.TLinkable
Returns the linked list node before this one.
getPrevious() - Method in class org.elasticsearch.util.gnu.trove.TLinkableAdapter
Returns the linked list node before this one.
getPrevious(T) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Return the node preceding the given node.
getPrimaryInterface() - Method in class org.elasticsearch.monitor.network.NetworkInfo
 
getPrivateElements() - Method in class org.elasticsearch.util.inject.internal.ExposedBindingImpl
 
getPrivateElements() - Method in interface org.elasticsearch.util.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.util.inject.spi.ProviderBinding
Returns the key whose binding is used to provide instances.
getProvider(Key<T>) - Method in class org.elasticsearch.util.inject.AbstractModule
 
getProvider(Class<T>) - Method in class org.elasticsearch.util.inject.AbstractModule
 
getProvider(Key<T>) - Method in interface org.elasticsearch.util.inject.Binder
Returns the provider used to obtain instances for the given injection key.
getProvider(Class<T>) - Method in interface org.elasticsearch.util.inject.Binder
Returns the provider used to obtain instances for the given injection type.
getProvider() - Method in interface org.elasticsearch.util.inject.Binding
Returns the scoped provider guice uses to fulfill requests for this binding.
getProvider(Key<T>) - Method in interface org.elasticsearch.util.inject.Injector
Returns the provider used to obtain instances for the given injection key.
getProvider(Class<T>) - Method in interface org.elasticsearch.util.inject.Injector
Returns the provider used to obtain instances for the given type.
getProvider() - Method in class org.elasticsearch.util.inject.internal.BindingImpl
 
getProvider() - Method in class org.elasticsearch.util.inject.internal.InstanceBindingImpl
 
getProvider(Key<T>) - Method in class org.elasticsearch.util.inject.PrivateModule
 
getProvider(Class<T>) - Method in class org.elasticsearch.util.inject.PrivateModule
 
getProvider() - Method in class org.elasticsearch.util.inject.spi.ProviderLookup
Returns the looked up provider.
getProvider(Key<T>) - Method in interface org.elasticsearch.util.inject.spi.TypeEncounter
Returns the provider used to obtain instances for the given injection key.
getProvider(Class<T>) - Method in interface org.elasticsearch.util.inject.spi.TypeEncounter
Returns the provider used to obtain instances for the given injection type.
getProviderInstance() - Method in class org.elasticsearch.util.inject.internal.ProviderInstanceBindingImpl
 
getProviderInstance() - Method in interface org.elasticsearch.util.inject.spi.ProviderInstanceBinding
Returns the user-supplied, unscoped provider.
getProviderKey() - Method in class org.elasticsearch.util.inject.internal.LinkedProviderBindingImpl
 
getProviderKey() - Method in interface org.elasticsearch.util.inject.spi.ProviderKeyBinding
Returns the key used to resolve the provider's binding.
getProviderMethods(Binder) - Method in class org.elasticsearch.util.inject.internal.ProviderMethodsModule
 
getProvidersOf(Injector, Matcher<Class>) - Static method in class org.elasticsearch.util.guice.Injectors
Returns a collection of all of the providers matching the given matcher
getProvidersOf(Injector, Class<T>) - Static method in class org.elasticsearch.util.guice.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
 
getQueuedSubmissionCount() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Returns an estimate of the number of tasks submitted to this pool that have not yet begun executing.
getQueuedTaskCount() - Method in class org.elasticsearch.util.concurrent.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 org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Returns an estimate of the number of tasks that have been forked by the current worker thread but not yet executed.
getQuick(int) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Returns the value at the specified offset without doing any bounds checking.
getQuick(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Returns the value at the specified offset without doing any bounds checking.
getQuick(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Returns the value at the specified offset without doing any bounds checking.
getQuick(int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Returns the value at the specified offset without doing any bounds checking.
getQuick(int) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Returns the value at the specified offset without doing any bounds checking.
getQuick(int) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Returns the value at the specified offset without doing any bounds checking.
getRangeQuery(String, String, String, boolean) - Method in class org.elasticsearch.index.query.support.MapperQueryParser
 
getRangeQuery(String, String, String, boolean) - Method in class org.elasticsearch.index.query.support.MultiFieldMapperQueryParser
 
getRawResult() - Method in class org.elasticsearch.util.concurrent.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 org.elasticsearch.util.concurrent.jsr166y.RecursiveAction
Always returns null.
getRawResult() - Method in class org.elasticsearch.util.concurrent.jsr166y.RecursiveTask
 
getRawType(Type) - Static method in class org.elasticsearch.util.inject.internal.MoreTypes
 
getRawType() - Method in class org.elasticsearch.util.inject.internal.MoreTypes.ParameterizedTypeImpl
 
getRawType() - Method in class org.elasticsearch.util.inject.TypeLiteral
Returns the raw (non-generic) type for this type.
getRegisteredParties() - Method in class org.elasticsearch.util.concurrent.jsr166y.Phaser
Returns the number of parties registered at this barrier.
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 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.
getResident() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
GetResponse - Class in org.elasticsearch.action.get
The response of a get action.
getRetransSegs() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
getReturnType(Method) - Method in class org.elasticsearch.util.inject.TypeLiteral
Returns the resolved generic return type of method.
getReuseAddress() - Method in class org.elasticsearch.transport.netty.NettyTransportManagement
 
getRoot() - Method in class org.elasticsearch.util.concurrent.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 any.
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 org.elasticsearch.util.concurrent.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
 
getSchedulerActiveCount() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPool
 
getSchedulerActiveCount() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPoolManagement
 
getSchedulerActiveCount() - Method in class org.elasticsearch.threadpool.cached.CachedThreadPool
 
getSchedulerActiveCount() - Method in class org.elasticsearch.threadpool.cached.CachedThreadPoolManagement
 
getSchedulerActiveCount() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPool
 
getSchedulerActiveCount() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPoolManagement
 
getSchedulerActiveCount() - Method in interface org.elasticsearch.threadpool.ThreadPool
The approximate number of threads that are actively executing scheduled tasks.
getSchedulerActiveCount() - Method in class org.elasticsearch.threadpool.ThreadPoolStats
The approximate number of threads that are actively executing scheduled tasks.
getSchedulerPoolSize() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPool
 
getSchedulerPoolSize() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPoolManagement
 
getSchedulerPoolSize() - Method in class org.elasticsearch.threadpool.cached.CachedThreadPool
 
getSchedulerPoolSize() - Method in class org.elasticsearch.threadpool.cached.CachedThreadPoolManagement
 
getSchedulerPoolSize() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPool
 
getSchedulerPoolSize() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPoolManagement
 
getSchedulerPoolSize() - Method in interface org.elasticsearch.threadpool.ThreadPool
The size of the scheduler thread pool.
getSchedulerPoolSize() - Method in class org.elasticsearch.threadpool.ThreadPoolStats
The size of the scheduler thread pool.
getSchedulerThreads() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPool
 
getSchedulerThreads() - Method in class org.elasticsearch.threadpool.cached.CachedThreadPool
 
getSchedulerThreads() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPool
 
getSchedulerThreads() - Method in interface org.elasticsearch.threadpool.ThreadPool
The size of scheduler threads.
getSchedulerThreads() - Method in class org.elasticsearch.threadpool.ThreadPoolInfo
The size of scheduler threads.
getScheduleSize() - Method in class org.elasticsearch.threadpool.blocking.BlockingThreadPoolManagement
 
getScheduleSize() - Method in class org.elasticsearch.threadpool.cached.CachedThreadPoolManagement
 
getScheduleSize() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPoolManagement
 
getScope() - Method in class org.elasticsearch.util.inject.spi.ScopeBinding
 
getScopeAnnotation() - Method in class org.elasticsearch.util.inject.internal.Scoping
Returns the scope annotation, or null if that isn't known for this instance.
getScopeInstance() - Method in class org.elasticsearch.util.inject.internal.Scoping
Returns the scope instance, or null if that isn't known for this instance.
getScoping() - Method in class org.elasticsearch.util.inject.internal.BindingImpl
 
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.
getSeconds() - Method in class org.elasticsearch.util.TimeValue
 
getSecondsFrac() - Method in class org.elasticsearch.util.TimeValue
 
getSegmentsFileName() - Method in class org.elasticsearch.util.lucene.IndexCommitDelegate
 
getSet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteHashSetDecorator
Returns a reference to the set wrapped by this decorator.
getSet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleHashSetDecorator
Returns a reference to the set wrapped by this decorator.
getSet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatHashSetDecorator
Returns a reference to the set wrapped by this decorator.
getSet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntHashSetDecorator
Returns a reference to the set wrapped by this decorator.
getSet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongHashSetDecorator
Returns a reference to the set wrapped by this decorator.
getSet() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortHashSetDecorator
Returns a reference to the set wrapped by this decorator.
getSet(int, byte) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Sets the value at the specified offset and returns the previously stored value.
getSet(int, double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Sets the value at the specified offset and returns the previously stored value.
getSet(int, float) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Sets the value at the specified offset and returns the previously stored value.
getSet(int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Sets the value at the specified offset and returns the previously stored value.
getSet(int, long) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Sets the value at the specified offset and returns the previously stored value.
getSet(int, short) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Sets the value at the specified offset and returns the previously stored value.
getSettings() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
The settings of the node.
getSettings() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
getSettings() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
getSettings() - Method in class org.elasticsearch.node.NodeBuilder
Set addition settings simply by working directly against the settings builder.
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.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.status.ShardStatus
 
getShards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
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) - Method in interface org.elasticsearch.index.routing.OperationRouting
 
getShards(ClusterState, String, String) - Method in class org.elasticsearch.index.routing.plain.PlainOperationRouting
 
getShare() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
getShouldFilters() - Method in class org.apache.lucene.search.PublicBooleanFilter
 
getSimilarity() - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
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.store.StoreManagement
 
getSizeInBytes() - Method in class org.elasticsearch.index.store.StoreManagement
 
getSource() - Method in class org.elasticsearch.action.get.GetResponse
 
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).
getSource() - Method in class org.elasticsearch.util.inject.internal.BindingImpl
 
getSource() - Method in class org.elasticsearch.util.inject.internal.ExposureBuilder
 
getSource() - Method in class org.elasticsearch.util.inject.internal.MatcherAndConverter
 
getSource() - Method in class org.elasticsearch.util.inject.internal.PrivateElementsImpl
 
getSource() - Method in interface org.elasticsearch.util.inject.spi.Element
Returns an arbitrary object containing information about the "place" where this element was configured.
getSource() - Method in class org.elasticsearch.util.inject.spi.InjectionRequest
 
getSource() - Method in class org.elasticsearch.util.inject.spi.MembersInjectorLookup
 
getSource() - Method in class org.elasticsearch.util.inject.spi.Message
 
getSource() - Method in class org.elasticsearch.util.inject.spi.ProviderLookup
 
getSource() - Method in class org.elasticsearch.util.inject.spi.ScopeBinding
 
getSource() - Method in class org.elasticsearch.util.inject.spi.StaticInjectionRequest
 
getSource() - Method in class org.elasticsearch.util.inject.spi.TypeConverterBinding
 
getSource() - Method in class org.elasticsearch.util.inject.spi.TypeListenerBinding
 
getSourceKey() - Method in interface org.elasticsearch.util.inject.spi.ConvertedConstantBinding
Returns the key for the source binding.
getSources() - Method in class org.elasticsearch.util.inject.internal.Errors
 
getSources() - Method in class org.elasticsearch.util.inject.spi.Message
 
getSpanScore() - Method in class org.elasticsearch.util.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
Returns the SpanScorer score only.
getStartTime() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
getState() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
 
getState() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
getState() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
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.RestResponse.Status
 
getStealCount() - Method in class org.elasticsearch.util.concurrent.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.util.lucene.search.MoreLikeThisQuery
 
getStoreSize() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
 
getStoreSize() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
getStoreSize() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
getStoreSize() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
getSubQuery() - Method in class org.elasticsearch.util.lucene.search.CustomBoostFactorQuery
 
getSuccessfulShards() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.IndexGatewaySnapshotResponse
The number of successful shards the gateway snapshot operation was performed 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.
getSupertype(Class<?>) - Method in class org.elasticsearch.util.inject.TypeLiteral
Returns the generic form of supertype.
getSurplusQueuedTaskCount() - Static method in class org.elasticsearch.util.concurrent.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.util.logging.log4j.ConsoleAppender
Returns the current value of the Target property.
getTask() - Method in interface org.elasticsearch.util.timer.Timeout
Returns the TimerTask which is associated with this handle.
getTaskName() - Method in class org.elasticsearch.util.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
 
getTerm() - Method in class org.elasticsearch.action.terms.TermFreq
The term.
getTerm() - Method in class org.elasticsearch.util.lucene.search.TermFilter
 
getTerms() - Method in class org.apache.lucene.search.PublicTermsFilter
 
getTermsFreqs() - Method in class org.elasticsearch.action.terms.FieldTermsFreq
The term frequencies of the field.
getThreadInfo(long[]) - Method in class org.elasticsearch.monitor.dump.thread.ThreadDumpContributor
 
getThreadNameDeterminer() - Static method in class org.elasticsearch.util.ThreadRenamingRunnable
Returns the ThreadNameDeterminer which overrides the proposed new thread name.
getThreadPool() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
Thread Pool level information.
getThreadPool() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
Thread Pool level stats.
getThreads() - Method in class org.elasticsearch.monitor.jvm.JvmStats
 
getTime() - Method in class org.elasticsearch.util.StopWatch.TaskInfo
Return the time this task took.
getTimeInNanos() - Method in class org.elasticsearch.util.concurrent.ThreadBarrier.BarrierTimer
Returns the elapsed time between two successive barrier executions.
getTimeInSeconds() - Method in class org.elasticsearch.util.concurrent.ThreadBarrier.BarrierTimer
Returns the elapsed time between two successive barrier executions.
getTimer() - Method in interface org.elasticsearch.util.timer.Timeout
Returns the Timer that created this handle.
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
 
getTimestamp() - Method in class org.elasticsearch.util.lucene.IndexCommitDelegate
 
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 class org.elasticsearch.monitor.process.ProcessStats.Fd
 
getTotalCores() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
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
 
getTotalShards() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.IndexGatewaySnapshotResponse
The number of total shards the gateway snapshot operation was performed 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
 
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
 
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() - 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.index.IndexResponse
The type of the document indexed.
getType() - Method in class org.elasticsearch.search.facets.CountFacet
 
getType() - Method in interface org.elasticsearch.search.facets.Facet
The type of the facet.
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.blocking.BlockingThreadPool
 
getType() - Method in class org.elasticsearch.threadpool.cached.CachedThreadPool
 
getType() - Method in class org.elasticsearch.threadpool.scaling.ScalingThreadPool
 
getType() - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
getType() - Method in class org.elasticsearch.threadpool.ThreadPoolInfo
The type of the thread pool.
getType() - Method in class org.elasticsearch.util.inject.spi.InjectionRequest
 
getType() - Method in class org.elasticsearch.util.inject.spi.MembersInjectorLookup
Gets the type containing the members to be injected.
getType() - Method in class org.elasticsearch.util.inject.spi.StaticInjectionRequest
 
getType() - Method in class org.elasticsearch.util.inject.TypeLiteral
Gets underlying Type instance.
getTypeConverter() - Method in class org.elasticsearch.util.inject.internal.MatcherAndConverter
 
getTypeConverter() - Method in class org.elasticsearch.util.inject.spi.TypeConverterBinding
 
getTypeLiteral() - Method in class org.elasticsearch.util.inject.Key
Gets the key type.
getTypeMatcher() - Method in class org.elasticsearch.util.inject.internal.MatcherAndConverter
 
getTypeMatcher() - Method in class org.elasticsearch.util.inject.spi.TypeConverterBinding
 
getTypeMatcher() - Method in class org.elasticsearch.util.inject.spi.TypeListenerBinding
Returns the type matcher which chooses which types the listener should be notified of.
getUnarrivedParties() - Method in class org.elasticsearch.util.concurrent.jsr166y.Phaser
Returns the number of registered parties that have not yet arrived at the current phase of this barrier.
getUnassigned() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
getUncaughtExceptionHandler() - Method in class org.elasticsearch.util.concurrent.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.util.inject.internal.MoreTypes.WildcardTypeImpl
 
getUptime() - Method in class org.elasticsearch.monitor.jvm.JvmStats
 
getUptime() - Method in class org.elasticsearch.monitor.os.OsStats
 
getUseClean() - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectory
 
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.util.lucene.IndexCommitDelegate
 
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 class org.elasticsearch.util.collect.ForwardingMapEntry
 
getValue() - Method in interface org.elasticsearch.util.inject.spi.ConvertedConstantBinding
Returns the converted value.
getValues() - Method in class org.elasticsearch.action.get.GetField
 
getValues() - Method in class org.elasticsearch.search.internal.InternalSearchHitField
 
getValues() - Method in interface org.elasticsearch.search.SearchHitField
The field values.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Returns the values of the map.
getValues(T[]) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Return the values of the map; the runtime type of the returned array is that of the specified array.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Returns the values of the map.
getValues(T[]) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Return the values of the map; the runtime type of the returned array is that of the specified array.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Returns the values of the map.
getValues(T[]) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Return the values of the map; the runtime type of the returned array is that of the specified array.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Returns the values of the map.
getValues(T[]) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Return the values of the map; the runtime type of the returned array is that of the specified array.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Returns the values of the map.
getValues(T[]) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Return the values of the map; the runtime type of the returned array is that of the specified array.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Returns the values of the map.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Returns the values of the map.
getValues(T[]) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Return the values of the map; the runtime type of the returned array is that of the specified array.
getValues() - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Returns the values of the map.
getVendor() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
getVersion() - Method in class org.elasticsearch.cluster.ClusterState
 
getVersion() - Method in class org.elasticsearch.util.lucene.IndexCommitDelegate
 
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 org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
 
getWaitingConsumerCount() - Method in interface org.elasticsearch.util.concurrent.jsr166y.TransferQueue
Returns an estimate of the number of consumers waiting to receive elements via BlockingQueue.take() or timed poll.
getWildcardQuery(String, String) - Method in class org.elasticsearch.index.query.support.MapperQueryParser
 
getWildcardQuery(String, String) - Method in class org.elasticsearch.index.query.support.MultiFieldMapperQueryParser
 
getWorkerCount() - Method in class org.elasticsearch.transport.netty.NettyTransportManagement
 
global() - Method in class org.elasticsearch.search.facets.SearchContextFacets.Facet
 
global(boolean) - Method in class org.elasticsearch.search.facets.SearchContextFacets.Facet
 
globalFieldCaseConversion - Static variable in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
globalFieldCaseConversion(XContentBuilder.FieldCaseConversion) - Static method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
globalSettings(Settings) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Sets the global settings associated with the settings built.
GreekAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
GreekAnalyzerProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.GreekAnalyzerProvider
 
GREEN - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
grep(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Searches the list for values satisfying condition in the manner of the *nix grep utility.
grep(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Searches the list for values satisfying condition in the manner of the *nix grep utility.
grep(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Searches the list for values satisfying condition in the manner of the *nix grep utility.
grep(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Searches the list for values satisfying condition in the manner of the *nix grep utility.
grep(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Searches the list for values satisfying condition in the manner of the *nix grep utility.
grep(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Searches the list for values satisfying condition in the manner of the *nix grep utility.
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 (ShardsIterator is an iterator across shard replication group.
GroupShardsIterator - Class in org.elasticsearch.cluster.routing
 
GroupShardsIterator() - Constructor for class org.elasticsearch.cluster.routing.GroupShardsIterator
 
GroupShardsIterator(Set<ShardsIterator>) - Constructor for class org.elasticsearch.cluster.routing.GroupShardsIterator
 
gt(Object) - Method in class org.elasticsearch.action.terms.TermsRequest
Greater than (like setting from with fromIInclusive set to false).
gt(String) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The from part of the filter query.
gt(int) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The from part of the filter query.
gt(long) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The from part of the filter query.
gt(float) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The from part of the filter query.
gt(double) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The from part of the filter query.
gt(String) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
gt(Object) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
gt(int) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
gt(long) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
gt(float) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
gt(double) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
gte(Object) - Method in class org.elasticsearch.action.terms.TermsRequest
Greater/equal than (like setting from with fromInclusive set to true).
gte(String) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The from part of the filter query.
gte(int) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The from part of the filter query.
gte(long) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The from part of the filter query.
gte(float) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The from part of the filter query.
gte(double) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The from part of the filter query.
gte(String) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
gte(Object) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
gte(int) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
gte(long) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
gte(float) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
gte(double) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The from part of the range query.
GuardedBy - Annotation Type in org.elasticsearch.util.concurrent
GuardedBy

The field or method to which this annotation is applied can only be accessed when holding a particular lock, which may be a built-in (synchronization) lock, or may be an explicit java.util.concurrent.Lock.

Guice - Class in org.elasticsearch.util.inject
The entry point to the Guice framework.
GwtCompatible - Annotation Type in org.elasticsearch.util.annotations
The presence of this annotation on a type indicates that the type may be used with the Google Web Toolkit (GWT).
GwtIncompatible - Annotation Type in org.elasticsearch.util.annotations
The presence of this annotation on a method indicates that the method may not be used with the Google Web Toolkit (GWT), even though its type is annotated as GwtCompatible and accessible in GWT.
GZIP - Static variable in class org.elasticsearch.util.Base64
Specify that data should be gzip-compressed in second bit.
GZIPCompressor - Class in org.elasticsearch.util.io.compression
 
GZIPCompressor() - Constructor for class org.elasticsearch.util.io.compression.GZIPCompressor
 

H

handle(Object, Errors) - Method in interface org.elasticsearch.util.inject.internal.ErrorHandler
Handles an error.
handle(Message) - Method in interface org.elasticsearch.util.inject.internal.ErrorHandler
Handles a user-reported error.
handleException(RemoteTransportException) - Method in class org.elasticsearch.transport.FutureTransportResponseHandler
 
handleException(RemoteTransportException) - Method in class org.elasticsearch.transport.PlainTransportFuture
 
handleException(RemoteTransportException) - Method in interface org.elasticsearch.transport.TransportResponseHandler
 
handleException(RemoteTransportException) - Method in class org.elasticsearch.transport.VoidTransportResponseHandler
 
handler(String) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
 
handleRequest(HttpRequest, HttpChannel) - Method in interface org.elasticsearch.http.HttpServerHandler
 
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.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.ping.broadcast.RestBroadcastPingAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.cluster.ping.replication.RestReplicationPingAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.admin.cluster.ping.single.RestSinglePingAction
 
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.RestIndicesAliasesAction
 
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.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.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.put.RestPutMappingAction
 
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.status.RestIndicesStatusAction
 
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.get.RestGetAction
 
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.search.RestSearchAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.search.RestSearchScrollAction
 
handleRequest(RestRequest, RestChannel) - Method in class org.elasticsearch.rest.action.terms.RestTermsAction
 
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
 
HandlesStreamInput - Class in org.elasticsearch.util.io.stream
 
HandlesStreamInput(StreamInput) - Constructor for class org.elasticsearch.util.io.stream.HandlesStreamInput
 
HandlesStreamInput.Cached - Class in org.elasticsearch.util.io.stream
 
HandlesStreamInput.Cached() - Constructor for class org.elasticsearch.util.io.stream.HandlesStreamInput.Cached
 
HandlesStreamOutput - Class in org.elasticsearch.util.io.stream
 
HandlesStreamOutput(StreamOutput) - Constructor for class org.elasticsearch.util.io.stream.HandlesStreamOutput
 
HandlesStreamOutput(StreamOutput, int) - Constructor for class org.elasticsearch.util.io.stream.HandlesStreamOutput
 
handleUpstream(ChannelHandlerContext, ChannelEvent) - Method in class org.elasticsearch.http.netty.OpenChannelsHandler
 
handleUpstream(ChannelHandlerContext, ChannelEvent) - Method in class org.elasticsearch.transport.netty.OpenChannelsHandler
 
hasBinding(Injector, Matcher<Class>) - Static method in class org.elasticsearch.util.guice.Injectors
Returns true if a binding exists for the given matcher
hasBinding(Injector, Class<?>) - Static method in class org.elasticsearch.util.guice.Injectors
Returns true if a binding exists for the given base class
hasBinding(Injector, Key<?>) - Static method in class org.elasticsearch.util.guice.Injectors
Returns true if a binding exists for the given key
hasChanges() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
 
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.xcontent.MergeContext
 
hasContent() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
hasContent() - Method in interface org.elasticsearch.rest.RestRequest
 
HasDependencies - Interface in org.elasticsearch.util.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.
hasErrors() - Method in class org.elasticsearch.util.inject.internal.Errors
 
hash(String, String) - Method in class org.elasticsearch.index.routing.hash.djb.DjbHashFunction
 
hash(String, String) - Method in interface org.elasticsearch.index.routing.hash.HashFunction
 
hash(String, String) - Method in class org.elasticsearch.index.routing.hash.simple.SimpleHashFunction
 
hash(String, String) - Method in class org.elasticsearch.index.routing.plain.PlainOperationRouting
 
hash(double) - Static method in class org.elasticsearch.util.gnu.trove.HashFunctions
Returns a hashcode for the specified value.
hash(float) - Static method in class org.elasticsearch.util.gnu.trove.HashFunctions
Returns a hashcode for the specified value.
hash(int) - Static method in class org.elasticsearch.util.gnu.trove.HashFunctions
Returns a hashcode for the specified value.
hash(long) - Static method in class org.elasticsearch.util.gnu.trove.HashFunctions
Returns a hashcode for the specified value.
hash(Object) - Static method in class org.elasticsearch.util.gnu.trove.HashFunctions
Returns a hashcode for the specified object.
HashBiMap<K,V> - Class in org.elasticsearch.util.collect
A BiMap backed by two HashMap instances.
hashCode() - Method in class org.elasticsearch.cluster.ClusterName
 
hashCode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
 
hashCode() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
hashCode() - Method in class org.elasticsearch.index.Index
 
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.search.SearchShardTarget
 
hashCode(Object...) - Static method in class org.elasticsearch.util.base.Objects
Generates a hash code for multiple values.
hashCode() - Method in class org.elasticsearch.util.collect.ForwardingList
 
hashCode() - Method in class org.elasticsearch.util.collect.ForwardingMap
 
hashCode() - Method in class org.elasticsearch.util.collect.ForwardingMapEntry
 
hashCode() - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
hashCode() - Method in class org.elasticsearch.util.collect.ForwardingMultiset
 
hashCode() - Method in class org.elasticsearch.util.collect.ForwardingSet
 
hashCode() - Method in class org.elasticsearch.util.collect.ImmutableBiMap
 
hashCode() - Method in class org.elasticsearch.util.collect.ImmutableMap
 
hashCode() - Method in class org.elasticsearch.util.collect.ImmutableMultimap
 
hashCode() - Method in class org.elasticsearch.util.collect.ImmutableMultiset
 
hashCode() - Method in class org.elasticsearch.util.collect.ImmutableSet
 
hashCode() - Method in class org.elasticsearch.util.collect.LinkedListMultimap
Returns the hash code for this multimap.
hashCode() - Method in interface org.elasticsearch.util.collect.MapDifference
Returns the hash code for this instance.
hashCode() - Method in interface org.elasticsearch.util.collect.MapDifference.ValueDifference
The hash code equals the value Arrays.asList(leftValue(), rightValue()).hashCode().
hashCode() - Method in interface org.elasticsearch.util.collect.Multimap
Returns the hash code for this multimap.
hashCode() - Method in interface org.elasticsearch.util.collect.Multiset.Entry
hashCode() - Method in interface org.elasticsearch.util.collect.Multiset
Returns the hash code for this multiset.
hashCode() - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TByteHashSet
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TDoubleHashSet
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TFloatHashSet
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.THashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.THashSet
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TIntHashSet
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TLongHashSet
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TShortHashSet
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
 
hashCode() - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
 
hashCode() - Method in class org.elasticsearch.util.inject.internal.MoreTypes.GenericArrayTypeImpl
 
hashCode(Type) - Static method in class org.elasticsearch.util.inject.internal.MoreTypes
Returns the hashCode of type.
hashCode() - Method in class org.elasticsearch.util.inject.internal.MoreTypes.ParameterizedTypeImpl
 
hashCode() - Method in class org.elasticsearch.util.inject.internal.MoreTypes.WildcardTypeImpl
 
hashCode() - Method in class org.elasticsearch.util.inject.internal.ProviderMethodsModule
 
hashCode() - Method in class org.elasticsearch.util.inject.Key
 
hashCode() - Method in class org.elasticsearch.util.inject.spi.Dependency
 
hashCode() - Method in class org.elasticsearch.util.inject.spi.InjectionPoint
 
hashCode() - Method in class org.elasticsearch.util.inject.spi.Message
 
hashCode() - Method in class org.elasticsearch.util.inject.TypeLiteral
 
hashCode() - Method in class org.elasticsearch.util.lucene.all.AllTermQuery
 
hashCode() - Method in class org.elasticsearch.util.lucene.IndexCommitDelegate
 
hashCode() - Method in class org.elasticsearch.util.lucene.search.CustomBoostFactorQuery
 
hashCode() - Method in class org.elasticsearch.util.lucene.search.TermFilter
 
hashCode() - Method in class org.elasticsearch.util.settings.ImmutableSettings
 
hashCode() - Method in class org.elasticsearch.util.SizeValue
 
hashCode() - Method in class org.elasticsearch.util.TimeValue
 
hashCode() - Method in class org.elasticsearch.util.transport.InetSocketTransportAddress
 
hashCode() - Method in class org.elasticsearch.util.transport.LocalTransportAddress
 
hashCode() - Method in class org.elasticsearch.util.UUID
Returns a hash code for this UUID.
HashedWheelTimer - Class in org.elasticsearch.util.timer
A Timer optimized for approximated I/O timeout scheduling.
HashedWheelTimer(ESLogger, ThreadFactory, long, TimeUnit) - Constructor for class org.elasticsearch.util.timer.HashedWheelTimer
Creates a new timer with the default number of ticks per wheel.
HashedWheelTimer(ESLogger, ThreadFactory, long, TimeUnit, int) - Constructor for class org.elasticsearch.util.timer.HashedWheelTimer
Creates a new timer.
HashFunction - Interface in org.elasticsearch.index.routing.hash
 
HashFunctions - Class in org.elasticsearch.util.gnu.trove
Provides various hash functions.
HashFunctions() - Constructor for class org.elasticsearch.util.gnu.trove.HashFunctions
 
HashMultimap<K,V> - Class in org.elasticsearch.util.collect
Implementation of Multimap using hash tables.
HashMultiset<E> - Class in org.elasticsearch.util.collect
Multiset implementation backed by a HashMap.
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.xcontent.XContentDocumentMapper.Builder
 
hasLength(CharSequence) - Static method in class org.elasticsearch.util.Strings
Check that the given CharSequence is neither null nor of length 0.
hasLength(String) - Static method in class org.elasticsearch.util.Strings
Check that the given String is neither null nor of length 0.
hasMapper() - Method in class org.elasticsearch.index.mapper.MapperService.SmartNameFieldMappers
Has at least one mapper for the field.
hasMapping(String) - Method in class org.elasticsearch.index.mapper.MapperService
 
hasMoreElements() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong.IteratorLong
True if there are more keys to iterate over.
hasNext() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
 
hasNext() - Method in class org.elasticsearch.util.collect.AbstractIterator
 
hasNext() - Method in class org.elasticsearch.util.collect.ForwardingIterator
 
hasNext() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong.IteratorLong
True if there are more keys to iterate over.
hasNext() - Method in class org.elasticsearch.util.gnu.trove.TLinkedList.IteratorImpl
True if a call to next() will return an object.
hasNextActive() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
 
hasNextActive() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
 
hasParam(String) - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
hasParam(String) - Method in interface org.elasticsearch.rest.RestRequest
 
hasPrevious() - Method in class org.elasticsearch.util.collect.ForwardingListIterator
 
hasPrevious() - Method in class org.elasticsearch.util.gnu.trove.TLinkedList.IteratorImpl
True if a call to previous() will return a value.
hasQueuedSubmissions() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Returns true if there are any tasks submitted to this pool that have not yet begun executing.
hasSearchAnalyzer() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper.Builder
 
hasShard(int) - Method in interface org.elasticsearch.index.service.IndexService
 
hasShard(int) - Method in class org.elasticsearch.index.service.InternalIndexService
 
hasText(CharSequence) - Static method in class org.elasticsearch.util.Strings
Check whether the given CharSequence has actual text.
hasText(String) - Static method in class org.elasticsearch.util.Strings
Check whether the given String has actual text.
hasUnassigned() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
hasWaitingConsumer() - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
 
hasWaitingConsumer() - Method in interface org.elasticsearch.util.concurrent.jsr166y.TransferQueue
Returns true if there is at least one consumer waiting to receive an element via BlockingQueue.take() or timed poll.
header(String) - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
header(String) - Method in interface org.elasticsearch.rest.RestRequest
 
HEADER - Static variable in enum org.elasticsearch.util.xcontent.xson.XsonType
 
headerNames() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
headerNames() - Method in interface org.elasticsearch.rest.RestRequest
 
headers(String) - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
headers(String) - Method in interface org.elasticsearch.rest.RestRequest
 
headMap(K) - Method in class org.elasticsearch.util.collect.ForwardingSortedMap
 
headMap(K) - Method in class org.elasticsearch.util.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys are less than toKey.
headSet(E) - Method in class org.elasticsearch.util.collect.ForwardingSortedSet
 
headSet(E) - Method in class org.elasticsearch.util.collect.ImmutableSortedSet
HEALTH - Static variable in class org.elasticsearch.action.TransportActions.Admin.Cluster
 
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.node.NodeClusterAdminClient
 
health(ClusterHealthRequest, ActionListener<ClusterHealthResponse>) - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
health(ClusterHealthRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
health(ClusterHealthRequest, ActionListener<ClusterHealthResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
HEAP_DUMP - Static variable in class org.elasticsearch.monitor.dump.heap.HeapDumpContributor
 
heapCommitted() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
 
HeapDirectory - Class in org.elasticsearch.index.store.memory
 
HeapDirectory() - Constructor for class org.elasticsearch.index.store.memory.HeapDirectory
 
HeapDirectory(SizeValue, SizeValue, boolean) - Constructor for class org.elasticsearch.index.store.memory.HeapDirectory
 
HeapDumpContributor - Class in org.elasticsearch.monitor.dump.heap
 
HeapDumpContributor(String, Settings) - Constructor for class org.elasticsearch.monitor.dump.heap.HeapDumpContributor
 
HeapIndexInput - Class in org.elasticsearch.index.store.memory
 
HeapIndexInput(HeapDirectory, HeapRamFile) - Constructor for class org.elasticsearch.index.store.memory.HeapIndexInput
 
HeapIndexOutput - Class in org.elasticsearch.index.store.memory
 
HeapIndexOutput(HeapDirectory, HeapRamFile) - Constructor for class org.elasticsearch.index.store.memory.HeapIndexOutput
 
HeapRamFile - Class in org.elasticsearch.index.store.memory
 
HeapRamFile(HeapDirectory) - Constructor for class org.elasticsearch.index.store.memory.HeapRamFile
 
HeapStore - Class in org.elasticsearch.index.store.memory
 
HeapStore(ShardId, Settings) - Constructor for class org.elasticsearch.index.store.memory.HeapStore
 
heapUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
 
hear(TypeLiteral<I>, TypeEncounter<I>) - Method in interface org.elasticsearch.util.inject.spi.TypeListener
Invoked when Guice encounters a new type eligible for constructor or members injection.
helpJoin() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Possibly executes other tasks until this task is done, then returns the result of the computation.
helpQuiesce() - Static method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Possibly executes tasks until the pool hosting the current task is quiescent.
highlight() - Static method in class org.elasticsearch.search.builder.SearchSourceBuilder
A static factory method to construct new search highlights.
highlight(SearchSourceHighlightBuilder) - 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
 
HighlighterParseElement - Class in org.elasticsearch.search.highlight
highlight : { tags_schema : "styled", pre_Tags : ["tag1", "tag2"], post_tags : ["tag1", "tag2"], order : "score", fields : { field1 : { } field2 : { fragment_size : 100, num_of_fragments : 2 } } }
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, String[]) - 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
 
highlightFilters - Static variable in class org.apache.lucene.search.vectorhighlight.CustomFieldQuery
 
HighlightPhase - Class in org.elasticsearch.search.highlight
 
HighlightPhase() - Constructor for 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).
homeFile() - Method in class org.elasticsearch.env.Environment
The home of the installation.
hours() - Method in class org.elasticsearch.util.TimeValue
 
hoursFrac() - Method in class org.elasticsearch.util.TimeValue
 
HttpChannel - Interface in org.elasticsearch.http
 
HttpDownloadHelper - Class in org.elasticsearch.util.http
 
HttpDownloadHelper() - Constructor for class org.elasticsearch.util.http.HttpDownloadHelper
 
HttpDownloadHelper.DownloadProgress - Interface in org.elasticsearch.util.http
Interface implemented for reporting progress of downloading.
HttpDownloadHelper.NullProgress - Class in org.elasticsearch.util.http
do nothing with progress info
HttpDownloadHelper.NullProgress() - Constructor for class org.elasticsearch.util.http.HttpDownloadHelper.NullProgress
 
HttpDownloadHelper.VerboseProgress - Class in org.elasticsearch.util.http
verbose progress system prints to some output stream
HttpDownloadHelper.VerboseProgress(PrintStream) - Constructor for class org.elasticsearch.util.http.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
 
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, HttpServerTransport, ThreadPool, RestController, TransportNodesInfoAction) - 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
 
HttpServerHandler - Interface in org.elasticsearch.http
 
HttpServerModule - Class in org.elasticsearch.http
 
HttpServerModule(Settings) - Constructor for class org.elasticsearch.http.HttpServerModule
 
HttpServerTransport - Interface in org.elasticsearch.http
 

I

id() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
id(String) - Method in class org.elasticsearch.action.admin.cluster.ping.single.SinglePingRequest
 
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(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.GetResponse
The id of the 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 rutn with.
id(String) - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
The id of document to load from which the "like" query will rutn with.
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 - Variable in class org.elasticsearch.action.support.single.SingleOperationRequest
 
id() - Method in class org.elasticsearch.action.support.single.SingleOperationRequest
 
id() - Method in enum org.elasticsearch.action.ThreadingModel
 
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
 
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.Index
 
id() - Method in exception org.elasticsearch.index.engine.IndexFailedEngineException
 
id() - Method in class org.elasticsearch.index.mapper.ParsedDocument
 
id() - Method in class org.elasticsearch.index.mapper.Uid
 
id() - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
 
id(String) - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
Really, just the id mapper should set this.
id() - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
id() - Method in enum org.elasticsearch.index.shard.IndexShardState
 
id() - Method in class org.elasticsearch.index.shard.ShardId
 
id() - Method in class org.elasticsearch.index.translog.Translog.Create
 
id() - Method in class org.elasticsearch.index.translog.Translog.Index
 
id() - Method in enum org.elasticsearch.index.translog.Translog.Operation.Type
 
id() - Method in class org.elasticsearch.monitor.process.ProcessInfo
The process id.
id() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
 
id() - Method in enum org.elasticsearch.search.facets.Facet.Type
 
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() - Method in class org.elasticsearch.util.transport.LocalTransportAddress
 
identicalTo(Object) - Static method in class org.elasticsearch.util.inject.matcher.Matchers
Returns a matcher which matches only the given object.
identity() - Static method in class org.elasticsearch.util.base.Functions
Returns the identity function.
IdentityHashSet<E> - Class in org.elasticsearch.util
 
IdentityHashSet() - Constructor for class org.elasticsearch.util.IdentityHashSet
 
IdentityHashSet(Collection<? extends E>) - Constructor for class org.elasticsearch.util.IdentityHashSet
 
IdentityHashSet(int) - Constructor for class org.elasticsearch.util.IdentityHashSet
 
idField(XContentIdFieldMapper.Builder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper.Builder
 
IdFieldMapper - Interface in org.elasticsearch.index.mapper
 
idFieldMappers() - Method in class org.elasticsearch.index.mapper.MapperService
 
idle() - Method in class org.elasticsearch.monitor.os.OsStats.Cpu
 
idMapper() - Method in interface org.elasticsearch.index.mapper.DocumentMapper
 
idMapper() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
ignoreBackups() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportShardGatewaySnapshotAction
Snapshot should only happen on primary shards.
ignoreBackups() - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
Should the operations be performed on the backups as well.
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.
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
 
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.optimize.TransportOptimizeAction
 
ignoreNonActiveExceptions() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
ignoreNonActiveExceptions() - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
 
ignoreNonActiveExceptions() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
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.index.shard.recovery
An exception marking that this recovery attempt should be ignored (since probably, we already recovered).
IgnoreRecoveryException(String) - Constructor for exception org.elasticsearch.index.shard.recovery.IgnoreRecoveryException
 
IgnoreRecoveryException(String, Throwable) - Constructor for exception org.elasticsearch.index.shard.recovery.IgnoreRecoveryException
 
ignoreTF(boolean) - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisFieldQueryBuilder
 
ignoreTF(boolean) - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisQueryBuilder
 
IllegalIndexShardStateException - Exception in org.elasticsearch.index.shard
 
IllegalIndexShardStateException(ShardId, IndexShardState, String) - 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
 
Immutable - Annotation Type in org.elasticsearch.util.concurrent
Immutable

The class to which this annotation is applied is immutable.

ImmutableBiMap<K,V> - Class in org.elasticsearch.util.collect
An immutable BiMap with reliable user-specified iteration order.
ImmutableBiMap.Builder<K,V> - Class in org.elasticsearch.util.collect
A builder for creating immutable bimap instances, especially public static final bimaps ("constant bimaps").
ImmutableBiMap.Builder() - Constructor for class org.elasticsearch.util.collect.ImmutableBiMap.Builder
Creates a new builder.
ImmutableClassToInstanceMap<B> - Class in org.elasticsearch.util.collect
A class-to-instance map backed by an ImmutableMap.
ImmutableClassToInstanceMap.Builder<B> - Class in org.elasticsearch.util.collect
A builder for creating immutable class-to-instance maps.
ImmutableClassToInstanceMap.Builder() - Constructor for class org.elasticsearch.util.collect.ImmutableClassToInstanceMap.Builder
 
ImmutableCollection<E> - Class in org.elasticsearch.util.collect
An immutable collection.
immutableCopy() - Method in class org.elasticsearch.util.collect.Sets.SetView
Returns an immutable copy of the current contents of this set view.
immutableEntry(K, V) - Static method in class org.elasticsearch.util.collect.Maps
Returns an immutable map entry with the specified key and value.
immutableEntry(E, int) - Static method in class org.elasticsearch.util.collect.Multisets
Returns an immutable multiset entry with the specified element and count.
immutableEnumSet(E, E...) - Static method in class org.elasticsearch.util.collect.Sets
Returns an immutable set instance containing the given enum elements.
immutableEnumSet(Iterable<E>) - Static method in class org.elasticsearch.util.collect.Sets
Returns an immutable set instance containing the given enum elements.
ImmutableList<E> - Class in org.elasticsearch.util.collect
A high-performance, immutable, random-access List implementation.
ImmutableList.Builder<E> - Class in org.elasticsearch.util.collect
A builder for creating immutable list instances, especially public static final lists ("constant lists").
ImmutableList.Builder() - Constructor for class org.elasticsearch.util.collect.ImmutableList.Builder
Creates a new builder.
ImmutableListMultimap<K,V> - Class in org.elasticsearch.util.collect
An immutable ListMultimap with reliable user-specified key and value iteration order.
ImmutableListMultimap.Builder<K,V> - Class in org.elasticsearch.util.collect
A builder for creating immutable ListMultimap instances, especially public static final multimaps ("constant multimaps").
ImmutableListMultimap.Builder() - Constructor for class org.elasticsearch.util.collect.ImmutableListMultimap.Builder
Creates a new builder.
ImmutableMap<K,V> - Class in org.elasticsearch.util.collect
An immutable, hash-based Map with reliable user-specified iteration order.
immutableMap() - Method in class org.elasticsearch.util.MapBuilder
 
ImmutableMap.Builder<K,V> - Class in org.elasticsearch.util.collect
A builder for creating immutable map instances, especially public static final maps ("constant maps").
ImmutableMap.Builder() - Constructor for class org.elasticsearch.util.collect.ImmutableMap.Builder
Creates a new builder.
ImmutableMultimap<K,V> - Class in org.elasticsearch.util.collect
An immutable Multimap.
ImmutableMultimap.Builder<K,V> - Class in org.elasticsearch.util.collect
A builder for creating immutable multimap instances, especially public static final multimaps ("constant multimaps").
ImmutableMultimap.Builder() - Constructor for class org.elasticsearch.util.collect.ImmutableMultimap.Builder
Creates a new builder.
ImmutableMultiset<E> - Class in org.elasticsearch.util.collect
An immutable hash-based multiset.
ImmutableMultiset.Builder<E> - Class in org.elasticsearch.util.collect
A builder for creating immutable multiset instances, especially public static final multisets ("constant multisets").
ImmutableMultiset.Builder() - Constructor for class org.elasticsearch.util.collect.ImmutableMultiset.Builder
Creates a new builder.
ImmutableSet<E> - Class in org.elasticsearch.util.collect
A high-performance, immutable Set with reliable, user-specified iteration order.
ImmutableSet.Builder<E> - Class in org.elasticsearch.util.collect
A builder for creating immutable set instances, especially public static final sets ("constant sets").
ImmutableSet.Builder() - Constructor for class org.elasticsearch.util.collect.ImmutableSet.Builder
Creates a new builder.
ImmutableSetMultimap<K,V> - Class in org.elasticsearch.util.collect
An immutable SetMultimap with reliable user-specified key and value iteration order.
ImmutableSetMultimap.Builder<K,V> - Class in org.elasticsearch.util.collect
A builder for creating immutable SetMultimap instances, especially public static final multimaps ("constant multimaps").
ImmutableSetMultimap.Builder() - Constructor for class org.elasticsearch.util.collect.ImmutableSetMultimap.Builder
Creates a new builder.
ImmutableSettings - Class in org.elasticsearch.util.settings
An immutable implementation of Settings.
ImmutableSettings.Builder - Class in org.elasticsearch.util.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() - Constructor for class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
ImmutableShardRouting(ShardRouting) - Constructor for class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
ImmutableShardRouting(String, int, String, boolean, ShardRoutingState) - Constructor for class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
ImmutableShardRouting(String, int, String, String, boolean, ShardRoutingState) - Constructor for class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
ImmutableSortedMap<K,V> - Class in org.elasticsearch.util.collect
An immutable SortedMap.
ImmutableSortedMap.Builder<K,V> - Class in org.elasticsearch.util.collect
A builder for creating immutable sorted map instances, especially public static final maps ("constant maps").
ImmutableSortedMap.Builder(Comparator<? super K>) - Constructor for class org.elasticsearch.util.collect.ImmutableSortedMap.Builder
Creates a new builder.
ImmutableSortedSet<E> - Class in org.elasticsearch.util.collect
An immutable SortedSet that stores its elements in a sorted array.
ImmutableSortedSet.Builder<E> - Class in org.elasticsearch.util.collect
A builder for creating immutable sorted set instances, especially public static final sets ("constant sets"), with a given comparator.
ImmutableSortedSet.Builder(Comparator<? super E>) - Constructor for class org.elasticsearch.util.collect.ImmutableSortedSet.Builder
Creates a new builder.
IMPLEMENTATION_ALREADY_SET - Static variable in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
ImplementedBy - Annotation Type in org.elasticsearch.util.inject
A pointer to the default implementation of a type.
in(Collection<? extends T>) - Static method in class org.elasticsearch.util.base.Predicates
Returns a predicate that evaluates to true if the object reference being tested is a member of the given collection.
in(Class<? extends Annotation>) - Method in interface org.elasticsearch.util.inject.binder.ScopedBindingBuilder
See the EDSL examples at Binder.
in(Scope) - Method in interface org.elasticsearch.util.inject.binder.ScopedBindingBuilder
See the EDSL examples at Binder.
in(Class<? extends Annotation>) - Method in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
in(Scope) - Method in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
include(XContentSpanQueryBuilder) - Method in class org.elasticsearch.index.query.xcontent.SpanNotQueryBuilder
 
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.
includeInAll - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
includeInAll(Boolean) - Method in interface org.elasticsearch.index.mapper.xcontent.XContentIncludeInAllMapper
 
includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper
 
includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.Builder
 
includeInAll - Variable in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
 
includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
 
includeInAll(boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.Builder
 
includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper
 
includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper.Builder
 
includeInAll(Boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper
 
includeLower(boolean) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
Should the lower bound be included or not.
includeLower(boolean) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
Should the lower bound be included or not.
includeUpper(boolean) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
Should the upper bound be included or not.
includeUpper(boolean) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
Should the upper bound be included or not.
increment(long) - Method in class org.elasticsearch.search.facets.CountFacet
 
increment() - Method in class org.elasticsearch.util.concurrent.highscalelib.ConcurrentAutoTable
ConcurrentAutoTable.add(long) with +1
increment(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Increments the primitive value mapped to key by 1
increment(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Increments the primitive value mapped to key by 1
increment(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Increments the primitive value mapped to key by 1
increment(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Increments the primitive value mapped to key by 1
increment(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Increments the primitive value mapped to key by 1
increment(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Increments the primitive value mapped to key by 1
increment(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Increments the primitive value mapped to key by 1
increment(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Increments the primitive value mapped to key by 1
increment(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Increments the primitive value mapped to key by 1
increment(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Increments the primitive value mapped to key by 1
increment(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Increments the primitive value mapped to key by 1
increment(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Increments the primitive value mapped to key by 1
increment(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Increments the primitive value mapped to key by 1
increment(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Increments the primitive value mapped to key by 1
increment(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Increments the primitive value mapped to key by 1
increment(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Increments the primitive value mapped to key by 1
increment(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Increments the primitive value mapped to key by 1
increment(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Increments the primitive value mapped to key by 1
increment(int) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Increments the primitive value mapped to key by 1
increment(int) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Increments the primitive value mapped to key by 1
increment(int) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Increments the primitive value mapped to key by 1
increment(int) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Increments the primitive value mapped to key by 1
increment(int) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Increments the primitive value mapped to key by 1
increment(int) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Increments the primitive value mapped to key by 1
increment(long) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Increments the primitive value mapped to key by 1
increment(long) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Increments the primitive value mapped to key by 1
increment(long) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Increments the primitive value mapped to key by 1
increment(long) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Increments the primitive value mapped to key by 1
increment(long) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Increments the primitive value mapped to key by 1
increment(long) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Increments the primitive value mapped to key by 1
increment(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Increments the primitive value mapped to key by 1
increment(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Increments the primitive value mapped to key by 1
increment(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Increments the primitive value mapped to key by 1
increment(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Increments the primitive value mapped to key by 1
increment(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Increments the primitive value mapped to key by 1
increment(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Increments the primitive value mapped to key by 1
increment(short) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Increments the primitive value mapped to key by 1
increment(short) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Increments the primitive value mapped to key by 1
increment(short) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Increments the primitive value mapped to key by 1
increment(short) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Increments the primitive value mapped to key by 1
increment(short) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Increments the primitive value mapped to key by 1
increment(short) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Increments the primitive value mapped to key by 1
incrementToken() - Method in class org.elasticsearch.index.analysis.NumericTokenizer
 
incrementToken() - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.CachedNumericTokenStream
 
incrementToken() - Method in class org.elasticsearch.util.lucene.all.AllTokenFilter
 
index() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
index() - Method in class org.elasticsearch.action.admin.cluster.ping.replication.IndexReplicationPingResponse
 
index(String) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.ReplicationPingResponse
 
index(String) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.GatewaySnapshotResponse
The index level gateway snapshot response for the given index.
index() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.IndexGatewaySnapshotResponse
The index the gateway snapshot has performed on.
index() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
index(String) - Method in class org.elasticsearch.action.admin.indices.status.IndicesStatusResponse
 
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(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() - Method in class org.elasticsearch.action.get.GetResponse
The index the document was fetched from.
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() - 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 - 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.SingleOperationRequest
 
index() - Method in class org.elasticsearch.action.support.single.SingleOperationRequest
 
INDEX - Static variable in class org.elasticsearch.action.TransportActions
 
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 JSON source associated with a given index and type.
index(IndexRequest) - Method in class org.elasticsearch.client.node.NodeClient
 
index(IndexRequest, ActionListener<IndexResponse>) - Method in class org.elasticsearch.client.node.NodeClient
 
index(IndexRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
index(IndexRequest, ActionListener<IndexResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
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.metadata.AliasAction
 
index() - 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
 
index - Variable in class org.elasticsearch.index.AbstractIndexComponent
 
index() - Method in class org.elasticsearch.index.AbstractIndexComponent
 
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.IndexShardGateway.RecoveryStatus
 
index() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.SnapshotStatus
 
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() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
index(Field.Index) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper.Builder
 
INDEX - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper.Defaults
 
index - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
index(Field.Index) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
INDEX - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Defaults
 
index - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
index() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
index(Field.Index) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.OpenBuilder
 
INDEX - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper.Defaults
 
INDEX - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.Defaults
 
INDEX - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper.Defaults
 
INDEX - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper.Defaults
 
INDEX - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper.Defaults
 
index(String, String, byte[]) - Method in interface org.elasticsearch.index.shard.service.IndexShard
 
index(String, String, byte[]) - 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(Iterable<V>, Function<? super V, K>) - Static method in class org.elasticsearch.util.collect.Multimaps
Creates an index ImmutableMultimap that contains the results of applying a specified function to each item in an Iterable of values.
index(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteHash
Locates the index of val.
index(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHash
Locates the index of val.
index(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatHash
Locates the index of val.
index(int) - Method in class org.elasticsearch.util.gnu.trove.TIntHash
Locates the index of val.
index(long) - Method in class org.elasticsearch.util.gnu.trove.TLongHash
Locates the index of val.
index(T) - Method in class org.elasticsearch.util.gnu.trove.TObjectHash
Locates the index of obj.
index(short) - Method in class org.elasticsearch.util.gnu.trove.TShortHash
Locates the index of val.
index() - Method in enum org.elasticsearch.util.xcontent.XContentType
 
INDEX_NAME - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper.Defaults
 
INDEX_NAME - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper.Defaults
 
INDEX_NAME - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper.Defaults
 
indexAction - Variable in class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
indexAliasesRequest() - Static method in class org.elasticsearch.client.Requests
Creates an index aliases request allowing to add and remove aliases.
IndexAlreadyExistsException - Exception in org.elasticsearch.indices
 
IndexAlreadyExistsException(Index) - Constructor for exception org.elasticsearch.indices.IndexAlreadyExistsException
 
indexAnalyzer() - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
A smart analyzer used for indexing that takes into account specific analyzers configured per FieldMapper.
indexAnalyzer() - Method in interface org.elasticsearch.index.mapper.DocumentMapper
The default index analyzer to be used.
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.xcontent.XContentAllFieldMapper.Builder
 
indexAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper.Builder
 
indexAnalyzer() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
indexAnalyzer - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
indexAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
indexAnalyzer - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
indexAnalyzer() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
indexAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.OpenBuilder
 
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) - Constructor for class org.elasticsearch.index.cache.IndexCache
 
IndexCache(Index, Settings, FilterCache) - Constructor for class org.elasticsearch.index.cache.IndexCache
 
indexCache() - Method in class org.elasticsearch.index.query.xcontent.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.util.lucene
A simple delegate that delegates all IndexCommit calls to a delegated IndexCommit.
IndexCommitDelegate(IndexCommit) - Constructor for class org.elasticsearch.util.lucene.IndexCommitDelegate
Constructs a new IndexCommit that will delegate all calls to the provided delegate.
IndexComponent - Interface in org.elasticsearch.index
 
IndexDeleteByQueryRequest - Class in org.elasticsearch.action.deletebyquery
Delete by query request to execute on a specific index.
IndexDeleteByQueryRequest(String, String...) - Constructor for class org.elasticsearch.action.deletebyquery.IndexDeleteByQueryRequest
 
IndexDeleteByQueryResponse - Class in org.elasticsearch.action.deletebyquery
Delete by query response executed on a specific index.
indexed() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
indexed() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
indexedValue(String) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Returns the indexed value.
indexedValue(T) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Returns the indexed value.
indexedValue(Void) - Method in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBinaryFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper
 
indexedValue(Boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
indexedValue(Float) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
 
indexedValue(Long) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper
 
indexedValue(Double) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
indexedValue(T) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper
 
indexedValue(Float) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper
 
indexedValue(Integer) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper
 
indexedValue(Long) - Method in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper
 
indexedValue(Short) - Method in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper
 
indexedValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper
 
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
 
IndexGateway - Interface in org.elasticsearch.index.gateway
 
indexGatewayHome() - Method in class org.elasticsearch.index.gateway.fs.FsIndexGateway
 
IndexGatewayModule - Class in org.elasticsearch.index.gateway
 
IndexGatewayModule(Settings, Gateway) - Constructor for class org.elasticsearch.index.gateway.IndexGatewayModule
 
IndexGatewaySnapshotRequest - Class in org.elasticsearch.action.admin.indices.gateway.snapshot
 
IndexGatewaySnapshotResponse - Class in org.elasticsearch.action.admin.indices.gateway.snapshot
An index level gateway snapshot response.
IndexMetaData - Class in org.elasticsearch.cluster.metadata
 
indexMetaData(ClusterState) - Method in class org.elasticsearch.index.routing.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
 
IndexMissingException - Exception in org.elasticsearch.indices
 
IndexMissingException(Index) - Constructor for exception org.elasticsearch.indices.IndexMissingException
 
IndexModule - Class in org.elasticsearch.index
 
IndexModule() - Constructor for class org.elasticsearch.index.IndexModule
 
indexModules() - 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() - Method in class org.elasticsearch.plugins.PluginsService
 
indexName(String) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
 
indexName() - Method in class org.elasticsearch.index.mapper.FieldMapper.Names
The indexed name of the field.
indexName(String) - Method in class org.elasticsearch.index.mapper.MapperService
Returns MapperService.SmartNameFieldMappers 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.mapper.xcontent.XContentBinaryFieldMapper.Builder
 
indexName(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper.Builder
 
indexName - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
indexName(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
indexName(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.OpenBuilder
 
indexName(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.Builder
 
indexName - Variable in class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper.Builder
 
indexName(String) - Method in class org.elasticsearch.index.query.xcontent.QueryParseContext
 
indexNameClean() - Method in class org.elasticsearch.index.mapper.FieldMapper.Names
The cleaned index name, before any "path" modifications performed on it.
IndexNameModule - Class in org.elasticsearch.index
 
IndexNameModule(Index) - Constructor for class org.elasticsearch.index.IndexNameModule
 
indexOf(Object) - Method in class org.elasticsearch.util.collect.ForwardingList
 
indexOf(Object) - Method in class org.elasticsearch.util.collect.ImmutableList
 
indexOf(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Searches the list front to back for the index of value.
indexOf(int, byte) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Searches the list front to back for the index of value, starting at offset.
indexOf(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Searches the list front to back for the index of value.
indexOf(int, double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Searches the list front to back for the index of value, starting at offset.
indexOf(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Searches the list front to back for the index of value.
indexOf(int, float) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Searches the list front to back for the index of value, starting at offset.
indexOf(int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Searches the list front to back for the index of value.
indexOf(int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Searches the list front to back for the index of value, starting at offset.
indexOf(long) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Searches the list front to back for the index of value.
indexOf(int, long) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Searches the list front to back for the index of value, starting at offset.
indexOf(short) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Searches the list front to back for the index of value.
indexOf(int, short) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Searches the list front to back for the index of value, starting at offset.
IndexQueryParser - Interface in org.elasticsearch.index.query
 
indexQueryParser(String) - Method in class org.elasticsearch.index.query.IndexQueryParserService
 
IndexQueryParserFactory - Interface in org.elasticsearch.index.query
 
IndexQueryParserMissingException - Exception in org.elasticsearch.index.query
 
IndexQueryParserMissingException(String) - Constructor for exception org.elasticsearch.index.query.IndexQueryParserMissingException
 
IndexQueryParserModule - Class in org.elasticsearch.index.query
 
IndexQueryParserModule(Settings) - Constructor for class org.elasticsearch.index.query.IndexQueryParserModule
 
IndexQueryParserService - Class in org.elasticsearch.index.query
 
IndexQueryParserService(Index, MapperService, IndexCache, AnalysisService) - Constructor for class org.elasticsearch.index.query.IndexQueryParserService
 
IndexQueryParserService(Index, Settings, MapperService, IndexCache, AnalysisService, SimilarityService, Map<String, IndexQueryParserFactory>) - 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
 
IndexReplicationOperationRequest - Class in org.elasticsearch.action.support.replication
 
IndexReplicationOperationRequest() - Constructor for class org.elasticsearch.action.support.replication.IndexReplicationOperationRequest
 
IndexReplicationPingRequest - Class in org.elasticsearch.action.admin.cluster.ping.replication
 
IndexReplicationPingRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.ping.replication.IndexReplicationPingRequest
 
IndexReplicationPingResponse - Class in org.elasticsearch.action.admin.cluster.ping.replication
 
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.
IndexResponse - Class in org.elasticsearch.action.index
A response of an index operation,
IndexRoutingTable - Class in org.elasticsearch.cluster.routing
 
indexRoutingTable(String) - Static method in class org.elasticsearch.cluster.routing.RoutingBuilders
 
indexRoutingTable(ClusterState) - Method in class org.elasticsearch.index.routing.plain.PlainOperationRouting
 
IndexRoutingTable.Builder - Class in org.elasticsearch.cluster.routing
 
IndexRoutingTable.Builder(String) - Constructor for class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
 
IndexService - Interface in org.elasticsearch.index.service
 
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 - 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(Settings) - Constructor for class org.elasticsearch.index.settings.IndexSettingsModule
 
indexShard(TransportShardReplicationOperationAction<Request, Response>.ShardOperationRequest) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
IndexShard - Interface in org.elasticsearch.index.shard.service
 
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
 
IndexShardComponent - Interface in org.elasticsearch.index.shard
 
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.RecoveryStatus - Class in org.elasticsearch.index.gateway
 
IndexShardGateway.RecoveryStatus(IndexShardGateway.RecoveryStatus.Index, IndexShardGateway.RecoveryStatus.Translog) - Constructor for class org.elasticsearch.index.gateway.IndexShardGateway.RecoveryStatus
 
IndexShardGateway.RecoveryStatus.Index - Class in org.elasticsearch.index.gateway
 
IndexShardGateway.RecoveryStatus.Index(long, int, SizeValue, TimeValue) - Constructor for class org.elasticsearch.index.gateway.IndexShardGateway.RecoveryStatus.Index
 
IndexShardGateway.RecoveryStatus.Translog - Class in org.elasticsearch.index.gateway
 
IndexShardGateway.RecoveryStatus.Translog(long, int, SizeValue) - Constructor for class org.elasticsearch.index.gateway.IndexShardGateway.RecoveryStatus.Translog
 
IndexShardGateway.Snapshot - Class in org.elasticsearch.index.gateway
 
IndexShardGateway.Snapshot(SnapshotIndexCommit, Translog.Snapshot, long, long, int) - Constructor for class org.elasticsearch.index.gateway.IndexShardGateway.Snapshot
 
IndexShardGateway.SnapshotStatus - Class in org.elasticsearch.index.gateway
 
IndexShardGateway.SnapshotStatus(TimeValue, IndexShardGateway.SnapshotStatus.Index, IndexShardGateway.SnapshotStatus.Translog) - Constructor for class org.elasticsearch.index.gateway.IndexShardGateway.SnapshotStatus
 
IndexShardGateway.SnapshotStatus.Index - Class in org.elasticsearch.index.gateway
 
IndexShardGateway.SnapshotStatus.Index(int, SizeValue, TimeValue) - Constructor for class org.elasticsearch.index.gateway.IndexShardGateway.SnapshotStatus.Index
 
IndexShardGateway.SnapshotStatus.Translog - Class in org.elasticsearch.index.gateway
 
IndexShardGateway.SnapshotStatus.Translog(int, TimeValue) - Constructor for class org.elasticsearch.index.gateway.IndexShardGateway.SnapshotStatus.Translog
 
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, Throwable) - Constructor for exception org.elasticsearch.index.gateway.IndexShardGatewayRecoveryException
 
IndexShardGatewayService - Class in org.elasticsearch.index.gateway
 
IndexShardGatewayService(ShardId, Settings, ThreadPool, IndexShard, IndexShardGateway, Store, RecoveryThrottler) - Constructor for class org.elasticsearch.index.gateway.IndexShardGatewayService
 
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(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) - Constructor for class org.elasticsearch.cluster.routing.IndexShardRoutingTable.Builder
 
indexShards(ClusterState, String, String) - Method in interface org.elasticsearch.index.routing.OperationRouting
 
indexShards(ClusterState, String, String) - Method in class org.elasticsearch.index.routing.plain.PlainOperationRouting
 
IndexShardStartedException - Exception in org.elasticsearch.index.shard
 
IndexShardStartedException(ShardId) - Constructor for exception org.elasticsearch.index.shard.IndexShardStartedException
 
IndexShardState - Enum in org.elasticsearch.index.shard
 
IndexShardStatus - Class in org.elasticsearch.action.admin.indices.status
 
IndexShardStatus.Docs - Class in org.elasticsearch.action.admin.indices.status
 
IndexShardStatus.Docs() - Constructor for class org.elasticsearch.action.admin.indices.status.IndexShardStatus.Docs
 
IndexStatus - Class in org.elasticsearch.action.admin.indices.status
 
IndexStatus.Docs - Class in org.elasticsearch.action.admin.indices.status
 
IndexStatus.Docs() - Constructor for class org.elasticsearch.action.admin.indices.status.IndexStatus.Docs
 
IndexWriters - Class in org.elasticsearch.util.lucene
 
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.ping.replication.ReplicationPingResponse
 
indices() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.GatewaySnapshotResponse
A map of index level responses of the gateway snapshot operation.
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.status.IndicesStatusResponse
 
indices(String...) - Method in class org.elasticsearch.action.count.CountRequest
 
indices(String...) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
 
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.metadata.MetaData
 
indices() - Method in interface org.elasticsearch.indices.IndicesService
 
indices() - Method in class org.elasticsearch.indices.InternalIndicesService
 
IndicesAdminClient - Interface in org.elasticsearch.client
Administrative actions/operations against indices.
indicesAliases(List<AliasAction>) - Method in class org.elasticsearch.cluster.metadata.MetaDataService
 
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
 
IndicesAliasesResponse - Class in org.elasticsearch.action.admin.indices.alias
A response for a create index action.
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, ShardStateAction, NodeIndexCreatedAction, NodeIndexDeletedAction, NodeMappingCreatedAction) - Constructor for class org.elasticsearch.indices.cluster.IndicesClusterStateService
 
indicesFailures() - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
 
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
 
IndicesMemoryCleaner - Class in org.elasticsearch.indices
 
IndicesMemoryCleaner(Settings, IndicesService) - Constructor for class org.elasticsearch.indices.IndicesMemoryCleaner
 
IndicesMemoryCleaner.MemoryCleanResult - Class in org.elasticsearch.indices
 
IndicesMemoryCleaner.MemoryCleanResult(int, int, SizeValue, SizeValue) - Constructor for class org.elasticsearch.indices.IndicesMemoryCleaner.MemoryCleanResult
 
IndicesMemoryCleaner.TranslogCleanResult - Class in org.elasticsearch.indices
 
IndicesMemoryCleaner.TranslogCleanResult(int, int, SizeValue) - Constructor for class org.elasticsearch.indices.IndicesMemoryCleaner.TranslogCleanResult
 
IndicesModule - Class in org.elasticsearch.indices
 
IndicesModule(Settings) - Constructor for class org.elasticsearch.indices.IndicesModule
 
indicesPattern - Static variable in class org.elasticsearch.rest.action.support.RestActions
 
IndicesPluginsModule - Class in org.elasticsearch.plugins
 
IndicesPluginsModule(Settings, PluginsService) - Constructor for class org.elasticsearch.plugins.IndicesPluginsModule
 
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
 
indicesService - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction
 
indicesService - Variable in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
indicesService - Variable in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
indicesService - Variable in class org.elasticsearch.action.support.single.TransportSingleOperationAction
 
IndicesService - Interface in org.elasticsearch.indices
 
indicesStatus(String...) - Static method in class org.elasticsearch.client.Requests
Creates an indices status request.
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
 
IndicesStatusResponse - Class in org.elasticsearch.action.admin.indices.status
 
inErrs() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
InetSocketTransportAddress - Class in org.elasticsearch.util.transport
A transport address used for IP socket address (wraps InetSocketAddress).
InetSocketTransportAddress(String, int) - Constructor for class org.elasticsearch.util.transport.InetSocketTransportAddress
 
InetSocketTransportAddress(InetAddress, int) - Constructor for class org.elasticsearch.util.transport.InetSocketTransportAddress
 
InetSocketTransportAddress(InetSocketAddress) - Constructor for class org.elasticsearch.util.transport.InetSocketTransportAddress
 
INFO - Static variable in class org.elasticsearch.action.TransportActions.Admin.Cluster.Node
 
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.threadpool.support.AbstractThreadPool
 
info() - Method in interface 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
 
info(String, Object...) - Method in interface org.elasticsearch.util.logging.ESLogger
Logs an INFO level message.
info(String, Throwable, Object...) - Method in interface org.elasticsearch.util.logging.ESLogger
Logs an INFO level message.
info(String, Object...) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
info(String, Throwable, Object...) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
inForkJoinPool() - Static method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Returns true if the current thread is executing as a ForkJoinPool computation.
init(String[]) - Method in class org.elasticsearch.bootstrap.Bootstrap
hook for JSVC
initCounter() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
 
initialCapacity(int) - Method in class org.elasticsearch.util.collect.MapMaker
Sets a custom initial capacity (defaults to 16).
initialize() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
 
initialize() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
 
initialize() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
 
initialized() - Method in class org.elasticsearch.util.component.Lifecycle
Returns true if the state is initialized.
initializeDelegate(MembersInjector<T>) - Method in class org.elasticsearch.util.inject.spi.MembersInjectorLookup
Sets the actual members injector.
initializeDelegate(Provider<T>) - Method in class org.elasticsearch.util.inject.spi.ProviderLookup
Sets the actual provider.
initializeEmpty(IndexMetaData) - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable.Builder
Initializes a new empry index
initializing() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
initializing() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
 
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.util.inject.internal.PrivateElementsImpl
 
Inject - Annotation Type in org.elasticsearch.util.inject
Annotates members of your implementation class (constructors, methods and fields) into which the Injector should inject values.
InjectionListener<I> - Interface in org.elasticsearch.util.inject.spi
Listens for injections into instances of type I.
InjectionPoint - Class in org.elasticsearch.util.inject.spi
A constructor, field or method that can receive injections.
InjectionRequest<T> - Class in org.elasticsearch.util.inject.spi
A request to inject the instance fields and methods of an instance.
InjectionRequest(Object, TypeLiteral<T>, T) - Constructor for class org.elasticsearch.util.inject.spi.InjectionRequest
 
injectMembers(Object) - Method in interface org.elasticsearch.util.inject.Injector
Injects dependencies into the fields and methods of instance.
injectMembers(T) - Method in interface org.elasticsearch.util.inject.MembersInjector
Injects dependencies into the fields and methods of instance.
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
 
Injector - Interface in org.elasticsearch.util.inject
Builds the graphs of objects that make up your application.
Injectors - Class in org.elasticsearch.util.guice
 
Injectors() - Constructor for class org.elasticsearch.util.guice.Injectors
 
inOrder(boolean) - Method in class org.elasticsearch.index.query.xcontent.SpanNearQueryBuilder
 
inPackage(Package) - Static method in class org.elasticsearch.util.inject.matcher.Matchers
Returns a matcher which matches classes in the given package.
inputArguments() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
InputStreamIndexInput - Class in org.elasticsearch.util.lucene.store
 
InputStreamIndexInput(IndexInput, long) - Constructor for class org.elasticsearch.util.lucene.store.InputStreamIndexInput
 
InputStreamStreamInput - Class in org.elasticsearch.util.io.stream
 
InputStreamStreamInput(InputStream) - Constructor for class org.elasticsearch.util.io.stream.InputStreamStreamInput
 
inSegs() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
insert(int, byte) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Inserts value into the list at offset.
insert(int, byte[]) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Inserts the array of values into the list at offset.
insert(int, byte[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Inserts a slice of the array of values into the list at offset.
insert(int, double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Inserts value into the list at offset.
insert(int, double[]) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Inserts the array of values into the list at offset.
insert(int, double[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Inserts a slice of the array of values into the list at offset.
insert(int, float) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Inserts value into the list at offset.
insert(int, float[]) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Inserts the array of values into the list at offset.
insert(int, float[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Inserts a slice of the array of values into the list at offset.
insert(int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Inserts value into the list at offset.
insert(int, int[]) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Inserts the array of values into the list at offset.
insert(int, int[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Inserts a slice of the array of values into the list at offset.
insert(int, T) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Implementation of index-based list insertions.
insert(int, long) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Inserts value into the list at offset.
insert(int, long[]) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Inserts the array of values into the list at offset.
insert(int, long[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Inserts a slice of the array of values into the list at offset.
insert(int, short) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Inserts value into the list at offset.
insert(int, short[]) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Inserts the array of values into the list at offset.
insert(int, short[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Inserts a slice of the array of values into the list at offset.
insert(String, T) - Method in class org.elasticsearch.util.path.PathTrie
 
insert(String[], int, T) - Method in class org.elasticsearch.util.path.PathTrie.TrieNode
 
insertionIndex(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteHash
Locates the index at which val can be inserted.
insertionIndex(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHash
Locates the index at which val can be inserted.
insertionIndex(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatHash
Locates the index at which val can be inserted.
insertionIndex(int) - Method in class org.elasticsearch.util.gnu.trove.TIntHash
Locates the index at which val can be inserted.
insertionIndex(long) - Method in class org.elasticsearch.util.gnu.trove.TLongHash
Locates the index at which val can be inserted.
insertionIndex(T) - Method in class org.elasticsearch.util.gnu.trove.TObjectHash
Locates the index at which obj can be inserted.
insertionIndex(short) - Method in class org.elasticsearch.util.gnu.trove.TShortHash
Locates the index at which val can be inserted.
inspect() - Method in class org.elasticsearch.util.concurrent.ThreadBarrier
Inspects if the barrier is broken.
install(Module) - Method in class org.elasticsearch.util.inject.AbstractModule
 
install(Module) - Method in interface org.elasticsearch.util.inject.Binder
Uses the given module to configure more bindings.
install(Module) - Method in class org.elasticsearch.util.inject.PrivateModule
 
INSTANCE - Static variable in class org.elasticsearch.transport.VoidTransportResponseHandler
 
INSTANCE - Static variable in class org.elasticsearch.util.io.stream.VoidStreamable
 
INSTANCE - Static variable in class org.elasticsearch.util.transport.DummyTransportAddress
 
INSTANCE_NOSPAWN - Static variable in class org.elasticsearch.transport.VoidTransportResponseHandler
 
InstanceBinding<T> - Interface in org.elasticsearch.util.inject.spi
A binding to a single instance.
InstanceBindingImpl<T> - Class in org.elasticsearch.util.inject.internal
 
InstanceBindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Set<InjectionPoint>, T) - Constructor for class org.elasticsearch.util.inject.internal.InstanceBindingImpl
 
InstanceBindingImpl(Object, Key<T>, Scoping, Set<InjectionPoint>, T) - Constructor for class org.elasticsearch.util.inject.internal.InstanceBindingImpl
 
instanceOf(Class<?>) - Static method in class org.elasticsearch.util.base.Predicates
Returns a predicate that evaluates to true if the object being tested is an instance of the given class.
inSubpackage(String) - Static method in class org.elasticsearch.util.inject.matcher.Matchers
Returns a matcher which matches classes in the given package and its subpackages.
integerField(String) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
interfaceHasIPAddresses(NetworkInterface, NetworkUtils.StackType) - Static method in class org.elasticsearch.util.network.NetworkUtils
A function to check if an interface supports an IP version (i.e has addresses defined for that IP version).
internal_size() - Method in class org.elasticsearch.util.concurrent.highscalelib.ConcurrentAutoTable
Return the internal counter striping factor.
internalAddListener(Object) - Method in class org.elasticsearch.action.support.AbstractListenableActionFuture
 
InternalClient - Interface in org.elasticsearch.client.internal
 
InternalClusterService - Class in org.elasticsearch.cluster.service
 
InternalClusterService(Settings, DiscoveryService, TransportService, ThreadPool) - Constructor for class org.elasticsearch.cluster.service.InternalClusterService
 
InternalContext - Class in org.elasticsearch.util.inject.internal
Internal context.
InternalContext() - Constructor for class org.elasticsearch.util.inject.internal.InternalContext
 
internalDebug(String) - Method in class org.elasticsearch.util.logging.jdk.JdkESLogger
 
internalDebug(String, Throwable) - Method in class org.elasticsearch.util.logging.jdk.JdkESLogger
 
internalDebug(String) - Method in class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
internalDebug(String, Throwable) - Method in class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
internalDebug(String) - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
internalDebug(String, Throwable) - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
internalDebug(String) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
internalDebug(String, Throwable) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
internalError(String) - Method in class org.elasticsearch.util.logging.jdk.JdkESLogger
 
internalError(String, Throwable) - Method in class org.elasticsearch.util.logging.jdk.JdkESLogger
 
internalError(String) - Method in class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
internalError(String, Throwable) - Method in class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
internalError(String) - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
internalError(String, Throwable) - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
internalError(String) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
internalError(String, Throwable) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
InternalFactory<T> - Interface in org.elasticsearch.util.inject.internal
Creates objects which will be injected.
internalHits() - Method in class org.elasticsearch.search.internal.InternalSearchHits
 
InternalIndexService - Class in org.elasticsearch.index.service
 
InternalIndexService(Injector, Index, Settings, MapperService, IndexQueryParserService, SimilarityService, IndexCache, OperationRouting) - Constructor for class org.elasticsearch.index.service.InternalIndexService
 
InternalIndexShard - Class in org.elasticsearch.index.shard.service
 
InternalIndexShard(ShardId, Settings, Store, Engine, Translog, ThreadPool, MapperService, IndexQueryParserService, IndexCache) - Constructor for class org.elasticsearch.index.shard.service.InternalIndexShard
 
InternalIndicesLifecycle - Class in org.elasticsearch.indices
 
InternalIndicesLifecycle(Settings) - Constructor for class org.elasticsearch.indices.InternalIndicesLifecycle
 
InternalIndicesService - Class in org.elasticsearch.indices
 
InternalIndicesService(Settings, IndicesClusterStateService, IndicesLifecycle, Injector) - Constructor for class org.elasticsearch.indices.InternalIndicesService
 
internalInfo(String) - Method in class org.elasticsearch.util.logging.jdk.JdkESLogger
 
internalInfo(String, Throwable) - Method in class org.elasticsearch.util.logging.jdk.JdkESLogger
 
internalInfo(String) - Method in class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
internalInfo(String, Throwable) - Method in class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
internalInfo(String) - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
internalInfo(String, Throwable) - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
internalInfo(String) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
internalInfo(String, Throwable) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
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
 
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
 
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) - Constructor for class org.elasticsearch.search.internal.InternalSearchHits
 
internalSearchRequest(ShardRouting, SearchRequest) - 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) - Constructor for class org.elasticsearch.search.internal.InternalSearchRequest
 
InternalSearchRequest(String, int) - Constructor for class org.elasticsearch.search.internal.InternalSearchRequest
 
InternalSearchResponse - Class in org.elasticsearch.search.internal
 
InternalSearchResponse(InternalSearchHits, Facets) - Constructor for class org.elasticsearch.search.internal.InternalSearchResponse
 
InternalSettingsPerparer - Class in org.elasticsearch.node.internal
 
InternalSettingsPerparer() - Constructor for class org.elasticsearch.node.internal.InternalSettingsPerparer
 
internalTrace(String) - Method in class org.elasticsearch.util.logging.jdk.JdkESLogger
 
internalTrace(String, Throwable) - Method in class org.elasticsearch.util.logging.jdk.JdkESLogger
 
internalTrace(String) - Method in class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
internalTrace(String, Throwable) - Method in class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
internalTrace(String) - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
internalTrace(String, Throwable) - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
internalTrace(String) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
internalTrace(String, Throwable) - Method in class org.elasticsearch.util.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, TransportClientNodesService, InternalTransportAdminClient, ClientTransportIndexAction, ClientTransportDeleteAction, ClientTransportGetAction, ClientTransportDeleteByQueryAction, ClientTransportCountAction, ClientTransportSearchAction, ClientTransportSearchScrollAction, ClientTransportTermsAction, ClientTransportMoreLikeThisAction) - Constructor for class org.elasticsearch.client.transport.support.InternalTransportClient
 
InternalTransportClusterAdminClient - Class in org.elasticsearch.client.transport.support
 
InternalTransportClusterAdminClient(Settings, TransportClientNodesService, ClientTransportClusterHealthAction, ClientTransportClusterStateAction, ClientTransportSinglePingAction, ClientTransportReplicationPingAction, ClientTransportBroadcastPingAction, ClientTransportNodesInfoAction, ClientTransportNodesShutdownAction, ClientTransportNodesRestartAction, ClientTransportNodesStatsAction) - Constructor for class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
InternalTransportIndicesAdminClient - Class in org.elasticsearch.client.transport.support
 
InternalTransportIndicesAdminClient(Settings, TransportClientNodesService, ClientTransportIndicesStatusAction, ClientTransportCreateIndexAction, ClientTransportDeleteIndexAction, ClientTransportRefreshAction, ClientTransportFlushAction, ClientTransportOptimizeAction, ClientTransportPutMappingAction, ClientTransportGatewaySnapshotAction, ClientTransportIndicesAliasesAction, ClientTransportClearIndicesCacheAction) - Constructor for class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
internalWarn(String) - Method in class org.elasticsearch.util.logging.jdk.JdkESLogger
 
internalWarn(String, Throwable) - Method in class org.elasticsearch.util.logging.jdk.JdkESLogger
 
internalWarn(String) - Method in class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
internalWarn(String, Throwable) - Method in class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
internalWarn(String) - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
internalWarn(String, Throwable) - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
internalWarn(String) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
internalWarn(String, Throwable) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
intersection(Set<E>, Set<?>) - Static method in class org.elasticsearch.util.collect.Sets
Returns an unmodifiable view of the intersection of two sets.
intToBytes(int) - Static method in class org.elasticsearch.util.Numbers
Converts an int to a byte array.
intValue() - Method in class org.elasticsearch.util.concurrent.highscalelib.ConcurrentAutoTable
Same as ConcurrentAutoTable.get(), included for completeness.
intValue() - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentParser
 
intValue() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
INVALID_FILENAME_CHARS - Static variable in class org.elasticsearch.util.Strings
 
InvalidIndexNameException - Exception in org.elasticsearch.indices
 
InvalidIndexNameException(Index, String, String) - Constructor for exception org.elasticsearch.indices.InvalidIndexNameException
 
InvalidTypeNameException - Exception in org.elasticsearch.index.mapper
 
InvalidTypeNameException(String) - Constructor for exception org.elasticsearch.index.mapper.InvalidTypeNameException
 
inverse() - Method in interface org.elasticsearch.util.collect.BiMap
Returns the inverse view of this bimap, which maps each of this bimap's values to its associated key.
inverse() - Method in class org.elasticsearch.util.collect.ImmutableBiMap
Returns the inverse view of this bimap, which maps each of this bimap's values to its associated key.
inverseGrep(TByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Searches the list for values which do not satisfy condition.
inverseGrep(TDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Searches the list for values which do not satisfy condition.
inverseGrep(TFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Searches the list for values which do not satisfy condition.
inverseGrep(TIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Searches the list for values which do not satisfy condition.
inverseGrep(TLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Searches the list for values which do not satisfy condition.
inverseGrep(TShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Searches the list for values which do not satisfy condition.
invertFrom(Multimap<? extends V, ? extends K>, M) - Static method in class org.elasticsearch.util.collect.Multimaps
Copies each key-value mapping in source into dest, with its key and value reversed.
invoke(String, Object[], String[]) - Method in class org.elasticsearch.jmx.ResourceDMBean
 
invoke(ForkJoinTask<T>) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Performs the given task, returning its result upon completion.
invoke() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Commences performing this task, awaits its completion if necessary, and return its result, or throws an (unchecked) exception if the underlying computation did so.
invokeAll(Collection<? extends Callable<T>>) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
 
invokeAll(ForkJoinTask<?>, ForkJoinTask<?>) - Static method in class org.elasticsearch.util.concurrent.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 org.elasticsearch.util.concurrent.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 org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Forks all tasks in the specified collection, returning when isDone holds for each task or an (unchecked) exception is encountered.
invokeListener(SearchResponse) - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
invokeListener(Throwable) - Method in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
IPv4_SETTING - Static variable in class org.elasticsearch.util.network.NetworkUtils
 
IPv6_SETTING - Static variable in class org.elasticsearch.util.network.NetworkUtils
 
isArray(Object) - Static method in class org.elasticsearch.util.xcontent.support.XContentMapValues
 
isBoostTerms() - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
isBroken() - Method in class org.elasticsearch.util.concurrent.ThreadBarrier
Queries if this barrier is in a broken state.
isCacheEnabled() - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectory
 
isCancelled() - Method in class org.elasticsearch.util.concurrent.AbstractFuture
 
isCancelled() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
 
isCancelled() - Method in interface org.elasticsearch.util.timer.Timeout
Returns true if and only if the TimerTask associated with this handle has been cancelled.
isClientNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
 
isCloseConnectionException(Throwable) - Static method in class org.elasticsearch.util.transport.NetworkExceptionHelper
 
isCompletedAbnormally() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Returns true if this task threw an exception or was cancelled.
isCompletedNormally() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Returns true if this task completed without throwing an exception and was not cancelled.
isConcrete(Class<?>) - Static method in class org.elasticsearch.util.Classes
 
isConnectException(Throwable) - Static method in class org.elasticsearch.util.transport.NetworkExceptionHelper
 
isConstant() - Method in class org.elasticsearch.util.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.util.inject.internal.ConstructionContext
 
isDataNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
Should this node hold data (shards) or not.
isDebugEnabled() - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
 
isDebugEnabled() - Method in interface org.elasticsearch.util.logging.ESLogger
Returns true if a DEBUG level message is logged.
isDebugEnabled() - Method in class org.elasticsearch.util.logging.jdk.JdkESLogger
 
isDebugEnabled() - Method in class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
isDebugEnabled() - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
isDeleted() - Method in class org.elasticsearch.util.lucene.IndexCommitDelegate
 
isDetected() - Static method in class org.elasticsearch.util.jline.ANSI
 
isDirect() - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectory
 
isDone() - Method in class org.elasticsearch.util.concurrent.AbstractFuture
 
isDone() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
 
isEagerSingleton(Stage) - Method in class org.elasticsearch.util.inject.internal.Scoping
Returns true if this scope is a singleton that should be loaded eagerly in stage.
isEmpty() - Method in class org.elasticsearch.index.mapper.FieldMappers
 
isEmpty() - Method in class org.elasticsearch.util.collect.ForwardingCollection
 
isEmpty() - Method in class org.elasticsearch.util.collect.ForwardingMap
 
isEmpty() - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
isEmpty() - Method in class org.elasticsearch.util.collect.ImmutableBiMap
 
isEmpty() - Method in class org.elasticsearch.util.collect.ImmutableCollection
 
isEmpty() - Method in class org.elasticsearch.util.collect.ImmutableMap
 
isEmpty() - Method in class org.elasticsearch.util.collect.ImmutableMultimap
 
isEmpty(Iterable<T>) - Static method in class org.elasticsearch.util.collect.Iterables
Determines if the given iterable contains no elements.
isEmpty() - Method in class org.elasticsearch.util.collect.LinkedListMultimap
 
isEmpty() - Method in interface org.elasticsearch.util.collect.Multimap
Returns true if the multimap contains no key-value pairs.
isEmpty() - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
isEmpty() - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Returns true if this map contains no key-value mappings.
isEmpty() - Method in class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
isEmpty() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Returns size() == 0.
isEmpty() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Returns size() == 0.
isEmpty() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Returns size() == 0.
isEmpty() - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
Returns true if this queue contains no elements.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteHashSetDecorator
Indicates whether set has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleHashSetDecorator
Indicates whether set has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatHashSetDecorator
Indicates whether set has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntHashSetDecorator
Indicates whether set has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongHashSetDecorator
Indicates whether set has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortHashSetDecorator
Indicates whether set has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Indicates whether map has any entries.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Tests whether this list contains any values.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Tests whether this list contains any values.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Tests whether this list contains any values.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.THash
Tells whether this set is currently holding any elements.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Tests whether this list contains any values.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Tests whether this list contains any values.
isEmpty() - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Tests whether this list contains any values.
isEmpty() - Method in class org.elasticsearch.util.IdentityHashSet
Returns true if this set contains no elements.
isEnabled() - Static method in class org.elasticsearch.util.jline.ANSI
 
isError(byte) - Static method in class org.elasticsearch.transport.Transport.Helper
 
isErrorEnabled() - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
 
isErrorEnabled() - Method in interface org.elasticsearch.util.logging.ESLogger
Returns true if an ERROR level message is logged.
isErrorEnabled() - Method in class org.elasticsearch.util.logging.jdk.JdkESLogger
 
isErrorEnabled() - Method in class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
isErrorEnabled() - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
isExists() - Method in class org.elasticsearch.action.get.GetResponse
Does the document exists.
isExpired() - Method in interface org.elasticsearch.util.timer.Timeout
Returns true if and only if the TimerTask associated with this handle has been expired.
isExplicitlyScoped() - Method in class org.elasticsearch.util.inject.internal.Scoping
Returns true if this scope was explicitly applied.
isFullySpecified() - Method in class org.elasticsearch.util.inject.internal.MoreTypes.GenericArrayTypeImpl
 
isFullySpecified() - Method in class org.elasticsearch.util.inject.internal.MoreTypes.ParameterizedTypeImpl
 
isFullySpecified() - Method in class org.elasticsearch.util.inject.internal.MoreTypes.WildcardTypeImpl
 
isInfoEnabled() - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
 
isInfoEnabled() - Method in interface org.elasticsearch.util.logging.ESLogger
Returns true if an INFO level message is logged.
isInfoEnabled() - Method in class org.elasticsearch.util.logging.jdk.JdkESLogger
 
isInfoEnabled() - Method in class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
isInfoEnabled() - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
isInnerClass(Class<?>) - Static method in class org.elasticsearch.util.Classes
 
isIPv4() - Static method in class org.elasticsearch.util.network.NetworkUtils
 
isManagedResource() - Method in class org.elasticsearch.jmx.ResourceDMBean
 
isNegativeQuery(Query) - Static method in class org.elasticsearch.util.lucene.search.Queries
 
isNoScope() - Method in class org.elasticsearch.util.inject.internal.Scoping
Returns true if this is the default scope.
isNull() - Static method in class org.elasticsearch.util.base.Predicates
Returns a predicate that evaluates to true if the object reference being tested is null.
isNullable() - Method in class org.elasticsearch.util.inject.spi.Dependency
Returns true if null is a legal value for this dependency.
isObject(Object) - Static method in class org.elasticsearch.util.xcontent.support.XContentMapValues
 
isOptimized() - Method in class org.elasticsearch.util.lucene.IndexCommitDelegate
 
isOptional() - Method in class org.elasticsearch.util.inject.spi.InjectionPoint
Returns true if this injection point shall be skipped if the injector cannot resolve bindings for all required dependencies.
isOrdered(Iterable<? extends T>) - Method in class org.elasticsearch.util.collect.Ordering
Returns true if each element in iterable after the first is greater than or equal to the element that preceded it, according to this ordering.
isPrimary() - Method in class org.elasticsearch.index.shard.IndexShardManagement
 
isPrimaryActive() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
isQuiescent() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Returns true if all worker threads are currently idle.
isReleasable() - Method in interface org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool.ManagedBlocker
Returns true if blocking is unnecessary.
isRequest(byte) - Static method in class org.elasticsearch.transport.Transport.Helper
 
isRetainedAtRuntime(Class<? extends Annotation>) - Static method in class org.elasticsearch.util.inject.internal.Annotations
Returns true if the given annotation is retained at runtime.
isRunning() - Method in class org.elasticsearch.util.StopWatch
Return whether the stop watch is currently running.
isScopeAnnotation(Class<? extends Annotation>) - Static method in class org.elasticsearch.util.inject.internal.Annotations
 
isShutdown() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Returns true if this pool has been shut down.
isShutdown() - Method in class org.elasticsearch.util.concurrent.ScalingThreadPoolExecutor
 
isStackAvailable(boolean) - Static method in class org.elasticsearch.util.network.NetworkUtils
 
isStarted() - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
isStarted() - Method in interface org.elasticsearch.threadpool.ThreadPool
Returns true if the thread pool has started.
isStrictlyOrdered(Iterable<? extends T>) - Method in class org.elasticsearch.util.collect.Ordering
Returns true if each element in iterable after the first is strictly greater than the element that preceded it, according to this ordering.
isSynthetic() - Method in class org.elasticsearch.util.inject.internal.MoreTypes.MemberImpl
 
isTerminated() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Returns true if all tasks have completed following shut down.
isTerminated() - Method in class org.elasticsearch.util.concurrent.jsr166y.Phaser
Returns true if this barrier has been terminated.
isTerminated() - Method in class org.elasticsearch.util.concurrent.ScalingThreadPoolExecutor
 
isTerminating() - Method in class org.elasticsearch.util.concurrent.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
 
isTraceEnabled() - Method in interface org.elasticsearch.util.logging.ESLogger
Returns true if a TRACE level message is logged.
isTraceEnabled() - Method in class org.elasticsearch.util.logging.jdk.JdkESLogger
 
isTraceEnabled() - Method in class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
isTraceEnabled() - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
isUseCompoundFile() - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy.MergePolicyParams
 
isValue() - Method in enum org.elasticsearch.util.xcontent.XContentParser.Token
 
isWarnEnabled() - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
 
isWarnEnabled() - Method in interface org.elasticsearch.util.logging.ESLogger
Returns true if a WARN level message is logged.
isWarnEnabled() - Method in class org.elasticsearch.util.logging.jdk.JdkESLogger
 
isWarnEnabled() - Method in class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
isWarnEnabled() - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
isWildcard() - Method in class org.elasticsearch.util.path.PathTrie.TrieNode
 
Iterables - Class in org.elasticsearch.util.collect
This class contains static utility methods that operate on or return objects of type Iterable.
iterate(PortsRange.PortCallback) - Method in class org.elasticsearch.util.transport.PortsRange
 
iterator() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
 
iterator() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
iterator() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.GatewaySnapshotResponse
 
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.deletebyquery.DeleteByQueryResponse
 
iterator() - Method in class org.elasticsearch.action.get.GetField
 
iterator() - Method in class org.elasticsearch.action.get.GetResponse
 
iterator() - Method in class org.elasticsearch.action.support.nodes.NodesOperationResponse
 
iterator() - Method in class org.elasticsearch.action.terms.FieldTermsFreq
 
iterator() - Method in class org.elasticsearch.action.terms.TermsResponse
Iterates over the FieldTermsFreq.
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.PlainShardsIterator
 
iterator() - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
iterator() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
iterator() - Method in class org.elasticsearch.cluster.routing.RoutingTable
 
iterator() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotIndexCommits
 
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.service.InternalIndexService
 
iterator() - Method in class org.elasticsearch.index.translog.memory.MemorySnapshot
 
iterator() - Method in class org.elasticsearch.indices.InternalIndicesService
 
iterator() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollectors
 
iterator() - Method in class org.elasticsearch.search.facets.Facets
Iterates over the Facets.
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.util.collect.ForwardingCollection
 
iterator() - Method in class org.elasticsearch.util.collect.ImmutableCollection
Returns an unmodifiable iterator across the elements in this collection.
iterator() - Method in class org.elasticsearch.util.collect.ImmutableList
 
iterator() - Method in class org.elasticsearch.util.collect.ImmutableMultiset
 
iterator() - Method in class org.elasticsearch.util.collect.ImmutableSet
 
iterator() - Method in interface org.elasticsearch.util.collect.Multiset
iterator() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashSet
 
iterator() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingSetInt
Standard Java Iterator.
iterator() - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
Returns an iterator over the elements in this queue in proper sequence, from head to tail.
iterator() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteHashSetDecorator
Creates an iterator over the values of the set.
iterator() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleHashSetDecorator
Creates an iterator over the values of the set.
iterator() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatHashSetDecorator
Creates an iterator over the values of the set.
iterator() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntHashSetDecorator
Creates an iterator over the values of the set.
iterator() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongHashSetDecorator
Creates an iterator over the values of the set.
iterator() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortHashSetDecorator
Creates an iterator over the values of the set.
iterator() - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TByteHashSet
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TDoubleHashSet
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TFloatHashSet
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.THashMap.EntryView
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.THashMap.KeyView
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.THashMap.ValueView
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.THashSet
Creates an iterator over the values of the set.
iterator() - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TIntHashSet
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TLongHashSet
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TShortHashSet
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
 
iterator() - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
 
iterator() - Method in class org.elasticsearch.util.IdentityHashSet
Returns an iterator over the elements in this set.
iterator() - Method in class org.elasticsearch.util.MapBackedSet
 
iterators() - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
 
Iterators - Class in org.elasticsearch.util.collect
This class contains static utility methods that operate on or return objects of type Iterator.
itoa(int) - Static method in class org.elasticsearch.util.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

javax.annotation - package javax.annotation
 
JdkESLogger - Class in org.elasticsearch.util.logging.jdk
 
JdkESLogger(String, Logger) - Constructor for class org.elasticsearch.util.logging.jdk.JdkESLogger
 
JdkESLoggerFactory - Class in org.elasticsearch.util.logging.jdk
 
JdkESLoggerFactory() - Constructor for class org.elasticsearch.util.logging.jdk.JdkESLoggerFactory
 
JLinePatternLayout - Class in org.elasticsearch.util.logging.log4j
 
JLinePatternLayout() - Constructor for class org.elasticsearch.util.logging.log4j.JLinePatternLayout
 
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
 
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.util.joda
 
Joda() - Constructor for class org.elasticsearch.util.joda.Joda
 
join(Iterable<?>) - Method in class org.elasticsearch.util.base.Joiner
Returns a string containing the string representation of each of parts, using the previously configured separator between each.
join(Object[]) - Method in class org.elasticsearch.util.base.Joiner
Returns a string containing the string representation of each of parts, using the previously configured separator between each.
join(Object, Object, Object...) - Method in class org.elasticsearch.util.base.Joiner
Returns a string containing the string representation of each argument, using the previously configured separator between each.
join(Map<?, ?>) - Method in class org.elasticsearch.util.base.Joiner.MapJoiner
Returns a string containing the string representation of each entry of map, using the previously configured separator and key-value separator.
join() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Returns the result of the computation when it is done.
Join - Class in org.elasticsearch.util.inject.internal
Utility for joining pieces of text separated by a delimiter.
join(String, Iterable<?>) - Static method in class org.elasticsearch.util.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.util.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.util.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.util.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.util.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.util.inject.internal.Join
Appends each of the tokens to appendable, separated by delimiter.
join(T, String, Object[]) - Static method in class org.elasticsearch.util.inject.internal.Join
Appends each of the tokens to appendable, separated by delimiter.
join(T, String, Object, Object...) - Static method in class org.elasticsearch.util.inject.internal.Join
Appends each of the tokens to appendable, separated by delimiter.
join(T, String, Iterator<?>) - Static method in class org.elasticsearch.util.inject.internal.Join
Appends each of the tokens to appendable, separated by delimiter.
join(T, String, String, Map<?, ?>) - Static method in class org.elasticsearch.util.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.util.inject.internal
Exception thrown in response to an IOException from the supplied Appendable.
Joiner - Class in org.elasticsearch.util.base
An object which joins pieces of text (specified as an array, Iterable, varargs or even a Map) with a separator.
Joiner.MapJoiner - Class in org.elasticsearch.util.base
An object that joins map entries in the same manner as Joiner joins iterables and arrays.
jsonBuilder() - Static method in class org.elasticsearch.util.xcontent.XContentFactory
Returns a binary content builder using JSON format (XContentType.JSON.
JsonSettingsLoader - Class in org.elasticsearch.util.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.util.settings.loader.JsonSettingsLoader
 
JsonXContent - Class in org.elasticsearch.util.xcontent.json
A JSON based content implementation using Jackson.
JsonXContent() - Constructor for class org.elasticsearch.util.xcontent.json.JsonXContent
 
JsonXContent.CachedBinaryBuilder - Class in org.elasticsearch.util.xcontent.json
 
JsonXContent.CachedBinaryBuilder() - Constructor for class org.elasticsearch.util.xcontent.json.JsonXContent.CachedBinaryBuilder
 
JsonXContent.CachedTextBuilder - Class in org.elasticsearch.util.xcontent.json
 
JsonXContent.CachedTextBuilder() - Constructor for class org.elasticsearch.util.xcontent.json.JsonXContent.CachedTextBuilder
 
JsonXContentGenerator - Class in org.elasticsearch.util.xcontent.json
 
JsonXContentGenerator(JsonGenerator) - Constructor for class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
JsonXContentParser - Class in org.elasticsearch.util.xcontent.json
 
JsonXContentParser(JsonParser) - Constructor for class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
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.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.GarbageCollector - Class in org.elasticsearch.monitor.jvm
 
JvmStats.GarbageCollectors - Class in org.elasticsearch.monitor.jvm
 
JvmStats.Mem - Class in org.elasticsearch.monitor.jvm
 
JvmStats.Threads - Class in org.elasticsearch.monitor.jvm
 

K

kb() - Method in class org.elasticsearch.util.SizeValue
 
kbFrac() - Method in class org.elasticsearch.util.SizeValue
 
keepAlive() - Method in class org.elasticsearch.search.internal.SearchContext
 
keepAlive(TimeValue) - 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.
keepAliveTimeout(Timeout) - Method in class org.elasticsearch.search.internal.SearchContext
 
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.util.StopWatch
Determine whether the TaskInfo array is built over time.
key() - Method in class org.elasticsearch.util.gnu.trove.TByteByteIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TByteFloatIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TByteIntIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TByteLongIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TByteObjectIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TByteShortIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TFloatByteIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TFloatIntIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TFloatLongIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TFloatShortIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TIntByteIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TIntFloatIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TIntIntIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TIntLongIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TIntObjectIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TIntShortIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TLongByteIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TLongFloatIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TLongIntIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TLongLongIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TLongObjectIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TLongShortIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TObjectByteIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TObjectIntIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TObjectLongIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TObjectShortIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TShortByteIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TShortFloatIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TShortIntIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TShortLongIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TShortObjectIterator
Provides access to the key of the mapping at the iterator's position.
key() - Method in class org.elasticsearch.util.gnu.trove.TShortShortIterator
Provides access to the key of the mapping at the iterator's position.
Key<T> - Class in org.elasticsearch.util.inject
Binding key consisting of an injection type and an optional annotation.
Key(Class<? extends Annotation>) - Constructor for class org.elasticsearch.util.inject.Key
Constructs a new key.
Key(Annotation) - Constructor for class org.elasticsearch.util.inject.Key
Constructs a new key.
Key() - Constructor for class org.elasticsearch.util.inject.Key
Constructs a new key.
keyComparator() - Method in class org.elasticsearch.util.collect.TreeMultimap
Returns the comparator that orders the multimap keys.
keyForEntry(Map.Entry<K, V>) - Method in class org.elasticsearch.util.gnu.trove.THashMap.EntryView
 
keys() - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
keys() - Method in class org.elasticsearch.util.collect.ImmutableMultimap
Returns a collection, which may contain duplicates, of all keys.
keys() - Method in class org.elasticsearch.util.collect.LinkedListMultimap
 
keys() - Method in interface org.elasticsearch.util.collect.Multimap
Returns a collection, which may contain duplicates, of all keys.
keys() - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
keys() - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Returns an enumeration of the keys in this table.
keys() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Returns an enumeration of the keys in this table.
keys() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Returns an enumeration of the auto-boxed keys in this table.
keys() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Returns an enumeration of the keys in this table.
keys() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Returns an enumeration of the keys in this table.
keys() - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
returns the keys of the map.
keys(byte[]) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
returns the keys of the map.
keys(byte[]) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
returns the keys of the map.
keys(byte[]) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
returns the keys of the map.
keys(byte[]) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
returns the keys of the map.
keys(byte[]) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
returns the keys of the map.
keys(byte[]) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
returns the keys of the map.
keys(byte[]) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
returns the keys of the map.
keys(double[]) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
returns the keys of the map.
keys(double[]) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
returns the keys of the map.
keys(double[]) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
returns the keys of the map.
keys(double[]) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
returns the keys of the map.
keys(double[]) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
returns the keys of the map.
keys(double[]) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
returns the keys of the map.
keys(double[]) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
returns the keys of the map.
keys(float[]) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
returns the keys of the map.
keys(float[]) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
returns the keys of the map.
keys(float[]) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
returns the keys of the map.
keys(float[]) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
returns the keys of the map.
keys(float[]) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
returns the keys of the map.
keys(float[]) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
returns the keys of the map.
keys(float[]) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
returns the keys of the map.
keys(int[]) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
returns the keys of the map.
keys(int[]) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
returns the keys of the map.
keys(int[]) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
returns the keys of the map.
keys(int[]) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
returns the keys of the map.
keys(int[]) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
returns the keys of the map.
keys(int[]) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
returns the keys of the map.
keys(int[]) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
returns the keys of the map.
keys(long[]) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
returns the keys of the map.
keys(long[]) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
returns the keys of the map.
keys(long[]) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
returns the keys of the map.
keys(long[]) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
returns the keys of the map.
keys(long[]) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
returns the keys of the map.
keys(long[]) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
returns the keys of the map.
keys(long[]) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
returns the keys of the map.
keys(K[]) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
returns the keys of the map.
keys(K[]) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
returns the keys of the map.
keys(K[]) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
returns the keys of the map.
keys(K[]) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
returns the keys of the map.
keys(K[]) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
returns the keys of the map.
keys(K[]) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
returns the keys of the map.
keys(short[]) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
returns the keys of the map.
keys(short[]) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
returns the keys of the map.
keys(short[]) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
returns the keys of the map.
keys(short[]) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
returns the keys of the map.
keys(short[]) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
returns the keys of the map.
keys(short[]) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
returns the keys of the map.
keys() - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
returns the keys of the map.
keys(short[]) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
returns the keys of the map.
keySet() - Method in class org.elasticsearch.util.collect.ForwardingMap
 
keySet() - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
keySet() - Method in class org.elasticsearch.util.collect.ImmutableBiMap
 
keySet() - Method in class org.elasticsearch.util.collect.ImmutableMap
Returns an immutable set of the keys in this map.
keySet() - Method in class org.elasticsearch.util.collect.ImmutableMultimap
Returns an immutable set of the distinct keys in this multimap.
keySet() - Method in class org.elasticsearch.util.collect.ImmutableSortedMap
Returns an immutable sorted set of the keys in this map.
keySet() - Method in class org.elasticsearch.util.collect.LinkedListMultimap
 
keySet() - Method in interface org.elasticsearch.util.collect.Multimap
Returns the set of all keys, each appearing once in the returned set.
keySet() - Method in class org.elasticsearch.util.collect.TreeMultimap
Returns the set of all keys, each appearing once in the returned set.
keySet() - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
keySet() - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Returns a Set view of the keys contained in this map.
keySet() - Method in class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
keySet() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Returns a Set view of the keys contained in this map.
keySet() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Returns a Set view of the keys contained in this map; with care the keys may be iterated over without auto-boxing.
keySet() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Returns a Set view of the keys contained in this map.
keySet() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Returns a Set view of the keys contained in this map.
keySet() - Method in class org.elasticsearch.util.gnu.trove.THashMap
returns a Set view on the keys of the map.
keyType() - Method in class org.elasticsearch.util.collect.EnumBiMap
Returns the associated key type.
keyType() - Method in class org.elasticsearch.util.collect.EnumHashBiMap
Returns the associated key type.
keyTypeIsSet() - Method in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
KEYWORD_ANALYZER - Static variable in class org.elasticsearch.util.lucene.Lucene
 
KeywordAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
KeywordAnalyzerProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.KeywordAnalyzerProvider
 
KeywordTokenizerFactory - Class in org.elasticsearch.index.analysis
 
KeywordTokenizerFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.KeywordTokenizerFactory
 

L

largestPrime - Static variable in class org.elasticsearch.util.gnu.trove.PrimeFinder
The largest prime this class can generate; currently equal to Integer.MAX_VALUE.
last() - Method in class org.elasticsearch.util.collect.ForwardingSortedSet
 
lastAccessTime() - Method in class org.elasticsearch.search.internal.SearchContext
 
lastIndexOf(Object) - Method in class org.elasticsearch.util.collect.ForwardingList
 
lastIndexOf(Object) - Method in class org.elasticsearch.util.collect.ImmutableList
 
lastIndexOf(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Searches the list back to front for the last index of value.
lastIndexOf(int, byte) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Searches the list back to front for the last index of value, starting at offset.
lastIndexOf(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Searches the list back to front for the last index of value.
lastIndexOf(int, double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Searches the list back to front for the last index of value, starting at offset.
lastIndexOf(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Searches the list back to front for the last index of value.
lastIndexOf(int, float) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Searches the list back to front for the last index of value, starting at offset.
lastIndexOf(int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Searches the list back to front for the last index of value.
lastIndexOf(int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Searches the list back to front for the last index of value, starting at offset.
lastIndexOf(long) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Searches the list back to front for the last index of value.
lastIndexOf(int, long) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Searches the list back to front for the last index of value, starting at offset.
lastIndexOf(short) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Searches the list back to front for the last index of value.
lastIndexOf(int, short) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Searches the list back to front for the last index of value, starting at offset.
lastIndexVersion() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.Snapshot
 
lastKey() - Method in class org.elasticsearch.util.collect.ForwardingSortedMap
 
lastKey() - Method in class org.elasticsearch.util.collect.ImmutableSortedMap
 
lastTaskName() - Method in class org.elasticsearch.util.StopWatch
Return the name of the last task.
lastTaskTime() - Method in class org.elasticsearch.util.StopWatch
Return the time taken by the last task.
lastTranslogId() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.Snapshot
 
lastTranslogSize() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.Snapshot
 
leftValue() - Method in interface org.elasticsearch.util.collect.MapDifference.ValueDifference
Returns the value from the left map (possibly null).
length() - Method in class org.elasticsearch.index.store.memory.ByteBufferIndexInput
 
length() - Method in class org.elasticsearch.index.store.memory.ByteBufferIndexOutput
 
length() - Method in class org.elasticsearch.index.store.memory.HeapIndexInput
 
length() - Method in class org.elasticsearch.index.store.memory.HeapIndexOutput
 
length() - Method in class org.elasticsearch.util.io.compression.lzf.LZFChunk
 
length() - Method in class org.elasticsearch.util.io.FastStringReader
 
length() - Method in class org.elasticsearch.util.lucene.analysis.CharSequenceTermAttribute
 
length - Variable in class org.elasticsearch.util.Unicode.UTF16Result
 
LengthTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
LengthTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.LengthTokenFilterFactory
 
lessThan(ScoreDoc, ScoreDoc) - Method in class org.elasticsearch.search.controller.ScoreDocQueue
 
LetterTokenizerFactory - Class in org.elasticsearch.index.analysis
 
LetterTokenizerFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.LetterTokenizerFactory
 
lifecycle - Variable in class org.elasticsearch.util.component.AbstractLifecycleComponent
 
Lifecycle - Class in org.elasticsearch.util.component
Lifecycle state.
Lifecycle() - Constructor for class org.elasticsearch.util.component.Lifecycle
 
Lifecycle.State - Enum in org.elasticsearch.util.component
 
LifecycleComponent<T> - Interface in org.elasticsearch.util.component
 
LifecycleListener - Interface in org.elasticsearch.util.component
 
lifecycleState() - Method in class org.elasticsearch.util.component.AbstractLifecycleComponent
 
lifecycleState() - Method in interface org.elasticsearch.util.component.LifecycleComponent
 
likeText(String) - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisFieldQueryBuilder
The text to use in order to find documents that are "like" this.
likeText(String) - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisQueryBuilder
The text to use in order to find documents that are "like" this.
likeText(String) - Method in class org.elasticsearch.index.query.xcontent.MoreLikeThisFieldQueryBuilder
The text to use in order to find documents that are "like" this.
likeText(String) - Method in class org.elasticsearch.index.query.xcontent.MoreLikeThisQueryBuilder
The text to use in order to find documents that are "like" this.
LinkedBindingBuilder<T> - Interface in org.elasticsearch.util.inject.binder
See the EDSL examples at Binder.
LinkedBindingImpl<T> - Class in org.elasticsearch.util.inject.internal
 
LinkedBindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping, Key<? extends T>) - Constructor for class org.elasticsearch.util.inject.internal.LinkedBindingImpl
 
LinkedBindingImpl(Object, Key<T>, Scoping, Key<? extends T>) - Constructor for class org.elasticsearch.util.inject.internal.LinkedBindingImpl
 
LinkedHashMultimap<K,V> - Class in org.elasticsearch.util.collect
Implementation of Multimap that does not allow duplicate key-value entries and that returns collections whose iterators follow the ordering in which the data was added to the multimap.
LinkedHashMultiset<E> - Class in org.elasticsearch.util.collect
A Multiset implementation with predictable iteration order.
LinkedKeyBinding<T> - Interface in org.elasticsearch.util.inject.spi
A binding to a linked key.
LinkedListMultimap<K,V> - Class in org.elasticsearch.util.collect
An implementation of ListMultimap that supports deterministic iteration order for both keys and values.
LinkedProviderBindingImpl<T> - Class in org.elasticsearch.util.inject.internal
 
LinkedProviderBindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping, Key<? extends Provider<? extends T>>) - Constructor for class org.elasticsearch.util.inject.internal.LinkedProviderBindingImpl
 
LinkedTransferQueue<E> - Class in org.elasticsearch.util.concurrent.jsr166y
An unbounded TransferQueue based on linked nodes.
LinkedTransferQueue() - Constructor for class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
Creates an initially empty LinkedTransferQueue.
LinkedTransferQueue(Collection<? extends E>) - Constructor for class org.elasticsearch.util.concurrent.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.util.OsUtils
True iff running on Linux.
listAll() - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectory
 
listAll() - Method in class org.elasticsearch.index.store.memory.HeapDirectory
 
listAll() - Method in class org.elasticsearch.util.lucene.store.SwitchDirectory
 
listCommits(Directory) - Static method in class org.elasticsearch.util.lucene.Directories
Lists all the commit point in a directory.
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.xcontent.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.ping.broadcast.BroadcastPingRequest
 
listenerThreaded(boolean) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.ReplicationPingRequest
 
listenerThreaded(boolean) - Method in class org.elasticsearch.action.admin.cluster.ping.single.SinglePingRequest
 
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.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.get.GetRequest
Should the listener be called on a separate thread if needed.
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.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() - 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.SingleOperationRequest
Should the listener be called on a separate thread if needed.
listenerThreaded(boolean) - Method in class org.elasticsearch.action.support.single.SingleOperationRequest
 
listIterator() - Method in class org.elasticsearch.util.collect.ForwardingList
 
listIterator(int) - Method in class org.elasticsearch.util.collect.ForwardingList
 
listIterator(int) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Returns an iterator positioned at index.
ListMultimap<K,V> - Interface in org.elasticsearch.util.collect
A Multimap that can hold duplicate key-value pairs and that maintains the insertion ordering of values for a given key.
listOf(Type) - Static method in class org.elasticsearch.util.inject.util.Types
Returns a type modelling a List whose elements are of type elementType.
Lists - Class in org.elasticsearch.util.collect
Static utility methods pertaining to List instances.
load(String) - Method in class org.elasticsearch.util.settings.loader.JsonSettingsLoader
 
load(byte[]) - Method in class org.elasticsearch.util.settings.loader.JsonSettingsLoader
 
load(XContentParser) - Method in class org.elasticsearch.util.settings.loader.JsonSettingsLoader
 
load(String) - Method in class org.elasticsearch.util.settings.loader.PropertiesSettingsLoader
 
load(byte[]) - Method in class org.elasticsearch.util.settings.loader.PropertiesSettingsLoader
 
load(String) - Method in interface org.elasticsearch.util.settings.loader.SettingsLoader
Loads (parses) the settings from a source string.
load(byte[]) - Method in interface org.elasticsearch.util.settings.loader.SettingsLoader
Loads (parses) the settings from a source bytes.
load(String) - Method in class org.elasticsearch.util.settings.loader.YamlSettingsLoader
 
load(byte[]) - Method in class org.elasticsearch.util.settings.loader.YamlSettingsLoader
 
loadAverage() - Method in class org.elasticsearch.monitor.os.OsStats
 
loadClass(String) - Method in class org.elasticsearch.util.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.
loaderFromResource(String) - Static method in class org.elasticsearch.util.settings.loader.SettingsLoaderFactory
Returns a SettingsLoader based on the resource name.
loaderFromSource(String) - Static method in class org.elasticsearch.util.settings.loader.SettingsLoaderFactory
Returns a SettingsLoader based on the actual settings source.
loadFromClasspath(String) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Loads settings from classpath that represents them using the SettingsLoaderFactory.loaderFromSource(String).
loadFromSource(String) - Method in class org.elasticsearch.util.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.util.settings.ImmutableSettings.Builder
Loads settings from a stream that represents them using the SettingsLoaderFactory.loaderFromSource(String).
loadFromUrl(URL) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Loads settings from a url that represents them using the SettingsLoaderFactory.loaderFromSource(String).
local(boolean) - Method in class org.elasticsearch.node.NodeBuilder
Is the node a local node.
LOCAL - Static variable in class org.elasticsearch.util.network.NetworkService
 
LocalDiscovery - Class in org.elasticsearch.discovery.local
 
LocalDiscovery(Settings, ClusterName, TransportService, ClusterService) - Constructor for class org.elasticsearch.discovery.local.LocalDiscovery
 
LocalDiscoveryModule - Class in org.elasticsearch.discovery.local
 
LocalDiscoveryModule() - Constructor for class org.elasticsearch.discovery.local.LocalDiscoveryModule
 
localNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
localNodeId(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
 
localNodeId() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
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.
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.util.transport
 
LocalTransportAddress(String) - Constructor for class org.elasticsearch.util.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() - Constructor for class org.elasticsearch.transport.local.LocalTransportModule
 
location() - Method in class org.elasticsearch.monitor.dump.DumpGenerator.Result
 
Log4jESLogger - Class in org.elasticsearch.util.logging.log4j
 
Log4jESLogger(String, Logger) - Constructor for class org.elasticsearch.util.logging.log4j.Log4jESLogger
 
Log4jESLoggerFactory - Class in org.elasticsearch.util.logging.log4j
 
Log4jESLoggerFactory() - Constructor for class org.elasticsearch.util.logging.log4j.Log4jESLoggerFactory
 
LogByteSizeMergePolicyProvider - Class in org.elasticsearch.index.merge.policy
 
LogByteSizeMergePolicyProvider(Store) - Constructor for class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider
 
LogConfigurator - Class in org.elasticsearch.util.logging.log4j
 
LogConfigurator() - Constructor for class org.elasticsearch.util.logging.log4j.LogConfigurator
 
LogDocMergePolicyProvider - Class in org.elasticsearch.index.merge.policy
 
LogDocMergePolicyProvider(Store) - Constructor for class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider
 
logger - Variable in class org.elasticsearch.index.AbstractIndexComponent
 
logger - Variable in class org.elasticsearch.index.shard.AbstractIndexShardComponent
 
logger - Variable in class org.elasticsearch.util.component.AbstractComponent
 
LoggerInfoStream - Class in org.elasticsearch.util.lucene
A PrintStream that logs each LoggerInfoStream.println(String) into a logger under trace level.
LoggerInfoStream(ESLogger) - Constructor for class org.elasticsearch.util.lucene.LoggerInfoStream
Constucts a new instance based on the provided logger.
LoggerMessageFormat - Class in org.elasticsearch.util.logging.support
 
LoggerMessageFormat() - Constructor for class org.elasticsearch.util.logging.support.LoggerMessageFormat
 
Loggers - Class in org.elasticsearch.util.logging
A set of utilities around Logging.
Loggers() - Constructor for class org.elasticsearch.util.logging.Loggers
 
logsFile() - Method in class org.elasticsearch.env.Environment
 
longField(String) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
LongStreamable - Class in org.elasticsearch.util.io.stream
 
LongStreamable() - Constructor for class org.elasticsearch.util.io.stream.LongStreamable
 
LongStreamable(long) - Constructor for class org.elasticsearch.util.io.stream.LongStreamable
 
longToBytes(long) - Static method in class org.elasticsearch.util.Numbers
Converts a long to a byte array.
longValue() - Method in class org.elasticsearch.util.concurrent.highscalelib.ConcurrentAutoTable
Same as ConcurrentAutoTable.get(), included for completeness.
longValue() - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentParser
 
longValue() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
lowercaseExpandedTerms(boolean) - Method in class org.elasticsearch.index.query.xcontent.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.xcontent.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.action.terms.TermsRequest
Lower then (like setting to with toInclusive set to false)
lt(String) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The to part of the filter query.
lt(int) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The to part of the filter query.
lt(long) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The to part of the filter query.
lt(float) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The to part of the filter query.
lt(double) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The to part of the filter query.
lt(String) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
lt(Object) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
lt(int) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
lt(long) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
lt(float) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
lt(double) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
lte(Object) - Method in class org.elasticsearch.action.terms.TermsRequest
Lower/equal then (like setting to with toInclusive set to false)
lte(String) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The to part of the filter query.
lte(int) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The to part of the filter query.
lte(long) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The to part of the filter query.
lte(float) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The to part of the filter query.
lte(double) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The to part of the filter query.
lte(String) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
lte(Object) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
lte(int) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
lte(long) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
lte(float) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
lte(double) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
ltoa(long) - Static method in class org.elasticsearch.util.Bytes
 
Lucene - Class in org.elasticsearch.util.lucene
 
Lucene.CountCollector - Class in org.elasticsearch.util.lucene
 
Lucene.CountCollector(float) - Constructor for class org.elasticsearch.util.lucene.Lucene.CountCollector
 
LZFChunk - Class in org.elasticsearch.util.io.compression.lzf
Helper class used to store LZF encoded segments (compressed and non-compressed) that can be sequenced to produce LZF files/streams.
LzfCompressor - Class in org.elasticsearch.util.io.compression
 
LzfCompressor() - Constructor for class org.elasticsearch.util.io.compression.LzfCompressor
 
LZFDecoder - Class in org.elasticsearch.util.io.compression.lzf
Decoder that handles decoding of sequence of encoded LZF chunks, combining them into a single contiguous result byte array
LZFEncoder - Class in org.elasticsearch.util.io.compression.lzf
Encoder that handles splitting of input into chunks to encode, calls ChunkEncoder to compress individual chunks and combines resulting chunks into contiguous output byte array.

M

macAddress() - Method in class org.elasticsearch.monitor.network.NetworkInfo.Interface
 
MAGENTA - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
main(String[]) - Static method in class org.elasticsearch.bootstrap.Bootstrap
 
main(String[]) - Static method in class org.elasticsearch.node.internal.InternalNode
 
main(String[]) - Static method in class org.elasticsearch.plugins.PluginManager
 
main(String[]) - Static method in class org.elasticsearch.Version
 
MAIN_INDEX_SUFFIX - Static variable in class org.elasticsearch.index.store.fs.FsStores
 
makeComputingMap(Function<? super K, ? extends V>) - Method in class org.elasticsearch.util.collect.MapMaker
Builds a map that supports atomic, on-demand computation of values.
makeKeySafe(TypeLiteral<T>) - Static method in class org.elasticsearch.util.inject.internal.MoreTypes
Returns an equivalent type that's safe for use in a key.
makeMap() - Method in class org.elasticsearch.util.collect.MapMaker
Builds the final map, without on-demand computation of values.
ManagedAttribute - Annotation Type in org.elasticsearch.jmx
 
managedBlock(ForkJoinPool.ManagedBlocker, boolean) - Static method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Blocks in accord with the given blocker.
ManagedGroupName - Annotation Type in org.elasticsearch.jmx
 
ManagedOperation - Annotation Type in org.elasticsearch.jmx
 
managementGroupName() - Method in class org.elasticsearch.index.shard.AbstractIndexShardComponent
 
map() - Method in class org.elasticsearch.util.MapBuilder
 
map(Map<String, Object>) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
map() - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentParser
 
map() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
MapBackedSet<E> - Class in org.elasticsearch.util
 
MapBackedSet(Map<E, Boolean>) - Constructor for class org.elasticsearch.util.MapBackedSet
Creates a new instance which wraps the specified map.
MapBinder<K,V> - Class in org.elasticsearch.util.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.util
 
MapBuilder() - Constructor for class org.elasticsearch.util.MapBuilder
 
MapDifference<K,V> - Interface in org.elasticsearch.util.collect
An object representing the differences between two maps.
MapDifference.ValueDifference<V> - Interface in org.elasticsearch.util.collect
A difference between the mappings from two maps with the same key.
MapMaker - Class in org.elasticsearch.util.collect
A ConcurrentMap builder, providing any combination of these features: soft or weak keys, soft or weak values, timed expiration, and on-demand computation of values.
MapMaker() - Constructor for class org.elasticsearch.util.collect.MapMaker
Constructs a new MapMaker instance with default settings, including strong keys, strong values, and no automatic expiration.
mapOf(Type, Type) - Static method in class org.elasticsearch.util.inject.util.Types
Returns a type modelling a Map whose keys are of type keyType and whose values are of type valueType.
mapper() - Method in class org.elasticsearch.index.mapper.FieldMappers
 
mapper() - Method in class org.elasticsearch.index.mapper.MapperService.SmartNameFieldMappers
The first mapper for the smart named field.
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.elasticsearch.index.query.support
A query parser that uses the MapperService in order to build smarter queries based on the mapping information.
MapperQueryParser(String, Analyzer, MapperService, IndexCache) - Constructor for class org.elasticsearch.index.query.support.MapperQueryParser
 
mappers() - Method in interface org.elasticsearch.index.mapper.DocumentMapper
 
mappers() - Method in class org.elasticsearch.index.mapper.FieldMappers
 
mappers() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
mappers() - Method in class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper
 
mappersAdded() - Method in class org.elasticsearch.index.mapper.ParsedDocument
Has the parsed document caused for new mappings to be added.
mappersAdded() - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
 
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.xcontent.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.SmartNameFieldMappers - Class in org.elasticsearch.index.mapper
 
MapperService.SmartNameFieldMappers(FieldMappers, DocumentMapper) - Constructor for class org.elasticsearch.index.mapper.MapperService.SmartNameFieldMappers
 
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) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
mappings() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
mappingSource() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction.MappingUpdatedRequest
 
mappingSource() - Method in interface org.elasticsearch.index.mapper.DocumentMapper
When constructed by parsing a mapping definition, will return it.
mappingSource(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper.Builder
 
mappingSource() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
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, MetaDataService) - Constructor for class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
MappingUpdatedAction.MappingUpdatedRequest - Class in org.elasticsearch.cluster.action.index
 
MappingUpdatedAction.MappingUpdatedRequest(String, String, String) - 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
 
Maps - Class in org.elasticsearch.util.collect
Static utility methods pertaining to Map instances.
mark - Variable in class org.elasticsearch.util.io.FastByteArrayInputStream
The currently marked position in the stream.
mark(int) - Method in class org.elasticsearch.util.io.FastByteArrayInputStream
Set the current marked position in the stream.
mark(int) - Method in class org.elasticsearch.util.io.FastCharArrayReader
Marks the present position in the stream.
mark(int) - Method in class org.elasticsearch.util.io.FastStringReader
Marks the present position in the stream.
markedPos - Variable in class org.elasticsearch.util.io.FastCharArrayReader
The position of mark in buffer.
markForClose() - Method in interface org.elasticsearch.util.concurrent.resource.AcquirableResource
Marks the resource to be closed.
markForClose() - Method in class org.elasticsearch.util.concurrent.resource.BlockingAcquirableResource
Marks the resource to be closed.
markForClose() - Method in class org.elasticsearch.util.concurrent.resource.NonBlockingAcquirableResource
 
markSupported() - Method in class org.elasticsearch.util.io.FastByteArrayInputStream
Tests if this InputStream supports mark/reset.
markSupported() - Method in class org.elasticsearch.util.io.FastCharArrayReader
Tells whether this stream supports the mark() operation, which it does.
markSupported() - Method in class org.elasticsearch.util.io.FastStringReader
Tells whether this stream supports the mark() operation, which it does.
master() - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
 
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() - 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
 
masterOperation(ClusterHealthRequest) - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
 
masterOperation(ClusterStateRequest) - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
 
masterOperation(IndicesAliasesRequest) - Method in class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
 
masterOperation(CreateIndexRequest) - Method in class org.elasticsearch.action.admin.indices.create.TransportCreateIndexAction
 
masterOperation(DeleteIndexRequest) - Method in class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
 
masterOperation(PutMappingRequest) - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
 
masterOperation(Request) - Method in class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
masterOperation(MappingUpdatedAction.MappingUpdatedRequest) - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
matchAllQuery() - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A query that match on all documents.
MatchAllQueryBuilder - Class in org.elasticsearch.index.query.xcontent
A query that matches on all documents.
MatchAllQueryBuilder() - Constructor for class org.elasticsearch.index.query.xcontent.MatchAllQueryBuilder
 
MatchAllQueryParser - Class in org.elasticsearch.index.query.xcontent
 
MatchAllQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.MatchAllQueryParser
 
Matcher<T> - Interface in org.elasticsearch.util.inject.matcher
Returns true or false for a given input.
MatcherAndConverter - Class in org.elasticsearch.util.inject.internal
 
MatcherAndConverter(Matcher<? super TypeLiteral<?>>, TypeConverter, Object) - Constructor for class org.elasticsearch.util.inject.internal.MatcherAndConverter
 
Matchers - Class in org.elasticsearch.util.inject.matcher
Matcher implementations.
matches(T) - Method in interface org.elasticsearch.util.inject.matcher.Matcher
Returns true if this matches t, false otherwise.
max(Iterable<E>) - Method in class org.elasticsearch.util.collect.Ordering
Returns the largest of the specified values according to this ordering.
max(E, E, E, E...) - Method in class org.elasticsearch.util.collect.Ordering
Returns the largest of the specified values according to this ordering.
max(E, E) - Method in class org.elasticsearch.util.collect.Ordering
Returns the larger of the two values according to this ordering.
max() - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Finds the maximum value in the list.
max() - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Finds the maximum value in the list.
max() - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Finds the maximum value in the list.
max() - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Finds the maximum value in the list.
max() - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Finds the maximum value in the list.
max() - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Finds the maximum value in the list.
MAX_CHUNK_LEN - Static variable in class org.elasticsearch.util.io.compression.lzf.LZFChunk
 
MAX_LITERAL - Static variable in class org.elasticsearch.util.io.compression.lzf.LZFChunk
Maximum length of literal run for LZF encoding.
maxDoc() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus.Docs
 
maxDoc() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus.Docs
 
maxDoc() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus.Docs
 
maxDoc() - Method in class org.elasticsearch.action.terms.TermsResponse
The total maximum number of documents (including deletions).
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.xcontent.MoreLikeThisFieldQueryBuilder
Set the maximum frequency in which words may still appear.
maxDocFreq(int) - Method in class org.elasticsearch.index.query.xcontent.MoreLikeThisQueryBuilder
Set the maximum frequency in which words may still appear.
maxFreq() - Method in class org.elasticsearch.action.terms.TermsRequest
An optional maximum document frequency to filter out terms.
maxFreq(int) - Method in class org.elasticsearch.action.terms.TermsRequest
An optional maximum document frequency to filter out terms.
maxNumberOfShardsPerNode(int) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
maxNumberOfShardsPerNode() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
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
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
 
maxPrecisionStep() - Method in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper
 
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.index.query.xcontent.FuzzyLikeThisFieldQueryBuilder
 
maxQueryTerms(int) - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisQueryBuilder
 
maxQueryTerms(int) - Method in class org.elasticsearch.index.query.xcontent.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.xcontent.MoreLikeThisQueryBuilder
Sets the maximum number of query terms that will be included in any generated query.
maxThreads() - Method in class org.elasticsearch.threadpool.ThreadPoolInfo
The maximum number of threads in the thread pool.
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.xcontent.MoreLikeThisFieldQueryBuilder
Sets the maximum word length above which words will be ignored.
maxWordLen(int) - Method in class org.elasticsearch.index.query.xcontent.MoreLikeThisQueryBuilder
Sets the maximum word length above which words will be ignored.
mb() - Method in class org.elasticsearch.util.SizeValue
 
MBean - Annotation Type in org.elasticsearch.jmx
 
mbFrac() - Method in class org.elasticsearch.util.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.util.inject.internal.MoreTypes
 
members() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
 
MembershipAction - Class in org.elasticsearch.discovery.zen.membership
 
MembershipAction(Settings, TransportService, 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.util.inject
Injects dependencies into the fields and methods on instances of type T.
MembersInjectorLookup<T> - Class in org.elasticsearch.util.inject.spi
A lookup of the members injector for a type.
MembersInjectorLookup(Object, TypeLiteral<T>) - Constructor for class org.elasticsearch.util.inject.spi.MembersInjectorLookup
 
memberType(Member) - Static method in class org.elasticsearch.util.inject.internal.MoreTypes
Returns Field.class, Method.class or Constructor.class.
memoize(Supplier<T>) - Static method in class org.elasticsearch.util.base.Suppliers
Returns a supplier which caches the instance retrieved during the first call to get() and returns that value on subsequent calls to get().
MEMORY_MANAGER_TYPE - Static variable in class org.elasticsearch.monitor.MonitorModule.MonitorSettings
 
MemoryMonitor - Interface in org.elasticsearch.monitor.memory
 
MemoryMonitorService - Class in org.elasticsearch.monitor.memory
 
MemoryMonitorService(Settings, MemoryMonitor) - Constructor for class org.elasticsearch.monitor.memory.MemoryMonitorService
 
MemorySnapshot - Class in org.elasticsearch.index.translog.memory
 
MemorySnapshot() - Constructor for class org.elasticsearch.index.translog.memory.MemorySnapshot
 
MemorySnapshot(Translog.Snapshot) - Constructor for class org.elasticsearch.index.translog.memory.MemorySnapshot
 
MemorySnapshot(long, Translog.Operation[]) - Constructor for class org.elasticsearch.index.translog.memory.MemorySnapshot
 
MemoryStoreModule - Class in org.elasticsearch.index.store.memory
 
MemoryStoreModule(Settings) - Constructor for class org.elasticsearch.index.store.memory.MemoryStoreModule
 
MemoryTranslog - Class in org.elasticsearch.index.translog.memory
 
MemoryTranslog(ShardId, Settings) - Constructor for class org.elasticsearch.index.translog.memory.MemoryTranslog
 
merge(DocumentMapper, DocumentMapper.MergeFlags) - Method in interface org.elasticsearch.index.mapper.DocumentMapper
Merges this document mapper with the provided document mapper.
merge(XContentMapper, MergeContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper
 
merge(XContentMapper, MergeContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
merge(DocumentMapper, DocumentMapper.MergeFlags) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
merge(XContentMapper, MergeContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
merge(XContentMapper, MergeContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper
 
merge(XContentMapper, MergeContext) - Method in interface org.elasticsearch.index.mapper.xcontent.XContentMapper
 
merge(XContentMapper, MergeContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper
 
merge(XContentMapper, MergeContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper
 
merge(XContentMapper, MergeContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper
 
merge(XContentMapper, MergeContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper
 
merge(XContentMapper, MergeContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper
 
merge(ShardDoc[], Map<SearchShardTarget, ? extends QuerySearchResultProvider>, Map<SearchShardTarget, ? extends FetchSearchResultProvider>) - Method in class org.elasticsearch.search.controller.SearchPhaseController
 
merge(Collection<Message>) - Method in class org.elasticsearch.util.inject.internal.Errors
 
merge(Errors) - Method in class org.elasticsearch.util.inject.internal.Errors
 
MergeContext - Class in org.elasticsearch.index.mapper.xcontent
 
MergeContext(XContentDocumentMapper, DocumentMapper.MergeFlags) - Constructor for class org.elasticsearch.index.mapper.xcontent.MergeContext
 
MergeFactor - Annotation Type in org.elasticsearch.index.merge.policy
The merge factor that is used for the shard.
mergeFlags() - Static method in class org.elasticsearch.index.mapper.DocumentMapper.MergeFlags
 
mergeFlags() - Method in class org.elasticsearch.index.mapper.xcontent.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
 
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
 
mergeStringArrays(String[], String[]) - Static method in class org.elasticsearch.util.Strings
Merge the given String arrays into one, with overlapping array elements only included once.
Message - Class in org.elasticsearch.util.inject.spi
An error message and the context in which it occured.
Message(List<Object>, String, Throwable) - Constructor for class org.elasticsearch.util.inject.spi.Message
 
Message(Object, String) - Constructor for class org.elasticsearch.util.inject.spi.Message
 
Message(String) - Constructor for class org.elasticsearch.util.inject.spi.Message
 
MessageChannelHandler - Class in org.elasticsearch.transport.netty
 
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
 
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.RoutingNodes
 
MetaData.Builder - Class in org.elasticsearch.cluster.metadata
 
MetaData.Builder() - Constructor for class org.elasticsearch.cluster.metadata.MetaData.Builder
 
metaDataChanged() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
MetaDataService - Class in org.elasticsearch.cluster.metadata
 
MetaDataService(Settings, Environment, ClusterService, IndicesService, ShardsRoutingStrategy, NodeIndexCreatedAction, NodeIndexDeletedAction, NodeMappingCreatedAction) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataService
 
MetaDataService.CreateIndexResult - Class in org.elasticsearch.cluster.metadata
 
MetaDataService.CreateIndexResult(boolean) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataService.CreateIndexResult
 
MetaDataService.DeleteIndexResult - Class in org.elasticsearch.cluster.metadata
 
MetaDataService.DeleteIndexResult(boolean) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataService.DeleteIndexResult
 
MetaDataService.IndicesAliasesResult - Class in org.elasticsearch.cluster.metadata
 
MetaDataService.IndicesAliasesResult() - Constructor for class org.elasticsearch.cluster.metadata.MetaDataService.IndicesAliasesResult
 
MetaDataService.PutMappingResult - Class in org.elasticsearch.cluster.metadata
The result of a putting mapping.
MetaDataService.PutMappingResult(boolean) - Constructor for class org.elasticsearch.cluster.metadata.MetaDataService.PutMappingResult
 
method() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
method() - Method in interface org.elasticsearch.rest.RestRequest
 
mhz() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
micros() - Method in class org.elasticsearch.util.TimeValue
 
microsFrac() - Method in class org.elasticsearch.util.TimeValue
 
millis() - Method in class org.elasticsearch.util.TimeValue
 
millisFrac() - Method in class org.elasticsearch.util.TimeValue
 
min(Iterable<E>) - Method in class org.elasticsearch.util.collect.Ordering
Returns the smallest of the specified values according to this ordering.
min(E, E, E, E...) - Method in class org.elasticsearch.util.collect.Ordering
Returns the smallest of the specified values according to this ordering.
min(E, E) - Method in class org.elasticsearch.util.collect.Ordering
Returns the smaller of the two values according to this ordering.
min() - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Finds the minimum value in the list.
min() - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Finds the minimum value in the list.
min() - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Finds the minimum value in the list.
min() - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Finds the minimum value in the list.
min() - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Finds the minimum value in the list.
min() - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Finds the minimum value in the list.
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.xcontent.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.xcontent.MoreLikeThisQueryBuilder
Sets the frequency at which words will be ignored which do not occur in at least this many docs.
minFreq() - Method in class org.elasticsearch.action.terms.TermsRequest
An optional minimum document frequency to filter out terms.
minFreq(int) - Method in class org.elasticsearch.action.terms.TermsRequest
An optional minimum document frequency to filter out terms.
minimumNumberShouldMatch(int) - Method in class org.elasticsearch.index.query.xcontent.BoolQueryBuilder
Specifies a minimum number of the optional (should) boolean clauses which must be satisfied.
minScore(float) - Method in class org.elasticsearch.action.count.CountRequest
The minimum score of the documents to include in the count.
minSimilarity(float) - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisFieldQueryBuilder
 
minSimilarity(float) - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisQueryBuilder
 
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.xcontent.MoreLikeThisFieldQueryBuilder
The frequency below which terms will be ignored in the source doc.
minTermFreq(int) - Method in class org.elasticsearch.index.query.xcontent.MoreLikeThisQueryBuilder
The frequency below which terms will be ignored in the source doc.
minThreads() - Method in class org.elasticsearch.threadpool.ThreadPoolInfo
The minimum number of threads in the thread pool.
minutes() - Method in class org.elasticsearch.util.TimeValue
 
minutesFrac() - Method in class org.elasticsearch.util.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.xcontent.MoreLikeThisFieldQueryBuilder
Sets the minimum word length below which words will be ignored.
minWordLen(int) - Method in class org.elasticsearch.index.query.xcontent.MoreLikeThisQueryBuilder
Sets the minimum word length below which words will be ignored.
misplacedBindingAnnotation(Member, Annotation) - Method in class org.elasticsearch.util.inject.internal.Errors
 
missingConstantValues() - Method in class org.elasticsearch.util.inject.internal.Errors
 
missingConstructor(Class<?>) - Method in class org.elasticsearch.util.inject.internal.Errors
 
missingImplementation(Key) - Method in class org.elasticsearch.util.inject.internal.Errors
We use a fairly generic error message here.
missingRuntimeRetention(Object) - Method in class org.elasticsearch.util.inject.internal.Errors
 
missingScopeAnnotation() - Method in class org.elasticsearch.util.inject.internal.Errors
 
MmapFsStore - Class in org.elasticsearch.index.store.fs
 
MmapFsStore(ShardId, Settings, Environment, String) - Constructor for class org.elasticsearch.index.store.fs.MmapFsStore
 
MmapFsStoreModule - Class in org.elasticsearch.index.store.fs
 
MmapFsStoreModule() - Constructor for class org.elasticsearch.index.store.fs.MmapFsStoreModule
 
model() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
Module - Interface in org.elasticsearch.util.inject
A module contributes configuration information, typically interface bindings, which will be used to create an Injector.
modules() - Method in class org.elasticsearch.plugins.AbstractPlugin
Defaults to return an empty list.
modules() - Method in interface org.elasticsearch.plugins.Plugin
Node level modules.
modules() - Method in class org.elasticsearch.plugins.PluginsService
 
Modules - Class in org.elasticsearch.util.inject.util
Static utility methods for creating and working with instances of Module.
Modules.OverriddenModuleBuilder - Interface in org.elasticsearch.util.inject.util
See the EDSL example at override().
ModulesFactory - Class in org.elasticsearch.util.guice
 
ModulesFactory() - Constructor for class org.elasticsearch.util.guice.ModulesFactory
 
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, MemoryMonitorService, JvmMonitorService, OsService, ProcessService, JvmService, NetworkService) - Constructor for class org.elasticsearch.monitor.MonitorService
 
MORE_LIKE_THIS - Static variable in class org.elasticsearch.action.TransportActions
 
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.node.NodeClient
 
moreLikeThis(MoreLikeThisRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.node.NodeClient
 
moreLikeThis(MoreLikeThisRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
moreLikeThis(MoreLikeThisRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
moreLikeThis(MoreLikeThisRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
moreLikeThis(MoreLikeThisRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
moreLikeThisFieldQuery(String) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A more like this query that runs against a specific field.
MoreLikeThisFieldQueryBuilder - Class in org.elasticsearch.index.query.xcontent
A more like this query that runs against a specific field.
MoreLikeThisFieldQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.xcontent.MoreLikeThisFieldQueryBuilder
A more like this query that runs against a specific field.
MoreLikeThisFieldQueryParser - Class in org.elasticsearch.index.query.xcontent
 
MoreLikeThisFieldQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.MoreLikeThisFieldQueryParser
 
moreLikeThisQuery(String...) - Static method in class org.elasticsearch.index.query.xcontent.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.xcontent.QueryBuilders
A more like this query that finds documents that are "like" the provided MoreLikeThisQueryBuilder.likeText(String) which is checked against the "_all" field.
MoreLikeThisQuery - Class in org.elasticsearch.util.lucene.search
 
MoreLikeThisQuery() - Constructor for class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
MoreLikeThisQuery(String, String[], Analyzer) - Constructor for class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
MoreLikeThisQueryBuilder - Class in org.elasticsearch.index.query.xcontent
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.xcontent.MoreLikeThisQueryBuilder
Constructs a new more like this query which uses the "_all" field.
MoreLikeThisQueryBuilder(String...) - Constructor for class org.elasticsearch.index.query.xcontent.MoreLikeThisQueryBuilder
Sets the field names that will be used when generating the 'More Like This' query.
MoreLikeThisQueryParser - Class in org.elasticsearch.index.query.xcontent
 
MoreLikeThisQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.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.
MoreTypes - Class in org.elasticsearch.util.inject.internal
Static methods for working with types that we aren't publishing in the public Types API.
MoreTypes.GenericArrayTypeImpl - Class in org.elasticsearch.util.inject.internal
 
MoreTypes.GenericArrayTypeImpl(Type) - Constructor for class org.elasticsearch.util.inject.internal.MoreTypes.GenericArrayTypeImpl
 
MoreTypes.MemberImpl - Class in org.elasticsearch.util.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.util.inject.internal
 
MoreTypes.ParameterizedTypeImpl(Type, Type, Type...) - Constructor for class org.elasticsearch.util.inject.internal.MoreTypes.ParameterizedTypeImpl
 
MoreTypes.WildcardTypeImpl - Class in org.elasticsearch.util.inject.internal
The WildcardType interface supports multiple upper bounds and multiple lower bounds.
MoreTypes.WildcardTypeImpl(Type[], Type[]) - Constructor for class org.elasticsearch.util.inject.internal.MoreTypes.WildcardTypeImpl
 
moveToBackup() - Method in class org.elasticsearch.cluster.routing.MutableShardRouting
 
moveToClosed() - Method in class org.elasticsearch.util.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.util.component.Lifecycle
 
moveToStopped() - Method in class org.elasticsearch.util.component.Lifecycle
 
Multibinder<T> - Class in org.elasticsearch.util.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
 
multiField(String) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
MultiFieldMapperQueryParser - Class in org.elasticsearch.index.query.support
 
MultiFieldMapperQueryParser(List<String>, ExtTObjectFloatHashMap<String>, Analyzer, MapperService, IndexCache) - Constructor for class org.elasticsearch.index.query.support.MultiFieldMapperQueryParser
 
Multimap<K,V> - Interface in org.elasticsearch.util.collect
A collection similar to a Map, but which may associate multiple values with a single key.
Multimaps - Class in org.elasticsearch.util.collect
Provides static methods acting on or generating a Multimap.
Multiset<E> - Interface in org.elasticsearch.util.collect
A collection that supports order-independent equality, like Set, but may have duplicate elements.
Multiset.Entry<E> - Interface in org.elasticsearch.util.collect
An unmodifiable element-count pair for a multiset.
Multisets - Class in org.elasticsearch.util.collect
Provides static utility methods for creating and working with Multiset instances.
must(XContentFilterBuilder) - Method in class org.elasticsearch.index.query.xcontent.BoolFilterBuilder
Adds a filter that must appear in the matching documents.
must(XContentQueryBuilder) - Method in class org.elasticsearch.index.query.xcontent.BoolQueryBuilder
Adds a query that must appear in the matching documents.
mustNot(XContentFilterBuilder) - Method in class org.elasticsearch.index.query.xcontent.BoolFilterBuilder
Adds a filter that must not appear in the matching documents.
mustNot(XContentQueryBuilder) - Method in class org.elasticsearch.index.query.xcontent.BoolQueryBuilder
Adds a query that must not appear in the matching documents.
MutableClassToInstanceMap<B> - Class in org.elasticsearch.util.collect
A mutable class-to-instance map backed by an arbitrary user-provided map.
MutableShardRouting - Class in org.elasticsearch.cluster.routing
 
MutableShardRouting() - Constructor for class org.elasticsearch.cluster.routing.MutableShardRouting
 
MutableShardRouting(ShardRouting) - Constructor for class org.elasticsearch.cluster.routing.MutableShardRouting
 
MutableShardRouting(String, int, String, boolean, ShardRoutingState) - Constructor for class org.elasticsearch.cluster.routing.MutableShardRouting
 
MutableShardRouting(String, int, String, String, boolean, ShardRoutingState) - Constructor for class org.elasticsearch.cluster.routing.MutableShardRouting
 

N

NA - Static variable in class org.elasticsearch.index.gateway.IndexShardGateway.SnapshotStatus
 
NA_INTERFACE - Static variable in class org.elasticsearch.monitor.network.NetworkInfo
 
name() - Method in class org.elasticsearch.action.get.GetField
 
name() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
The name of the node.
name() - Method in class org.elasticsearch.index.analysis.AbstractAnalyzerProvider
 
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 class org.elasticsearch.index.analysis.NamedAnalyzer
The name of the analyzer.
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.Index
 
NAME - Static variable in interface org.elasticsearch.index.mapper.AllFieldMapper
 
name(String) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
 
name() - Method in class org.elasticsearch.index.mapper.FieldMapper.Names
The logical name of the field.
name(String) - Method in class org.elasticsearch.index.mapper.MapperService
Returns MapperService.SmartNameFieldMappers for all the FieldMappers that are registered under the given name across all the different DocumentMapper types.
NAME - Static variable in interface org.elasticsearch.index.mapper.SourceFieldMapper
 
NAME - Static variable in interface org.elasticsearch.index.mapper.TypeFieldMapper
 
NAME - Static variable in interface org.elasticsearch.index.mapper.UidFieldMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper.Defaults
 
name() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper.Defaults
 
name - Variable in class org.elasticsearch.index.mapper.xcontent.XContentMapper.Builder
 
name() - Method in interface org.elasticsearch.index.mapper.xcontent.XContentMapper
 
name() - Method in class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper
 
name() - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper
 
NAME - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper.Defaults
 
NAME - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper.Defaults
 
name() - Method in interface org.elasticsearch.index.query.IndexQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.ConstantScoreQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.CustomBoostFactorQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.DisMaxQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.FieldQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.FilteredQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisFieldQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.MatchAllQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.MoreLikeThisFieldQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.MoreLikeThisQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.PrefixFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.PrefixQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.QueryFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.QueryStringQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.RangeFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.RangeQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.SpanFirstQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.SpanNearQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.SpanNotQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.SpanOrQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.SpanTermQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.TermFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.TermQueryParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.TermsFilterParser
 
NAME - Static variable in class org.elasticsearch.index.query.xcontent.WildcardQueryParser
 
name() - Method in class org.elasticsearch.index.query.xcontent.XContentIndexQueryParser
 
name() - Method in class org.elasticsearch.index.similarity.AbstractSimilarityProvider
 
name() - Method in interface org.elasticsearch.index.similarity.SimilarityProvider
 
name() - Method in exception org.elasticsearch.monitor.dump.DumpContributionFailedException
 
name() - Method in class org.elasticsearch.monitor.jvm.JvmStats.GarbageCollector
 
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.search.facets.CountFacet
The "logical" name of the facet.
name() - Method in interface org.elasticsearch.search.facets.Facet
The "logical" name of the search facet.
name() - Method in class org.elasticsearch.search.facets.SearchContextFacets.QueryFacet
 
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(int) - Static method in class org.elasticsearch.util.jline.ANSI.Code
Returns the symbolic name for the given ANSI code.
name() - Method in class org.elasticsearch.util.lucene.all.AllEntries.Entry
 
Named - Annotation Type in org.elasticsearch.util.inject.name
Annotates named things.
named(String) - Static method in class org.elasticsearch.util.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
 
names() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
names - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
names() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
names() - Method in class org.elasticsearch.index.query.xcontent.BoolFilterParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.BoolQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.ConstantScoreQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.CustomBoostFactorQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.DisMaxQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.FieldQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.FilteredQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisFieldQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.MatchAllQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.MoreLikeThisFieldQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.MoreLikeThisQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.PrefixFilterParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.PrefixQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.QueryFilterParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.QueryStringQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.RangeFilterParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.RangeQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.SpanFirstQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.SpanNearQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.SpanNotQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.SpanOrQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.SpanTermQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.TermFilterParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.TermQueryParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.TermsFilterParser
 
names() - Method in class org.elasticsearch.index.query.xcontent.WildcardQueryParser
 
names() - Method in interface org.elasticsearch.index.query.xcontent.XContentFilterParser
The names this filter is registered under.
names() - Method in interface org.elasticsearch.index.query.xcontent.XContentQueryParser
The names this query parser is registered under.
Names - Class in org.elasticsearch.util.inject.name
Utility methods for use with @Named.
Names - Class in org.elasticsearch.util
 
nameUUIDFromBytes(byte[]) - Static method in class org.elasticsearch.util.UUID
Static factory to retrieve a type 3 (name based) UUID based on the specified byte array.
nanos() - Method in class org.elasticsearch.util.TimeValue
 
NativeVersionedMap - Class in org.elasticsearch.util.lucene.versioned
An implementation of VersionedMap based on trove TIntIntHashMap.
NativeVersionedMap() - Constructor for class org.elasticsearch.util.lucene.versioned.NativeVersionedMap
 
NativeVersionedMap(int) - Constructor for class org.elasticsearch.util.lucene.versioned.NativeVersionedMap
 
natural() - Static method in class org.elasticsearch.util.collect.Ordering
Returns a serializable ordering that uses the natural order of the values.
naturalOrder() - Static method in class org.elasticsearch.util.collect.ImmutableSortedMap
Returns a builder that creates immutable sorted maps whose keys are ordered by their natural ordering.
naturalOrder() - Static method in class org.elasticsearch.util.collect.ImmutableSortedSet
Returns a builder that creates immutable sorted sets whose elements are ordered by their natural ordering.
NettyHttpChannel - Class in org.elasticsearch.http.netty
 
NettyHttpChannel(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
 
NettyTransport - Class in org.elasticsearch.transport.netty
 
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.NodeConnections - Class in org.elasticsearch.transport.netty
 
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() - 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.stats.NodeStats
Network level statistics.
NetworkExceptionHelper - Class in org.elasticsearch.util.transport
 
NetworkExceptionHelper() - Constructor for class org.elasticsearch.util.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.util.network
 
NetworkModule() - Constructor for class org.elasticsearch.util.network.NetworkModule
 
NetworkProbe - Interface in org.elasticsearch.monitor.network
 
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 - Class in org.elasticsearch.util.network
 
NetworkService(Settings) - Constructor for class org.elasticsearch.util.network.NetworkService
 
NetworkService.CustomNameResolver - Interface in org.elasticsearch.util.network
 
NetworkService.TcpSettings - Class in org.elasticsearch.util.network
 
NetworkService.TcpSettings() - Constructor for class org.elasticsearch.util.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.util.network
 
NetworkUtils.StackType - Enum in org.elasticsearch.util.network
 
newAcquirableResource(T) - Static method in class org.elasticsearch.util.concurrent.resource.AcquirableResourceFactory
 
newArray(Class<T>, int) - Static method in class org.elasticsearch.util.collect.ObjectArrays
Returns a new array of the given length with the specified component type.
newArray(T[], int) - Static method in class org.elasticsearch.util.collect.ObjectArrays
Returns a new array of the given length with the same type as a reference array.
newArrayList() - Static method in class org.elasticsearch.util.collect.Lists
Creates a mutable, empty ArrayList instance.
newArrayList(E...) - Static method in class org.elasticsearch.util.collect.Lists
Creates a mutable ArrayList instance containing the given elements.
newArrayList(Iterable<? extends E>) - Static method in class org.elasticsearch.util.collect.Lists
Creates a mutable ArrayList instance containing the given elements.
newArrayList(Iterator<? extends E>) - Static method in class org.elasticsearch.util.collect.Lists
Creates a mutable ArrayList instance containing the given elements.
newArrayListWithCapacity(int) - Static method in class org.elasticsearch.util.collect.Lists
Creates an ArrayList instance backed by an array of the exact size specified; equivalent to ArrayList.ArrayList(int).
newArrayListWithExpectedSize(int) - Static method in class org.elasticsearch.util.collect.Lists
Creates an ArrayList instance sized appropriately to hold an estimated number of elements without resizing.
newBlockingThreadPool(int, int, long, int, long) - Static method in class org.elasticsearch.util.concurrent.DynamicExecutors
Creates a thread pool similar to that constructed by DynamicExecutors.newScalingThreadPool(int, int, long), but blocks the call to execute if the queue has reached it's capacity, and all max threads are busy handling requests.
newBlockingThreadPool(int, int, long, int, long, ThreadFactory) - Static method in class org.elasticsearch.util.concurrent.DynamicExecutors
Creates a thread pool, same as in DynamicExecutors.newBlockingThreadPool(int, int, long, int, long), using the provided ThreadFactory to create new threads when needed.
newClusterStateBuilder() - Static method in class org.elasticsearch.cluster.ClusterState
 
newConcurrentMap() - Static method in class org.elasticsearch.util.concurrent.ConcurrentCollections
 
newConcurrentMapLong() - Static method in class org.elasticsearch.util.concurrent.ConcurrentCollections
 
newConcurrentSet() - Static method in class org.elasticsearch.util.concurrent.ConcurrentCollections
 
newEnumMap(Class<K>) - Static method in class org.elasticsearch.util.collect.Maps
Creates an EnumMap instance.
newEnumMap(Map<K, ? extends V>) - Static method in class org.elasticsearch.util.collect.Maps
Creates an EnumMap with the same mappings as the specified map.
newEnumSet(Iterable<E>, Class<E>) - Static method in class org.elasticsearch.util.collect.Sets
Returns a new EnumSet instance containing the given elements.
newFactory(Class<F>, Class<?>) - Static method in class org.elasticsearch.util.inject.assistedinject.FactoryProvider
 
newFactory(TypeLiteral<F>, TypeLiteral<?>) - Static method in class org.elasticsearch.util.inject.assistedinject.FactoryProvider
 
newFuture() - Static method in class org.elasticsearch.action.support.PlainActionFuture
 
newHashMap() - Static method in class org.elasticsearch.util.collect.Maps
Creates a mutable, empty HashMap instance.
newHashMap(Map<? extends K, ? extends V>) - Static method in class org.elasticsearch.util.collect.Maps
Creates a mutable HashMap instance with the same mappings as the specified map.
newHashMapWithExpectedSize(int) - Static method in class org.elasticsearch.util.collect.Maps
Creates a HashMap instance with enough capacity to hold the specified number of elements without rehashing.
newHashSet() - Static method in class org.elasticsearch.util.collect.Sets
Creates a mutable, empty HashSet instance.
newHashSet(E...) - Static method in class org.elasticsearch.util.collect.Sets
Creates a mutable HashSet instance containing the given elements in unspecified order.
newHashSet(Iterable<? extends E>) - Static method in class org.elasticsearch.util.collect.Sets
Creates a mutable HashSet instance containing the given elements in unspecified order.
newHashSet(Iterator<? extends E>) - Static method in class org.elasticsearch.util.collect.Sets
Creates a mutable HashSet instance containing the given elements in unspecified order.
newHashSetWithExpectedSize(int) - Static method in class org.elasticsearch.util.collect.Sets
Creates an empty HashSet instance with enough capacity to hold the specified number of elements without rehashing.
newIdentityHashMap() - Static method in class org.elasticsearch.util.collect.Maps
Creates an IdentityHashMap instance.
newIndexMetaDataBuilder(String) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
newIndexMetaDataBuilder(IndexMetaData) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
newIndexRequestInstance(ReplicationPingRequest, String) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportReplicationPingAction
 
newIndexRequestInstance(GatewaySnapshotRequest, String) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
 
newIndexRequestInstance(DeleteByQueryRequest, String) - Method in class org.elasticsearch.action.deletebyquery.TransportDeleteByQueryAction
 
newIndexRequestInstance(Request, String) - Method in class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
newInstance() - Method in class org.elasticsearch.client.transport.action.support.BaseClientTransportAction
 
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
 
newInstance(String) - Method in class org.elasticsearch.util.logging.ESLoggerFactory
 
newInstance(String, String) - Method in class org.elasticsearch.util.logging.ESLoggerFactory
 
newInstance(String, String) - Method in class org.elasticsearch.util.logging.jdk.JdkESLoggerFactory
 
newInstance(String, String) - Method in class org.elasticsearch.util.logging.log4j.Log4jESLoggerFactory
 
newInstance(String, String) - Method in class org.elasticsearch.util.logging.slf4j.Slf4jESLoggerFactory
 
newLinkedHashMap() - Static method in class org.elasticsearch.util.collect.Maps
Creates a mutable, empty, insertion-ordered LinkedHashMap instance.
newLinkedHashMap(Map<? extends K, ? extends V>) - Static method in class org.elasticsearch.util.collect.Maps
Creates a mutable, insertion-ordered LinkedHashMap instance with the same mappings as the specified map.
newLinkedHashSet() - Static method in class org.elasticsearch.util.collect.Sets
Creates a mutable, empty LinkedHashSet instance.
newLinkedHashSet(Iterable<? extends E>) - Static method in class org.elasticsearch.util.collect.Sets
Creates a mutable LinkedHashSet instance containing the given elements in order.
newLinkedList() - Static method in class org.elasticsearch.util.collect.Lists
Creates an empty LinkedList instance.
newLinkedList(Iterable<? extends E>) - Static method in class org.elasticsearch.util.collect.Lists
Creates a LinkedList instance containing the given elements.
newListMultimap(Map<K, Collection<V>>, Supplier<? extends List<V>>) - Static method in class org.elasticsearch.util.collect.Multimaps
Creates a new ListMultimap that uses the provided map and factory.
newMapBinder(Binder, TypeLiteral<K>, TypeLiteral<V>) - Static method in class org.elasticsearch.util.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.util.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.util.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.util.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.util.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.util.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.util.MapBuilder
 
newMapBuilder(Map<K, V>) - Static method in class org.elasticsearch.util.MapBuilder
 
newMasterNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
 
newMergePolicy(IndexWriter) - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicyProvider
 
newMergePolicy(IndexWriter) - Method in class org.elasticsearch.index.merge.policy.LogByteSizeMergePolicyProvider
 
newMergePolicy(IndexWriter) - Method in class org.elasticsearch.index.merge.policy.LogDocMergePolicyProvider
 
newMergePolicy(IndexWriter) - Method in interface org.elasticsearch.index.merge.policy.MergePolicyProvider
 
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
 
newMultimap(Map<K, Collection<V>>, Supplier<? extends Collection<V>>) - Static method in class org.elasticsearch.util.collect.Multimaps
Creates a new Multimap that uses the provided map and factory.
newNode(DiscoveryNode) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
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.shutdown.TransportNodesShutdownAction
 
newNodeRequest(String, NodesShutdownRequest) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.TransportNodesShutdownAction
 
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
 
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.shutdown.TransportNodesShutdownAction
 
newNodeResponse() - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
 
newNodeResponse() - Method in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
newNodesBuilder() - Static method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
newParameterizedType(Type, Type...) - Static method in class org.elasticsearch.util.inject.util.Types
Returns a new parameterized type, applying typeArguments to rawType.
newParameterizedTypeWithOwner(Type, Type, Type...) - Static method in class org.elasticsearch.util.inject.util.Types
Returns a new parameterized type, applying typeArguments to rawType and enclosed by ownerType.
newPrivateBinder() - Method in interface org.elasticsearch.util.inject.Binder
Creates a new private child environment for bindings and other configuration.
newRequest() - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
 
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.ping.broadcast.TransportBroadcastPingAction
 
newRequest() - Method in class org.elasticsearch.action.admin.cluster.ping.single.TransportSinglePingAction
 
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.cache.clear.TransportClearIndicesCacheAction
 
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.flush.TransportFlushAction
 
newRequest() - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
 
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.status.TransportIndicesStatusAction
 
newRequest() - Method in class org.elasticsearch.action.count.TransportCountAction
 
newRequest() - Method in class org.elasticsearch.action.get.TransportGetAction
 
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.TransportSingleOperationAction
 
newRequest() - Method in class org.elasticsearch.action.terms.TransportTermsAction
 
newRequest() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
newRequestInstance() - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportIndexReplicationPingAction
 
newRequestInstance() - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportReplicationPingAction
 
newRequestInstance() - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportShardReplicationPingAction
 
newRequestInstance() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
 
newRequestInstance() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportIndexGatewaySnapshotAction
 
newRequestInstance() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportShardGatewaySnapshotAction
 
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.TransportClusterHealthAction
 
newResponse(NodesInfoRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
 
newResponse(NodesRestartRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.admin.cluster.node.restart.TransportNodesRestartAction
 
newResponse(NodesShutdownRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.TransportNodesShutdownAction
 
newResponse(NodesStatsRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
 
newResponse(BroadcastPingRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.ping.broadcast.TransportBroadcastPingAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.ping.single.TransportSinglePingAction
 
newResponse() - Method in class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
 
newResponse(ClearIndicesCacheRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.create.TransportCreateIndexAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
 
newResponse(FlushRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
newResponse() - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
 
newResponse(OptimizeRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
newResponse(RefreshRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
newResponse(IndicesStatusRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
 
newResponse(CountRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.count.TransportCountAction
 
newResponse() - Method in class org.elasticsearch.action.get.TransportGetAction
 
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.TransportSingleOperationAction
 
newResponse(TermsRequest, AtomicReferenceArray, ClusterState) - Method in class org.elasticsearch.action.terms.TransportTermsAction
 
newResponse() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
newResponseInstance(IndexReplicationPingRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportIndexReplicationPingAction
 
newResponseInstance(ReplicationPingRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportReplicationPingAction
 
newResponseInstance() - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportShardReplicationPingAction
 
newResponseInstance(GatewaySnapshotRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
 
newResponseInstance(IndexGatewaySnapshotRequest, AtomicReferenceArray) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportIndexGatewaySnapshotAction
 
newResponseInstance() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportShardGatewaySnapshotAction
 
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
 
newRoutingTableBuilder() - Static method in class org.elasticsearch.cluster.routing.RoutingTable
 
newScalingThreadPool(int, int, long) - Static method in class org.elasticsearch.util.concurrent.DynamicExecutors
Creates a thread pool that creates new threads as needed, but will reuse previously constructed threads when they are available.
newScalingThreadPool(int, int, long, ThreadFactory) - Static method in class org.elasticsearch.util.concurrent.DynamicExecutors
Creates a thread pool, same as in DynamicExecutors.newScalingThreadPool(int, int, long), using the provided ThreadFactory to create new threads when needed.
newSetBinder(Binder, TypeLiteral<T>) - Static method in class org.elasticsearch.util.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.util.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.util.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.util.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.util.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.util.inject.multibindings.Multibinder
Returns a new multibinder that collects instances of type in a Set that is itself bound with annotationType.
newSetFromMap(Map<E, Boolean>) - Static method in class org.elasticsearch.util.collect.Sets
Returns a set backed by the specified map.
newSetMultimap(Map<K, Collection<V>>, Supplier<? extends Set<V>>) - Static method in class org.elasticsearch.util.collect.Multimaps
Creates a new SetMultimap that uses the provided map and factory.
newShardRequest() - Method in class org.elasticsearch.action.admin.cluster.ping.broadcast.TransportBroadcastPingAction
 
newShardRequest(ShardRouting, BroadcastPingRequest) - Method in class org.elasticsearch.action.admin.cluster.ping.broadcast.TransportBroadcastPingAction
 
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.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.status.TransportIndicesStatusAction
 
newShardRequest(ShardRouting, IndicesStatusRequest) - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
 
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
 
newShardRequest() - Method in class org.elasticsearch.action.terms.TransportTermsAction
 
newShardRequest(ShardRouting, TermsRequest) - Method in class org.elasticsearch.action.terms.TransportTermsAction
 
newShardRequestInstance(IndexReplicationPingRequest, int) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportIndexReplicationPingAction
 
newShardRequestInstance(IndexGatewaySnapshotRequest, int) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportIndexGatewaySnapshotAction
 
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.cluster.ping.broadcast.TransportBroadcastPingAction
 
newShardResponse() - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
 
newShardResponse() - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
newShardResponse() - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
newShardResponse() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
newShardResponse() - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
 
newShardResponse() - Method in class org.elasticsearch.action.count.TransportCountAction
 
newShardResponse() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
newShardResponse() - Method in class org.elasticsearch.action.terms.TransportTermsAction
 
newSortedSetMultimap(Map<K, Collection<V>>, Supplier<? extends SortedSet<V>>) - Static method in class org.elasticsearch.util.collect.Multimaps
Creates a new SortedSetMultimap that uses the provided map and factory.
newTaskFor(Runnable, T) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
 
newTaskFor(Callable<T>) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
 
newTermQuery(Term) - Method in class org.elasticsearch.index.query.support.MapperQueryParser
 
newThread(ForkJoinPool) - Method in interface org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool.ForkJoinWorkerThreadFactory
Returns a new worker thread operating in the given pool.
newTimeout(TimerTask, TimeValue) - Method in class org.elasticsearch.timer.TimerService
 
newTimeout(TimerTask, long, TimeUnit) - Method in class org.elasticsearch.timer.TimerService
 
newTimeout(TimerTask, long, TimeUnit) - Method in class org.elasticsearch.util.timer.HashedWheelTimer
 
newTimeout(TimerTask, long, TimeUnit) - Method in interface org.elasticsearch.util.timer.Timer
Schedules the specified TimerTask for one-time execution after the specified delay.
newTranslog() - Method in class org.elasticsearch.index.translog.memory.MemoryTranslog
 
newTranslog() - 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.
newTreeMap() - Static method in class org.elasticsearch.util.collect.Maps
Creates a mutable, empty TreeMap instance using the natural ordering of its elements.
newTreeMap(SortedMap<K, ? extends V>) - Static method in class org.elasticsearch.util.collect.Maps
Creates a mutable TreeMap instance with the same mappings as the specified map and using the same ordering as the specified map.
newTreeMap(Comparator<C>) - Static method in class org.elasticsearch.util.collect.Maps
Creates a mutable, empty TreeMap instance using the given comparator.
newTreeSet() - Static method in class org.elasticsearch.util.collect.Sets
Creates a mutable, empty TreeSet instance sorted by the natural sort ordering of its elements.
newTreeSet(Iterable<? extends E>) - Static method in class org.elasticsearch.util.collect.Sets
Creates a mutable TreeSet instance containing the given elements sorted by their natural ordering.
newTreeSet(Comparator<? super E>) - Static method in class org.elasticsearch.util.collect.Sets
Creates a mutable, empty TreeSet instance with the given comparator.
next() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
 
next() - Method in class org.elasticsearch.util.collect.AbstractIterator
 
next() - Method in class org.elasticsearch.util.collect.ForwardingIterator
 
next() - Method in interface org.elasticsearch.util.collect.PeekingIterator
next() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong.IteratorLong
Auto-box and return the next key.
next(int) - Method in class org.elasticsearch.util.concurrent.jsr166y.ThreadLocalRandom
 
next() - Method in class org.elasticsearch.util.gnu.trove.TByteIterator
Advances the iterator to the next element in the underlying collection and returns it.
next() - Method in class org.elasticsearch.util.gnu.trove.TDoubleIterator
Advances the iterator to the next element in the underlying collection and returns it.
next() - Method in class org.elasticsearch.util.gnu.trove.TFloatIterator
Advances the iterator to the next element in the underlying collection and returns it.
next() - Method in class org.elasticsearch.util.gnu.trove.TIntIterator
Advances the iterator to the next element in the underlying collection and returns it.
next() - Method in class org.elasticsearch.util.gnu.trove.TLinkedList.IteratorImpl
Returns the value at the Iterator's index and advances the iterator.
next() - Method in class org.elasticsearch.util.gnu.trove.TLongIterator
Advances the iterator to the next element in the underlying collection and returns it.
next() - Method in class org.elasticsearch.util.gnu.trove.TShortIterator
Advances the iterator to the next element in the underlying collection and returns it.
next() - Method in class org.elasticsearch.util.io.compression.lzf.LZFChunk
 
nextActive() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
 
nextActive() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
 
nextActiveOrNull() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
 
nextActiveOrNull() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
 
nextDouble(double) - Method in class org.elasticsearch.util.concurrent.jsr166y.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed double value between 0 (inclusive) and the specified value (exclusive).
nextDouble(double, double) - Method in class org.elasticsearch.util.concurrent.jsr166y.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextElement() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong.IteratorLong
Auto-box and return the next key.
nextIndex() - Method in class org.elasticsearch.util.collect.ForwardingListIterator
 
nextIndex() - Method in class org.elasticsearch.util.gnu.trove.TLinkedList.IteratorImpl
returns the index of the next node in the list (the one that would be returned by a call to next()).
nextIndex() - Method in class org.elasticsearch.util.gnu.trove.TObjectByteIterator
Returns the index of the next value in the data structure or a negative value if the iterator is exhausted.
nextIndex() - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleIterator
Returns the index of the next value in the data structure or a negative value if the iterator is exhausted.
nextIndex() - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatIterator
Returns the index of the next value in the data structure or a negative value if the iterator is exhausted.
nextIndex() - Method in class org.elasticsearch.util.gnu.trove.TObjectIntIterator
Returns the index of the next value in the data structure or a negative value if the iterator is exhausted.
nextIndex() - Method in class org.elasticsearch.util.gnu.trove.TObjectLongIterator
Returns the index of the next value in the data structure or a negative value if the iterator is exhausted.
nextIndex() - Method in class org.elasticsearch.util.gnu.trove.TObjectShortIterator
Returns the index of the next value in the data structure or a negative value if the iterator is exhausted.
nextInt(int, int) - Method in class org.elasticsearch.util.concurrent.jsr166y.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextLong() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong.IteratorLong
Return the next key as a primitive long.
nextLong(long) - Method in class org.elasticsearch.util.concurrent.jsr166y.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between 0 (inclusive) and the specified value (exclusive).
nextLong(long, long) - Method in class org.elasticsearch.util.concurrent.jsr166y.ThreadLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextPossibleMasters(Iterable<DiscoveryNode>, int) - Method in class org.elasticsearch.discovery.zen.elect.ElectMasterService
Returns a list of the next possible masters.
nextPrime(int) - Static method in class org.elasticsearch.util.gnu.trove.PrimeFinder
Returns a prime number which is >= desiredCapacity and very close to desiredCapacity (within 11% if desiredCapacity >= 1000).
nextToken() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
nextToken() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
nextToken() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
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
 
NioFsStore - Class in org.elasticsearch.index.store.fs
 
NioFsStore(ShardId, Settings, Environment, String) - Constructor for class org.elasticsearch.index.store.fs.NioFsStore
 
NioFsStoreModule - Class in org.elasticsearch.index.store.fs
 
NioFsStoreModule() - Constructor for class org.elasticsearch.index.store.fs.NioFsStoreModule
 
NO_DOC - Static variable in class org.elasticsearch.util.lucene.Lucene
 
NO_OPTIONS - Static variable in class org.elasticsearch.util.Base64
No options specified.
NO_SCOPE - Static variable in class org.elasticsearch.util.inject.Scopes
No scope; the same as not applying any scope at all.
NoClassSettingsException - Exception in org.elasticsearch.util.settings
A specific type of SettingsException indicating failure to load a class based on a settings value.
NoClassSettingsException(String) - Constructor for exception org.elasticsearch.util.settings.NoClassSettingsException
 
NoClassSettingsException(String, Throwable) - Constructor for exception org.elasticsearch.util.settings.NoClassSettingsException
 
noDateTimeFormatter() - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.Builder
 
node() - Method in class org.elasticsearch.action.support.nodes.NodeOperationResponse
The node this information relates to.
node(String) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
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 exception org.elasticsearch.transport.ConnectTransportException
 
NodeAdminClient - Class in org.elasticsearch.client.node
 
NodeAdminClient(Settings, NodeClusterAdminClient, NodeIndicesAdminClient) - Constructor for class org.elasticsearch.client.node.NodeAdminClient
 
nodeBooleanValue(Object) - Static method in class org.elasticsearch.util.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.
NodeClient - Class in org.elasticsearch.client.node
 
NodeClient(Settings, ThreadPool, NodeAdminClient, TransportIndexAction, TransportDeleteAction, TransportDeleteByQueryAction, TransportGetAction, TransportCountAction, TransportSearchAction, TransportSearchScrollAction, TransportTermsAction, TransportMoreLikeThisAction) - Constructor for class org.elasticsearch.client.node.NodeClient
 
NodeClientModule - Class in org.elasticsearch.client.node
 
NodeClientModule() - Constructor for class org.elasticsearch.client.node.NodeClientModule
 
NodeClusterAdminClient - Class in org.elasticsearch.client.node
 
NodeClusterAdminClient(Settings, TransportClusterHealthAction, TransportClusterStateAction, TransportSinglePingAction, TransportBroadcastPingAction, TransportReplicationPingAction, TransportNodesInfoAction, TransportNodesShutdownAction, TransportNodesRestartAction, TransportNodesStatsAction) - 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
 
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
 
NodeDisconnectedTransportException - Exception in org.elasticsearch.transport
 
NodeDisconnectedTransportException(DiscoveryNode, String) - Constructor for exception org.elasticsearch.transport.NodeDisconnectedTransportException
 
nodeDoubleValue(Object) - Static method in class org.elasticsearch.util.xcontent.support.XContentMapValues
 
nodeExists(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes
 
nodeFloatValue(Object) - Static method in class org.elasticsearch.util.xcontent.support.XContentMapValues
 
nodeId() - Method in exception org.elasticsearch.action.FailedNodeException
 
nodeId() - Method in class org.elasticsearch.cluster.action.index.NodeMappingCreatedAction.NodeMappingCreatedResponse
 
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, TransportIndicesStatusAction, TransportCreateIndexAction, TransportDeleteIndexAction, TransportRefreshAction, TransportFlushAction, TransportOptimizeAction, TransportPutMappingAction, TransportGatewaySnapshotAction, TransportIndicesAliasesAction, TransportClearIndicesCacheAction) - Constructor for class org.elasticsearch.client.node.NodeIndicesAdminClient
 
NodeInfo - Class in org.elasticsearch.action.admin.cluster.node.info
Node information (static, does not change over time).
NodeInfo(DiscoveryNode, ImmutableMap<String, String>, Settings, OsInfo, ProcessInfo, JvmInfo, NetworkInfo, ThreadPoolInfo, TransportInfo) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
 
nodeIntegerValue(Object) - Static method in class org.elasticsearch.util.xcontent.support.XContentMapValues
 
nodeLongValue(Object) - Static method in class org.elasticsearch.util.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
 
NodeModule - Class in org.elasticsearch.node.internal
 
NodeModule(Node) - Constructor for class org.elasticsearch.node.internal.NodeModule
 
nodeName() - Method in class org.elasticsearch.index.AbstractIndexComponent
 
nodeName() - Method in class org.elasticsearch.index.shard.AbstractIndexShardComponent
 
nodeName() - Method in class org.elasticsearch.util.component.AbstractComponent
 
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(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(TransportNodesShutdownAction.NodeShutdownRequest) - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.TransportNodesShutdownAction
 
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
 
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
 
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 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
 
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) - Static method in class org.elasticsearch.util.xcontent.support.XContentMapValues
 
nodesIds() - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
nodesIds(String...) - Method in class org.elasticsearch.action.support.nodes.NodesOperationRequest
 
nodesIdsPattern - Static variable in class org.elasticsearch.rest.action.support.RestActions
 
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.node.NodeClusterAdminClient
 
nodesInfo(NodesInfoRequest, ActionListener<NodesInfoResponse>) - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
nodesInfo() - Static method in class org.elasticsearch.client.Requests
Creates a nodes info request against all the nodes.
nodesInfo(String...) - Static method in class org.elasticsearch.client.Requests
Creates a nodes info request against one or more nodes.
nodesInfo(NodesInfoRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
nodesInfo(NodesInfoRequest, ActionListener<NodesInfoResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
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.
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
 
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.node.NodeClusterAdminClient
 
nodesRestart(NodesRestartRequest, ActionListener<NodesRestartResponse>) - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
nodesRestart() - Static method in class org.elasticsearch.client.Requests
Restarts all nodes in the cluster.
nodesRestart(String...) - Static method in class org.elasticsearch.client.Requests
Restarts specific nodes in the cluster.
nodesRestart(NodesRestartRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
nodesRestart(NodesRestartRequest, ActionListener<NodesRestartResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
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.
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.node.NodeClusterAdminClient
 
nodesShutdown(NodesShutdownRequest, ActionListener<NodesShutdownResponse>) - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
nodesShutdown() - Static method in class org.elasticsearch.client.Requests
Shuts down all nodes in the cluster.
nodesShutdown(String...) - Static method in class org.elasticsearch.client.Requests
Shuts down the specified nodes in the cluster.
nodesShutdown(NodesShutdownRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
nodesShutdown(NodesShutdownRequest, ActionListener<NodesShutdownResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
NodesShutdownRequest - Class in org.elasticsearch.action.admin.cluster.node.shutdown
A request to shutdown one ore more nodes (or the whole cluster).
NodesShutdownRequest() - Constructor for class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequest
 
NodesShutdownRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownRequest
Shuts down nodes based on the nodes ids specified.
NodesShutdownResponse - Class in org.elasticsearch.action.admin.cluster.node.shutdown
 
NodesShutdownResponse(ClusterName, NodesShutdownResponse.NodeShutdownResponse[]) - Constructor for class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownResponse
 
NodesShutdownResponse.NodeShutdownResponse - Class in org.elasticsearch.action.admin.cluster.node.shutdown
 
NodesShutdownResponse.NodeShutdownResponse(DiscoveryNode) - Constructor for class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownResponse.NodeShutdownResponse
 
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.node.NodeClusterAdminClient
 
nodesStats(NodesStatsRequest, ActionListener<NodesStatsResponse>) - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
nodesStats(String...) - Static method in class org.elasticsearch.client.Requests
Creates a nodes stats request against one or more nodes.
nodesStats(NodesStatsRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
nodesStats(NodesStatsRequest, ActionListener<NodesStatsResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
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.
NodesStatsResponse - Class in org.elasticsearch.action.admin.cluster.node.stats
 
NodesStatsResponse() - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodesStatsResponse
 
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 (static, does not change over time).
NodeStats(DiscoveryNode, OsStats, ProcessStats, JvmStats, NetworkStats, ThreadPoolStats, TransportStats) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
 
nodesToShards() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
nodesToShardsSorted(Comparator<RoutingNode>) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
NON_LOOPBACK_ADDRESS - Static variable in class org.elasticsearch.util.network.NetworkUtils
 
NonBlockingAcquirableResource<T extends Releasable> - Class in org.elasticsearch.util.concurrent.resource
A wrapper around a resource that can be released.
NonBlockingAcquirableResource(T) - Constructor for class org.elasticsearch.util.concurrent.resource.NonBlockingAcquirableResource
 
NonBlockingHashMap<TypeK,TypeV> - Class in org.elasticsearch.util.concurrent.highscalelib
A lock-free alternate implementation of ConcurrentHashMap with better scaling properties and generally lower costs to mutate the Map.
NonBlockingHashMap() - Constructor for class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Create a new NonBlockingHashMap with default minimum size (currently set to 8 K/V pairs or roughly 84 bytes on a standard 32-bit JVM).
NonBlockingHashMap(int) - Constructor for class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Create a new NonBlockingHashMap with initial room for the given number of elements, thus avoiding internal resizing operations to reach an appropriate size.
NonBlockingHashMapLong<TypeV> - Class in org.elasticsearch.util.concurrent.highscalelib
A lock-free alternate implementation of java.util.ConcurrentHashMap with primitive long keys, better scaling properties and generally lower costs.
NonBlockingHashMapLong() - Constructor for class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Create a new NonBlockingHashMapLong with default minimum size (currently set to 8 K/V pairs or roughly 84 bytes on a standard 32-bit JVM).
NonBlockingHashMapLong(int) - Constructor for class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Create a new NonBlockingHashMapLong with initial room for the given number of elements, thus avoiding internal resizing operations to reach an appropriate size.
NonBlockingHashMapLong(boolean) - Constructor for class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Create a new NonBlockingHashMapLong, setting the space-for-speed tradeoff.
NonBlockingHashMapLong(int, boolean) - Constructor for class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Create a new NonBlockingHashMapLong, setting both the initial size and the space-for-speed tradeoff.
NonBlockingHashMapLong.IteratorLong - Class in org.elasticsearch.util.concurrent.highscalelib
A class which implements the Iterator and Enumeration interfaces, generified to the Long class and supporting a non-auto-boxing NonBlockingHashMapLong.IteratorLong.nextLong() function.
NonBlockingHashMapLong.IteratorLong() - Constructor for class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong.IteratorLong
A new IteratorLong
NonBlockingHashSet<E> - Class in org.elasticsearch.util.concurrent.highscalelib
A simple wrapper around NonBlockingHashMap making it implement the Set interface.
NonBlockingHashSet() - Constructor for class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashSet
Make a new empty NonBlockingHashSet.
NonBlockingHashtable<TypeK,TypeV> - Class in org.elasticsearch.util.concurrent.highscalelib
A lock-free alternate implementation of ConcurrentHashMap with better scaling properties and generally lower costs to mutate the Map.
NonBlockingHashtable() - Constructor for class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Create a new NonBlockingHashtable with default minimum size (currently set to 8 K/V pairs or roughly 84 bytes on a standard 32-bit JVM).
NonBlockingHashtable(int) - Constructor for class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Create a new NonBlockingHashtable with initial room for the given number of elements, thus avoiding internal resizing operations to reach an appropriate size.
NonBlockingIdentityHashMap<TypeK,TypeV> - Class in org.elasticsearch.util.concurrent.highscalelib
A lock-free alternate implementation of ConcurrentHashMap with better scaling properties and generally lower costs to mutate the Map.
NonBlockingIdentityHashMap() - Constructor for class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Create a new NonBlockingHashMap with default minimum size (currently set to 8 K/V pairs or roughly 84 bytes on a standard 32-bit JVM).
NonBlockingIdentityHashMap(int) - Constructor for class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Create a new NonBlockingHashMap with initial room for the given number of elements, thus avoiding internal resizing operations to reach an appropriate size.
NonBlockingSetInt - Class in org.elasticsearch.util.concurrent.highscalelib
A multi-threaded bit-vector set, implemented as an array of primitive longs.
NonBlockingSetInt() - Constructor for class org.elasticsearch.util.concurrent.highscalelib.NonBlockingSetInt
Create a new empty bit-vector
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
 
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
 
nonHeapCommitted() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
 
nonHeapUsed() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Mem
 
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
 
normsField(String) - Method in class org.elasticsearch.index.query.xcontent.MatchAllQueryBuilder
Field used for normalization factor (document boost).
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(Predicate<T>) - Static method in class org.elasticsearch.util.base.Predicates
Returns a predicate that evaluates to true if the given predicate evaluates to false.
not(Matcher<? super T>) - Static method in class org.elasticsearch.util.inject.matcher.Matchers
Inverts the given matcher.
notASubtype(Class<?>, Class<?>) - Method in class org.elasticsearch.util.inject.internal.Errors
 
notNull() - Static method in class org.elasticsearch.util.base.Predicates
Returns a predicate that evaluates to true if the object reference being tested is not null.
NotSerializableTransportException - Exception in org.elasticsearch.transport
 
NotSerializableTransportException(Throwable) - Constructor for exception org.elasticsearch.transport.NotSerializableTransportException
 
NotThreadSafe - Annotation Type in org.elasticsearch.util.concurrent
NotThreadSafe

The class to which this annotation is applied is not thread-safe.

NULL_KEY - Static variable in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper.Defaults
 
NULL_VALUE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper.Defaults
 
Nullability - Class in org.elasticsearch.util.inject.internal
Whether a member supports null values injected.
Nullable - Annotation Type in javax.annotation
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.util.inject.internal
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.util.xcontent.builder.XContentBuilder
 
nullsFirst() - Method in class org.elasticsearch.util.collect.Ordering
Returns an ordering that treats null as less than all other values and uses this to compare non-null values.
nullsLast() - Method in class org.elasticsearch.util.collect.Ordering
Returns an ordering that treats null as greater than all other values and uses this ordering to compare non-null values.
nullValue(boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper.Builder
 
nullValue(float) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper.Builder
 
nullValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper.Builder
 
nullValue(double) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper.Builder
 
nullValue(float) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper.Builder
 
nullValue(int) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper.Builder
 
nullValue(long) - Method in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper.Builder
 
nullValue(short) - Method in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper.Builder
 
nullValue - Variable in class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper.Builder
 
nullValue(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper.Builder
 
nullValue() - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
number() - Static method in class org.elasticsearch.Version
 
numberOfFiles() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.RecoveryStatus.Index
 
numberOfFiles() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.SnapshotStatus.Index
 
numberOfFiles() - Method in exception org.elasticsearch.index.shard.recovery.RecoverFilesRecoveryException
 
numberOfFragments() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight.ParsedHighlightField
 
numberOfOperations() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.RecoveryStatus.Translog
 
numberOfOperations() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.SnapshotStatus.Translog
 
numberOfOwningShards() - Method in class org.elasticsearch.cluster.routing.RoutingNode
The number fo shards on this node that will not be eventually relocated.
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
 
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
 
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.util
A set of utlities around numbers.
numberType() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
numberType() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
numberType() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
numberValue() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
numberValue() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
numberValue() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
numDocs() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus.Docs
 
numDocs() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus.Docs
 
numDocs() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus.Docs
 
numDocs() - Method in class org.elasticsearch.action.terms.TermsResponse
The total number of documents.
NumericAnalyzer<T extends NumericTokenizer> - Class in org.elasticsearch.index.analysis
 
NumericAnalyzer() - Constructor for class org.elasticsearch.index.analysis.NumericAnalyzer
 
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
 
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
 
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
 
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
 

O

object(String) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
ObjectArrays - Class in org.elasticsearch.util.collect
Static utility methods pertaining to object arrays.
objectFromBytes(byte[]) - Static method in class org.elasticsearch.util.io.Serializers
 
objectFromStream(DataInput) - Static method in class org.elasticsearch.util.io.Serializers
 
Objects - Class in org.elasticsearch.util.base
Helper functions that can operate on any Object.
objectToBytes(Serializable) - Static method in class org.elasticsearch.util.io.Serializers
 
objectToStream(Serializable, DataOutput) - Static method in class org.elasticsearch.util.io.Serializers
 
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
 
obtainShardFailures() - Method in class org.elasticsearch.action.search.type.TransportSearchCache
 
of() - Static method in class org.elasticsearch.util.collect.ImmutableBiMap
Returns the empty bimap.
of(K, V) - Static method in class org.elasticsearch.util.collect.ImmutableBiMap
Returns an immutable bimap containing a single entry.
of(K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableBiMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableBiMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableBiMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableBiMap
Returns an immutable map containing the given entries, in order.
of() - Static method in class org.elasticsearch.util.collect.ImmutableList
Returns the empty immutable list.
of(E) - Static method in class org.elasticsearch.util.collect.ImmutableList
Returns an immutable list containing a single element.
of(E, E) - Static method in class org.elasticsearch.util.collect.ImmutableList
Identical to ImmutableList.of(Object[]).
of(E, E, E) - Static method in class org.elasticsearch.util.collect.ImmutableList
Identical to ImmutableList.of(Object[]).
of(E, E, E, E) - Static method in class org.elasticsearch.util.collect.ImmutableList
Identical to ImmutableList.of(Object[]).
of(E, E, E, E, E) - Static method in class org.elasticsearch.util.collect.ImmutableList
Identical to ImmutableList.of(Object[]).
of(E, E, E, E, E, E) - Static method in class org.elasticsearch.util.collect.ImmutableList
Identical to ImmutableList.of(Object[]).
of(E, E, E, E, E, E, E) - Static method in class org.elasticsearch.util.collect.ImmutableList
Identical to ImmutableList.of(Object[]).
of(E, E, E, E, E, E, E, E) - Static method in class org.elasticsearch.util.collect.ImmutableList
Identical to ImmutableList.of(Object[]).
of(E, E, E, E, E, E, E, E, E) - Static method in class org.elasticsearch.util.collect.ImmutableList
Identical to ImmutableList.of(Object[]).
of(E, E, E, E, E, E, E, E, E, E) - Static method in class org.elasticsearch.util.collect.ImmutableList
Identical to ImmutableList.of(Object[]).
of(E, E, E, E, E, E, E, E, E, E, E) - Static method in class org.elasticsearch.util.collect.ImmutableList
Identical to ImmutableList.of(Object[]).
of(E...) - Static method in class org.elasticsearch.util.collect.ImmutableList
Returns an immutable list containing the given elements, in order.
of() - Static method in class org.elasticsearch.util.collect.ImmutableListMultimap
Returns the empty multimap.
of(K, V) - Static method in class org.elasticsearch.util.collect.ImmutableListMultimap
Returns an immutable multimap containing a single entry.
of(K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableListMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableListMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableListMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableListMultimap
Returns an immutable multimap containing the given entries, in order.
of() - Static method in class org.elasticsearch.util.collect.ImmutableMap
Returns the empty map.
of(K, V) - Static method in class org.elasticsearch.util.collect.ImmutableMap
Returns an immutable map containing a single entry.
of(K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableMap
Returns an immutable map containing the given entries, in order.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableMap
Returns an immutable map containing the given entries, in order.
of() - Static method in class org.elasticsearch.util.collect.ImmutableMultimap
Returns an empty multimap.
of(K, V) - Static method in class org.elasticsearch.util.collect.ImmutableMultimap
Returns an immutable multimap containing a single entry.
of(K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableMultimap
Returns an immutable multimap containing the given entries, in order.
of() - Static method in class org.elasticsearch.util.collect.ImmutableMultiset
Returns the empty immutable multiset.
of(E...) - Static method in class org.elasticsearch.util.collect.ImmutableMultiset
Returns an immutable multiset containing the given elements.
of() - Static method in class org.elasticsearch.util.collect.ImmutableSet
Returns the empty immutable set.
of(E) - Static method in class org.elasticsearch.util.collect.ImmutableSet
Returns an immutable set containing a single element.
of(E, E) - Static method in class org.elasticsearch.util.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
of(E, E, E) - Static method in class org.elasticsearch.util.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
of(E, E, E, E) - Static method in class org.elasticsearch.util.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
of(E, E, E, E, E) - Static method in class org.elasticsearch.util.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
of(E...) - Static method in class org.elasticsearch.util.collect.ImmutableSet
Returns an immutable set containing the given elements, in order.
of() - Static method in class org.elasticsearch.util.collect.ImmutableSetMultimap
Returns the empty multimap.
of(K, V) - Static method in class org.elasticsearch.util.collect.ImmutableSetMultimap
Returns an immutable multimap containing a single entry.
of(K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableSetMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableSetMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableSetMultimap
Returns an immutable multimap containing the given entries, in order.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableSetMultimap
Returns an immutable multimap containing the given entries, in order.
of() - Static method in class org.elasticsearch.util.collect.ImmutableSortedMap
Returns the empty sorted map.
of(K, V) - Static method in class org.elasticsearch.util.collect.ImmutableSortedMap
Returns an immutable map containing a single entry.
of(K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableSortedMap
Returns an immutable sorted map containing the given entries, sorted by the natural ordering of their keys.
of(K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableSortedMap
Returns an immutable sorted map containing the given entries, sorted by the natural ordering of their keys.
of(K, V, K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableSortedMap
Returns an immutable sorted map containing the given entries, sorted by the natural ordering of their keys.
of(K, V, K, V, K, V, K, V, K, V) - Static method in class org.elasticsearch.util.collect.ImmutableSortedMap
Returns an immutable sorted map containing the given entries, sorted by the natural ordering of their keys.
of() - Static method in class org.elasticsearch.util.collect.ImmutableSortedSet
Returns the empty immutable sorted set.
of(E) - Static method in class org.elasticsearch.util.collect.ImmutableSortedSet
Returns an immutable sorted set containing a single element.
of(E, E) - Static method in class org.elasticsearch.util.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
of(E, E, E) - Static method in class org.elasticsearch.util.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
of(E, E, E, E) - Static method in class org.elasticsearch.util.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
of(E, E, E, E, E) - Static method in class org.elasticsearch.util.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
of(E...) - Static method in class org.elasticsearch.util.collect.ImmutableSortedSet
Returns an immutable sorted set containing the given elements sorted by their natural ordering.
of(T) - Static method in class org.elasticsearch.util.inject.util.Providers
Returns a provider which always provides instance.
OFF - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
offer(E) - Method in class org.elasticsearch.util.collect.ForwardingQueue
 
offer(E) - Method in class org.elasticsearch.util.concurrent.DynamicThreadPoolExecutor.DynamicQueue
Inserts the specified element at the tail of this queue if there is at least one available thread to run the current task.
offer(E, long, TimeUnit) - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
Inserts the specified element at the tail of this queue.
offer(E) - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
Inserts the specified element at the tail of this queue.
ofInstance(T) - Static method in class org.elasticsearch.util.base.Suppliers
Returns a supplier that always supplies instance.
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper.Defaults
 
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Defaults
 
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper.Defaults
 
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.Defaults
 
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper.Defaults
 
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper.Defaults
 
OMIT_NORMS - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper.Defaults
 
OMIT_TERM_FREQ_AND_POSITIONS - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Defaults
 
OMIT_TERM_FREQ_AND_POSITIONS - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper.Defaults
 
OMIT_TERM_FREQ_AND_POSITIONS - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.Defaults
 
OMIT_TERM_FREQ_AND_POSITIONS - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper.Defaults
 
OMIT_TERM_FREQ_AND_POSITIONS - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper.Defaults
 
OMIT_TERM_FREQ_AND_POSITIONS - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper.Defaults
 
omitNorms() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
omitNorms - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
omitNorms(boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
omitNorms - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
omitNorms() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
omitNorms(boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.OpenBuilder
 
omitNorms(boolean) - Method in class org.elasticsearch.util.lucene.FieldBuilder
 
omitTermFreqAndPositions() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
omitTermFreqAndPositions(boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper.Builder
 
omitTermFreqAndPositions - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
omitTermFreqAndPositions(boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
omitTermFreqAndPositions - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
omitTermFreqAndPositions() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
omitTermFreqAndPositions(boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.OpenBuilder
 
omitTermFreqAndPositions(boolean) - Method in class org.elasticsearch.util.lucene.FieldBuilder
 
on(String) - Static method in class org.elasticsearch.util.base.Joiner
Returns a joiner which automatically places separator between consecutive elements.
on(char) - Static method in class org.elasticsearch.util.base.Joiner
Returns a joiner which automatically places separator between consecutive elements.
onAdvance(int, int) - Method in class org.elasticsearch.util.concurrent.jsr166y.Phaser
Overridable method to perform an action upon impending phase advance, and to control termination.
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..
onDisconnectedFromMaster() - Method in interface org.elasticsearch.discovery.zen.fd.MasterFaultDetection.Listener
 
onException(Exception) - Method in interface org.elasticsearch.threadpool.FutureListener
 
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 interface org.elasticsearch.search.action.SearchServiceListener
 
onGoingRecoveries() - Method in class org.elasticsearch.indices.recovery.throttler.RecoveryThrottler
 
onGoingStreams() - Method in class org.elasticsearch.indices.recovery.throttler.RecoveryThrottler
 
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.util.inject.matcher.Matchers
Returns a matcher which matches objects equal to the given object.
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
 
onMasterFailure(DiscoveryNode) - Method in interface org.elasticsearch.discovery.zen.fd.MasterFaultDetection.Listener
 
onNewClusterState(ClusterState) - Method in interface org.elasticsearch.discovery.zen.publish.PublishClusterStateAction.NewClusterStateListener
 
onNodeConnected(DiscoveryNode) - Method in interface org.elasticsearch.transport.TransportConnectionListener
 
onNodeDisconnected(DiscoveryNode) - Method in interface org.elasticsearch.transport.TransportConnectionListener
 
onNodeFailure(DiscoveryNode) - 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
 
onPing(ZenPing.PingResponse[]) - Method in interface org.elasticsearch.discovery.zen.ping.ZenPing.PingListener
 
onPortNumber(int) - Method in interface org.elasticsearch.util.transport.PortsRange.PortCallback
 
onResponse(Response) - Method in interface org.elasticsearch.action.ActionListener
A response handler.
onResponse(L) - Method in class org.elasticsearch.action.support.AdapterActionFuture
 
onResult(T) - Method in interface org.elasticsearch.search.action.SearchServiceListener
 
onResult(T) - Method in interface org.elasticsearch.threadpool.FutureListener
 
onResultOf(Function<F, ? extends T>) - Method in class org.elasticsearch.util.collect.Ordering
Returns a new ordering on F which orders elements by first applying a function to them, then comparing those results using this.
onStart() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinWorkerThread
Initializes internal state after construction but before processing any tasks.
onTermination(Throwable) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinWorkerThread
Performs cleanup associated with termination of this worker thread.
onTick() - Method in interface org.elasticsearch.util.http.HttpDownloadHelper.DownloadProgress
tick handler
onTick() - Method in class org.elasticsearch.util.http.HttpDownloadHelper.NullProgress
tick handler
onTick() - Method in class org.elasticsearch.util.http.HttpDownloadHelper.VerboseProgress
tick handler
onTimeout(TimeValue) - Method in interface org.elasticsearch.cluster.TimeoutClusterStateListener
 
OpenChannelsHandler - Class in org.elasticsearch.http.netty
 
OpenChannelsHandler() - Constructor for class org.elasticsearch.http.netty.OpenChannelsHandler
 
OpenChannelsHandler - Class in org.elasticsearch.transport.netty
 
OpenChannelsHandler() - Constructor for class org.elasticsearch.transport.netty.OpenChannelsHandler
 
openInput(String) - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectory
 
openInput(String) - Method in class org.elasticsearch.index.store.memory.HeapDirectory
 
openInput(String) - Method in class org.elasticsearch.util.lucene.store.SwitchDirectory
 
OperationRouting - Interface in org.elasticsearch.index.routing
 
operationRouting() - Method in interface org.elasticsearch.index.service.IndexService
 
operationRouting() - Method in class org.elasticsearch.index.service.InternalIndexService
 
OperationRoutingModule - Class in org.elasticsearch.index.routing
 
OperationRoutingModule(Settings) - Constructor for class org.elasticsearch.index.routing.OperationRoutingModule
 
operationThreaded(boolean) - Method in class org.elasticsearch.action.admin.cluster.ping.single.SinglePingRequest
 
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.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.SingleOperationRequest
Controls if the operation will be executed on a separate thread when executed locally.
operationThreaded(boolean) - Method in class org.elasticsearch.action.support.single.SingleOperationRequest
Controls if the operation will be executed on a separate thread when executed locally.
operationThreading(BroadcastOperationThreading) - Method in class org.elasticsearch.action.admin.cluster.ping.broadcast.BroadcastPingRequest
 
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.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.
OPTIMIZE - Static variable in class org.elasticsearch.action.TransportActions.Admin.Indices
 
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.node.NodeIndicesAdminClient
 
optimize(OptimizeRequest, ActionListener<OptimizeResponse>) - Method in class org.elasticsearch.client.node.NodeIndicesAdminClient
 
optimize(OptimizeRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
optimize(OptimizeRequest, ActionListener<OptimizeResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
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
 
OptimizeFailedEngineException - Exception in org.elasticsearch.index.engine
 
OptimizeFailedEngineException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.engine.OptimizeFailedEngineException
 
optimizeQuery(Query) - Static method in class org.elasticsearch.util.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(String...) - Static method in class org.elasticsearch.client.Requests
Creates an optimize request.
OptimizeResponse - Class in org.elasticsearch.action.admin.indices.optimize
A response for optimize action.
optionalConstructor(Constructor) - Method in class org.elasticsearch.util.inject.internal.Errors
 
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.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(Iterable<? extends Predicate<? super T>>) - Static method in class org.elasticsearch.util.base.Predicates
Returns a predicate that evaluates to true if any one of its components evaluates to true.
or(Predicate<? super T>...) - Static method in class org.elasticsearch.util.base.Predicates
Returns a predicate that evaluates to true if any one of its components evaluates to true.
or(Predicate<? super T>, Predicate<? super T>) - Static method in class org.elasticsearch.util.base.Predicates
Returns a predicate that evaluates to true if either of its components evaluates to true.
or(Matcher<? super T>) - Method in class org.elasticsearch.util.inject.matcher.AbstractMatcher
 
or(Matcher<? super T>) - Method in interface org.elasticsearch.util.inject.matcher.Matcher
Returns a new matcher which returns true if either this or the given matcher return true.
order(String) - Method in class org.elasticsearch.search.builder.SearchSourceHighlightBuilder
The order of fragments per field.
ORDERED - Static variable in class org.elasticsearch.util.Base64
Encode using the special "ordered" dialect of Base64 described here: http://www.faqs.org/qa/rfcc-1940.html.
orderedBy(Comparator<K>) - Static method in class org.elasticsearch.util.collect.ImmutableSortedMap
Returns a builder that creates immutable sorted maps with an explicit comparator.
orderedBy(Comparator<E>) - Static method in class org.elasticsearch.util.collect.ImmutableSortedSet
Returns a builder that creates immutable sorted sets with an explicit comparator.
Ordering<T> - Class in org.elasticsearch.util.collect
A comparator with added methods to support common functions.
Ordering() - Constructor for class org.elasticsearch.util.collect.Ordering
Constructs a new instance of this class (only invokable by the subclass constructor, typically implicit).
org.apache.lucene.search - package org.apache.lucene.search
 
org.apache.lucene.search.vectorhighlight - package org.apache.lucene.search.vectorhighlight
 
org.elasticsearch - package org.elasticsearch
 
org.elasticsearch.action - package org.elasticsearch.action
 
org.elasticsearch.action.admin.cluster.health - package org.elasticsearch.action.admin.cluster.health
 
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.ping.broadcast - package org.elasticsearch.action.admin.cluster.ping.broadcast
 
org.elasticsearch.action.admin.cluster.ping.replication - package org.elasticsearch.action.admin.cluster.ping.replication
 
org.elasticsearch.action.admin.cluster.ping.single - package org.elasticsearch.action.admin.cluster.ping.single
 
org.elasticsearch.action.admin.cluster.state - package org.elasticsearch.action.admin.cluster.state
 
org.elasticsearch.action.admin.indices.alias - package org.elasticsearch.action.admin.indices.alias
 
org.elasticsearch.action.admin.indices.cache.clear - package org.elasticsearch.action.admin.indices.cache.clear
 
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.flush - package org.elasticsearch.action.admin.indices.flush
Flush index/indices action.
org.elasticsearch.action.admin.indices.gateway.snapshot - package org.elasticsearch.action.admin.indices.gateway.snapshot
GAteway Snapshot Action.
org.elasticsearch.action.admin.indices.mapping.put - package org.elasticsearch.action.admin.indices.mapping.put
Put Mapping Action.
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.status - package org.elasticsearch.action.admin.indices.status
 
org.elasticsearch.action.count - package org.elasticsearch.action.count
 
org.elasticsearch.action.delete - package org.elasticsearch.action.delete
Delete action.
org.elasticsearch.action.deletebyquery - package org.elasticsearch.action.deletebyquery
Delete by query action.
org.elasticsearch.action.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.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 - package org.elasticsearch.action.support.single
 
org.elasticsearch.action.terms - package org.elasticsearch.action.terms
Terms action.
org.elasticsearch.bootstrap - package org.elasticsearch.bootstrap
 
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.transport - package org.elasticsearch.client.transport
 
org.elasticsearch.client.transport.action - package org.elasticsearch.client.transport.action
 
org.elasticsearch.client.transport.action.admin.cluster.health - package org.elasticsearch.client.transport.action.admin.cluster.health
 
org.elasticsearch.client.transport.action.admin.cluster.node.info - package org.elasticsearch.client.transport.action.admin.cluster.node.info
 
org.elasticsearch.client.transport.action.admin.cluster.node.restart - package org.elasticsearch.client.transport.action.admin.cluster.node.restart
 
org.elasticsearch.client.transport.action.admin.cluster.node.shutdown - package org.elasticsearch.client.transport.action.admin.cluster.node.shutdown
 
org.elasticsearch.client.transport.action.admin.cluster.node.stats - package org.elasticsearch.client.transport.action.admin.cluster.node.stats
 
org.elasticsearch.client.transport.action.admin.cluster.ping.broadcast - package org.elasticsearch.client.transport.action.admin.cluster.ping.broadcast
 
org.elasticsearch.client.transport.action.admin.cluster.ping.replication - package org.elasticsearch.client.transport.action.admin.cluster.ping.replication
 
org.elasticsearch.client.transport.action.admin.cluster.ping.single - package org.elasticsearch.client.transport.action.admin.cluster.ping.single
 
org.elasticsearch.client.transport.action.admin.cluster.state - package org.elasticsearch.client.transport.action.admin.cluster.state
 
org.elasticsearch.client.transport.action.admin.indices.alias - package org.elasticsearch.client.transport.action.admin.indices.alias
 
org.elasticsearch.client.transport.action.admin.indices.cache.clear - package org.elasticsearch.client.transport.action.admin.indices.cache.clear
 
org.elasticsearch.client.transport.action.admin.indices.create - package org.elasticsearch.client.transport.action.admin.indices.create
 
org.elasticsearch.client.transport.action.admin.indices.delete - package org.elasticsearch.client.transport.action.admin.indices.delete
 
org.elasticsearch.client.transport.action.admin.indices.flush - package org.elasticsearch.client.transport.action.admin.indices.flush
 
org.elasticsearch.client.transport.action.admin.indices.gateway.snapshot - package org.elasticsearch.client.transport.action.admin.indices.gateway.snapshot
 
org.elasticsearch.client.transport.action.admin.indices.mapping.create - package org.elasticsearch.client.transport.action.admin.indices.mapping.create
 
org.elasticsearch.client.transport.action.admin.indices.optimize - package org.elasticsearch.client.transport.action.admin.indices.optimize
 
org.elasticsearch.client.transport.action.admin.indices.refresh - package org.elasticsearch.client.transport.action.admin.indices.refresh
 
org.elasticsearch.client.transport.action.admin.indices.status - package org.elasticsearch.client.transport.action.admin.indices.status
 
org.elasticsearch.client.transport.action.count - package org.elasticsearch.client.transport.action.count
 
org.elasticsearch.client.transport.action.delete - package org.elasticsearch.client.transport.action.delete
 
org.elasticsearch.client.transport.action.deletebyquery - package org.elasticsearch.client.transport.action.deletebyquery
 
org.elasticsearch.client.transport.action.get - package org.elasticsearch.client.transport.action.get
 
org.elasticsearch.client.transport.action.index - package org.elasticsearch.client.transport.action.index
 
org.elasticsearch.client.transport.action.mlt - package org.elasticsearch.client.transport.action.mlt
 
org.elasticsearch.client.transport.action.search - package org.elasticsearch.client.transport.action.search
 
org.elasticsearch.client.transport.action.support - package org.elasticsearch.client.transport.action.support
 
org.elasticsearch.client.transport.action.terms - package org.elasticsearch.client.transport.action.terms
 
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.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.strategy - package org.elasticsearch.cluster.routing.strategy
 
org.elasticsearch.cluster.service - package org.elasticsearch.cluster.service
 
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.fs - package org.elasticsearch.gateway.fs
 
org.elasticsearch.gateway.none - package org.elasticsearch.gateway.none
 
org.elasticsearch.http - package org.elasticsearch.http
 
org.elasticsearch.http.netty - package org.elasticsearch.http.netty
 
org.elasticsearch.index - package org.elasticsearch.index
 
org.elasticsearch.index.analysis - package org.elasticsearch.index.analysis
 
org.elasticsearch.index.cache - package org.elasticsearch.index.cache
 
org.elasticsearch.index.cache.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.soft - package org.elasticsearch.index.cache.filter.soft
 
org.elasticsearch.index.cache.filter.support - package org.elasticsearch.index.cache.filter.support
 
org.elasticsearch.index.cache.filter.weak - package org.elasticsearch.index.cache.filter.weak
 
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.gateway - package org.elasticsearch.index.gateway
 
org.elasticsearch.index.gateway.fs - package org.elasticsearch.index.gateway.fs
 
org.elasticsearch.index.gateway.none - package org.elasticsearch.index.gateway.none
 
org.elasticsearch.index.mapper - package org.elasticsearch.index.mapper
 
org.elasticsearch.index.mapper.xcontent - package org.elasticsearch.index.mapper.xcontent
 
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.query - package org.elasticsearch.index.query
 
org.elasticsearch.index.query.support - package org.elasticsearch.index.query.support
 
org.elasticsearch.index.query.xcontent - package org.elasticsearch.index.query.xcontent
 
org.elasticsearch.index.routing - package org.elasticsearch.index.routing
 
org.elasticsearch.index.routing.hash - package org.elasticsearch.index.routing.hash
 
org.elasticsearch.index.routing.hash.djb - package org.elasticsearch.index.routing.hash.djb
 
org.elasticsearch.index.routing.hash.simple - package org.elasticsearch.index.routing.hash.simple
 
org.elasticsearch.index.routing.plain - package org.elasticsearch.index.routing.plain
 
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.recovery - package org.elasticsearch.index.shard.recovery
 
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.memory - package org.elasticsearch.index.translog.memory
 
org.elasticsearch.indices - package org.elasticsearch.indices
 
org.elasticsearch.indices.cluster - package org.elasticsearch.indices.cluster
 
org.elasticsearch.indices.recovery.throttler - package org.elasticsearch.indices.recovery.throttler
 
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.jvm - package org.elasticsearch.monitor.jvm
 
org.elasticsearch.monitor.memory - package org.elasticsearch.monitor.memory
 
org.elasticsearch.monitor.memory.alpha - package org.elasticsearch.monitor.memory.alpha
 
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.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.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.ping.broadcast - package org.elasticsearch.rest.action.admin.cluster.ping.broadcast
 
org.elasticsearch.rest.action.admin.cluster.ping.replication - package org.elasticsearch.rest.action.admin.cluster.ping.replication
 
org.elasticsearch.rest.action.admin.cluster.ping.single - package org.elasticsearch.rest.action.admin.cluster.ping.single
 
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.cache.clear - package org.elasticsearch.rest.action.admin.indices.cache.clear
 
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.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.put - package org.elasticsearch.rest.action.admin.indices.mapping.put
 
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.status - package org.elasticsearch.rest.action.admin.indices.status
 
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.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.search - package org.elasticsearch.rest.action.search
 
org.elasticsearch.rest.action.support - package org.elasticsearch.rest.action.support
 
org.elasticsearch.rest.action.terms - package org.elasticsearch.rest.action.terms
 
org.elasticsearch.rest.support - package org.elasticsearch.rest.support
 
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.dfs - package org.elasticsearch.search.dfs
 
org.elasticsearch.search.facets - package org.elasticsearch.search.facets
 
org.elasticsearch.search.fetch - package org.elasticsearch.search.fetch
 
org.elasticsearch.search.highlight - package org.elasticsearch.search.highlight
 
org.elasticsearch.search.internal - package org.elasticsearch.search.internal
 
org.elasticsearch.search.query - package org.elasticsearch.search.query
 
org.elasticsearch.threadpool - package org.elasticsearch.threadpool
 
org.elasticsearch.threadpool.blocking - package org.elasticsearch.threadpool.blocking
 
org.elasticsearch.threadpool.cached - package org.elasticsearch.threadpool.cached
 
org.elasticsearch.threadpool.scaling - package org.elasticsearch.threadpool.scaling
 
org.elasticsearch.threadpool.support - package org.elasticsearch.threadpool.support
 
org.elasticsearch.timer - package org.elasticsearch.timer
 
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.util - package org.elasticsearch.util
 
org.elasticsearch.util.annotations - package org.elasticsearch.util.annotations
 
org.elasticsearch.util.base - package org.elasticsearch.util.base
Miscellaneous common util classes and annotations.
org.elasticsearch.util.base.internal - package org.elasticsearch.util.base.internal
 
org.elasticsearch.util.collect - package org.elasticsearch.util.collect
This package contains generic collection interfaces and implementations, and other utilities for working with collections.
org.elasticsearch.util.component - package org.elasticsearch.util.component
 
org.elasticsearch.util.concurrent - package org.elasticsearch.util.concurrent
 
org.elasticsearch.util.concurrent.highscalelib - package org.elasticsearch.util.concurrent.highscalelib
A copy of Cliff High-Scale-Lib version 1.1.2.
org.elasticsearch.util.concurrent.jsr166y - package org.elasticsearch.util.concurrent.jsr166y
Preview versions of classes targeted for Java 7.
org.elasticsearch.util.concurrent.resource - package org.elasticsearch.util.concurrent.resource
 
org.elasticsearch.util.gnu.trove - package org.elasticsearch.util.gnu.trove
Taken AS IS to use in Elastic Search under Trove License, version 2.1.0
org.elasticsearch.util.gnu.trove.decorator - package org.elasticsearch.util.gnu.trove.decorator
GNU Trove: Decorators for java.util.{Map,Set} compatability
org.elasticsearch.util.guice - package org.elasticsearch.util.guice
 
org.elasticsearch.util.http - package org.elasticsearch.util.http
 
org.elasticsearch.util.inject - package org.elasticsearch.util.inject
Google Guice (pronounced "juice") is an ultra-lightweight dependency injection framework.
org.elasticsearch.util.inject.assistedinject - package org.elasticsearch.util.inject.assistedinject
Extension for combining factory interfaces with injection; this extension requires guice-jndi-2.0.jar.
org.elasticsearch.util.inject.binder - package org.elasticsearch.util.inject.binder
Interfaces which make up Binder's expression language.
org.elasticsearch.util.inject.internal - package org.elasticsearch.util.inject.internal
Guice (sounds like like "juice")
org.elasticsearch.util.inject.matcher - package org.elasticsearch.util.inject.matcher
Used for matching things.
org.elasticsearch.util.inject.multibindings - package org.elasticsearch.util.inject.multibindings
Extension for binding multiple instances in a collection; this extension requires guice-multibindings-2.0.jar.
org.elasticsearch.util.inject.name - package org.elasticsearch.util.inject.name
Support for binding to string-based names.
org.elasticsearch.util.inject.spi - package org.elasticsearch.util.inject.spi
Guice service provider interface
org.elasticsearch.util.inject.util - package org.elasticsearch.util.inject.util
Helper methods for working with Guice.
org.elasticsearch.util.io - package org.elasticsearch.util.io
 
org.elasticsearch.util.io.compression - package org.elasticsearch.util.io.compression
 
org.elasticsearch.util.io.compression.lzf - package org.elasticsearch.util.io.compression.lzf
 
org.elasticsearch.util.io.stream - package org.elasticsearch.util.io.stream
 
org.elasticsearch.util.jline - package org.elasticsearch.util.jline
 
org.elasticsearch.util.joda - package org.elasticsearch.util.joda
 
org.elasticsearch.util.lease - package org.elasticsearch.util.lease
 
org.elasticsearch.util.logging - package org.elasticsearch.util.logging
 
org.elasticsearch.util.logging.jdk - package org.elasticsearch.util.logging.jdk
 
org.elasticsearch.util.logging.log4j - package org.elasticsearch.util.logging.log4j
 
org.elasticsearch.util.logging.slf4j - package org.elasticsearch.util.logging.slf4j
 
org.elasticsearch.util.logging.support - package org.elasticsearch.util.logging.support
 
org.elasticsearch.util.lucene - package org.elasticsearch.util.lucene
 
org.elasticsearch.util.lucene.all - package org.elasticsearch.util.lucene.all
 
org.elasticsearch.util.lucene.analysis - package org.elasticsearch.util.lucene.analysis
 
org.elasticsearch.util.lucene.docidset - package org.elasticsearch.util.lucene.docidset
 
org.elasticsearch.util.lucene.search - package org.elasticsearch.util.lucene.search
 
org.elasticsearch.util.lucene.store - package org.elasticsearch.util.lucene.store
 
org.elasticsearch.util.lucene.versioned - package org.elasticsearch.util.lucene.versioned
 
org.elasticsearch.util.network - package org.elasticsearch.util.network
 
org.elasticsearch.util.path - package org.elasticsearch.util.path
 
org.elasticsearch.util.settings - package org.elasticsearch.util.settings
Settings based utility.
org.elasticsearch.util.settings.loader - package org.elasticsearch.util.settings.loader
Settings loader (parser) allowing to parse different "source" formats into a Settings.
org.elasticsearch.util.timer - package org.elasticsearch.util.timer
 
org.elasticsearch.util.transport - package org.elasticsearch.util.transport
 
org.elasticsearch.util.trove - package org.elasticsearch.util.trove
 
org.elasticsearch.util.xcontent - package org.elasticsearch.util.xcontent
 
org.elasticsearch.util.xcontent.builder - package org.elasticsearch.util.xcontent.builder
 
org.elasticsearch.util.xcontent.json - package org.elasticsearch.util.xcontent.json
 
org.elasticsearch.util.xcontent.support - package org.elasticsearch.util.xcontent.support
 
org.elasticsearch.util.xcontent.xson - package org.elasticsearch.util.xcontent.xson
 
originalQuery() - Method in class org.elasticsearch.search.internal.SearchContext
The original query to execute, unmodified.
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.stats.NodeStats
Operating System level statistics.
OS_NAME - Static variable in class org.elasticsearch.util.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.util
 
OutOfScopeException - Exception in org.elasticsearch.util.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.util.inject.OutOfScopeException
 
OutOfScopeException(String, Throwable) - Constructor for exception org.elasticsearch.util.inject.OutOfScopeException
 
OutOfScopeException(Throwable) - Constructor for exception org.elasticsearch.util.inject.OutOfScopeException
 
OutputStreamStreamOutput - Class in org.elasticsearch.util.io.stream
 
OutputStreamStreamOutput(OutputStream) - Constructor for class org.elasticsearch.util.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.util.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.util.inject.util.Modules
Returns a builder that creates a module that overlays override modules over the given modules.

P

paddedPartition(Iterable<T>, int) - Static method in class org.elasticsearch.util.collect.Iterables
Divides an iterable into unmodifiable sublists of the given size, padding the final iterable with null values if necessary.
paddedPartition(Iterator<T>, int) - Static method in class org.elasticsearch.util.collect.Iterators
Divides an iterator into unmodifiable sublists of the given size, padding the final iterator with null values if necessary.
param(String) - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
param(String) - Method in interface org.elasticsearch.rest.RestRequest
 
param(String) - Method in class org.elasticsearch.util.xcontent.ToXContent.MapParams
 
param(String) - Method in interface org.elasticsearch.util.xcontent.ToXContent.Params
 
paramAsBoolean(String, boolean) - Method in interface org.elasticsearch.rest.RestRequest
 
paramAsBoolean(String, Boolean) - Method in interface org.elasticsearch.rest.RestRequest
 
paramAsBoolean(String, boolean) - Method in class org.elasticsearch.rest.support.AbstractRestRequest
 
paramAsBoolean(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
 
paramAsSize(String, SizeValue) - Method in interface org.elasticsearch.rest.RestRequest
 
paramAsSize(String, SizeValue) - 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() - Method in interface org.elasticsearch.rest.RestRequest
 
parse(String, String, byte[]) - Method in interface org.elasticsearch.index.mapper.DocumentMapper
Parses the source into a parsed document.
parse(String, String, byte[], DocumentMapper.ParseListener) - Method in interface org.elasticsearch.index.mapper.DocumentMapper
Parses the source into a parsed document.
parse(byte[]) - Method in interface org.elasticsearch.index.mapper.DocumentMapper
Parses the source into the parsed document.
parse(String, String) - Method in interface org.elasticsearch.index.mapper.DocumentMapperParser
Parses the source mapping definition into a document mapper with the specified type (overriding the one defined in the source mapping).
parse(String) - Method in interface org.elasticsearch.index.mapper.DocumentMapperParser
Parses the source mapping definition into a document mapper.
parse(String, String) - Method in class org.elasticsearch.index.mapper.MapperService
Just parses and returns the mapper without adding it.
parse(String, Map<String, Object>, XContentTypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBinaryFieldMapper.TypeParser
 
parse(String, Map<String, Object>, XContentTypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper.TypeParser
 
parse(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
parse(String, Map<String, Object>, XContentTypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper.TypeParser
 
parse(byte[]) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
parse(String, String, byte[]) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
parse(String, String, byte[], DocumentMapper.ParseListener) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
parse(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapperParser
 
parse(String, String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapperParser
 
parse(String, Map<String, Object>, XContentTypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper.TypeParser
 
parse(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
parse(String, Map<String, Object>, XContentTypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper.TypeParser
 
parse(String, Map<String, Object>, XContentTypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper.TypeParser
 
parse(String, Map<String, Object>, XContentTypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper.TypeParser
 
parse(ParseContext) - Method in interface org.elasticsearch.index.mapper.xcontent.XContentMapper
 
parse(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper
 
parse(String, Map<String, Object>, XContentTypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper.TypeParser
 
parse(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper
 
parse(String, Map<String, Object>, XContentTypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.TypeParser
 
parse(String, Map<String, Object>, XContentTypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper.TypeParser
 
parse(String, Map<String, Object>, XContentTypeParser.ParserContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper.TypeParser
 
parse(String, Map<String, Object>, XContentTypeParser.ParserContext) - Method in interface org.elasticsearch.index.mapper.xcontent.XContentTypeParser
 
parse(byte[]) - Method in interface org.elasticsearch.index.query.IndexQueryParser
 
parse(byte[], int, int) - Method in interface org.elasticsearch.index.query.IndexQueryParser
 
parse(String) - Method in interface org.elasticsearch.index.query.IndexQueryParser
 
parse(QueryBuilder) - Method in interface org.elasticsearch.index.query.IndexQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.BoolFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.BoolQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.ConstantScoreQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.CustomBoostFactorQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.DisMaxQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.FieldQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.FilteredQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisFieldQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.MatchAllQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.MoreLikeThisFieldQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.MoreLikeThisQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.PrefixFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.PrefixQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.QueryFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.QueryStringQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.SpanFirstQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.SpanNearQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.SpanNotQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.SpanOrQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.SpanTermQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.TermFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.TermQueryParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.TermsFilterParser
 
parse(QueryParseContext) - Method in class org.elasticsearch.index.query.xcontent.WildcardQueryParser
 
parse(QueryParseContext) - Method in interface org.elasticsearch.index.query.xcontent.XContentFilterParser
Parses the into a filter from the current parser location.
parse(QueryBuilder) - Method in class org.elasticsearch.index.query.xcontent.XContentIndexQueryParser
 
parse(byte[]) - Method in class org.elasticsearch.index.query.xcontent.XContentIndexQueryParser
 
parse(byte[], int, int) - Method in class org.elasticsearch.index.query.xcontent.XContentIndexQueryParser
 
parse(String) - Method in class org.elasticsearch.index.query.xcontent.XContentIndexQueryParser
 
parse(XContentParser) - Method in class org.elasticsearch.index.query.xcontent.XContentIndexQueryParser
 
parse(QueryParseContext) - Method in interface org.elasticsearch.index.query.xcontent.XContentQueryParser
Parses the into a query from the current parser location.
parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.facets.FacetsParseElement
 
parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.fetch.ExplainParseElement
 
parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.fetch.FieldsParseElement
 
parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.highlight.HighlighterParseElement
 
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.QueryParseElement
 
parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.query.QueryParserNameParseElement
 
parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.query.SizeParseElement
 
parse(XContentParser, SearchContext) - Method in class org.elasticsearch.search.query.SortParseElement
 
parse(XContentParser, SearchContext) - Method in interface org.elasticsearch.search.SearchParseElement
 
parseBoolean(char[], int, int, boolean) - Static method in class org.elasticsearch.util.Booleans
 
parseBoolean(String, boolean) - Static method in class org.elasticsearch.util.Booleans
 
parseBoolean(String, Boolean) - Static method in class org.elasticsearch.util.Booleans
 
ParseContext - Class in org.elasticsearch.index.mapper.xcontent
 
ParseContext(XContentDocumentMapper, ContentPath) - Constructor for class org.elasticsearch.index.mapper.xcontent.ParseContext
 
ParseContext.ParsedIdState - Enum in org.elasticsearch.index.mapper.xcontent
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBinaryFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper
 
parseCreateField(ParseContext) - Method in class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper
 
parseDateTimeFormatter(String, Object) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentTypeParsers
 
ParsedDocument - Class in org.elasticsearch.index.mapper
 
ParsedDocument(String, String, String, Document, byte[], boolean) - Constructor for class org.elasticsearch.index.mapper.ParsedDocument
 
parsedId(ParseContext.ParsedIdState) - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
 
parsedIdState() - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
 
ParsedScrollId - Class in org.elasticsearch.action.search.type
 
ParsedScrollId(String, String, Tuple<String, Long>[]) - 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.facets.FacetsPhase
 
parseElements() - Method in class org.elasticsearch.search.fetch.FetchPhase
 
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(XContentFieldMapper.Builder, String, Map<String, Object>, XContentTypeParser.ParserContext) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentTypeParsers
 
parseIndex(String, String) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentTypeParsers
 
parseInnerFilter() - Method in class org.elasticsearch.index.query.xcontent.QueryParseContext
 
parseInnerQuery() - Method in class org.elasticsearch.index.query.xcontent.QueryParseContext
 
parseLocaleString(String) - Static method in class org.elasticsearch.util.Strings
Parse the given localeString into a Locale.
parseNumberField(XContentNumberFieldMapper.Builder, String, Map<String, Object>, XContentTypeParser.ParserContext) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentTypeParsers
 
parsePathType(String, String) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentTypeParsers
 
parseQuerySource(RestRequest) - Static method in class org.elasticsearch.rest.action.support.RestActions
 
parser() - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
 
parser() - Method in class org.elasticsearch.index.query.xcontent.QueryParseContext
 
parser() - Method in class org.elasticsearch.util.joda.FormatDateTimeFormatter
 
parseScrollId(String) - Static method in class org.elasticsearch.action.search.type.TransportSearchHelper
 
parseSizeValue(String, SizeValue) - Static method in class org.elasticsearch.util.SizeValue
 
parseStore(String, String) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentTypeParsers
 
parseStringValue(String, PropertyPlaceholder.PlaceholderResolver, Set<String>) - Method in class org.elasticsearch.util.PropertyPlaceholder
 
parseTermVector(String, String) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentTypeParsers
 
parseTimeValue(String, TimeValue) - Static method in class org.elasticsearch.util.TimeValue
 
partition(Iterable<T>, int) - Static method in class org.elasticsearch.util.collect.Iterables
Divides an iterable into unmodifiable sublists of the given size (the final iterable may be smaller).
partition(Iterator<T>, int) - Static method in class org.elasticsearch.util.collect.Iterators
Divides an iterator into unmodifiable sublists of the given size (the final list may be smaller).
partition(List<T>, int) - Static method in class org.elasticsearch.util.collect.Lists
Returns consecutive sublists of a list, each of the same size (the final list may be smaller).
passiveOpens() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
path() - Method in class org.elasticsearch.http.netty.NettyHttpRequest
 
path() - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
 
path() - Method in class org.elasticsearch.index.mapper.xcontent.XContentMapper.BuilderContext
 
path() - Method in interface org.elasticsearch.rest.RestRequest
The path part of the URI (without the query string).
PATH_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper.Defaults
 
PATH_TYPE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.Defaults
 
pathAsText(String) - Method in class org.elasticsearch.index.mapper.xcontent.ContentPath
 
pathEquals(String, String) - Static method in class org.elasticsearch.util.Strings
Compare two paths after normalization of them.
PathTrie<T> - Class in org.elasticsearch.util.path
 
PathTrie() - Constructor for class org.elasticsearch.util.path.PathTrie
 
PathTrie(String, String) - Constructor for class org.elasticsearch.util.path.PathTrie
 
PathTrie.TrieNode<T> - Class in org.elasticsearch.util.path
 
PathTrie.TrieNode(String, T, PathTrie.TrieNode, String) - Constructor for class org.elasticsearch.util.path.PathTrie.TrieNode
 
pathType() - Method in class org.elasticsearch.index.mapper.xcontent.ContentPath
 
pathType(ContentPath.Type) - Method in class org.elasticsearch.index.mapper.xcontent.ContentPath
 
pathType(ContentPath.Type) - Method in class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper.Builder
 
pathType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper
 
pathType(ContentPath.Type) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.Builder
 
payload - Variable in class org.elasticsearch.util.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
payloadScore - Variable in class org.elasticsearch.util.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
payloadsSeen - Variable in class org.elasticsearch.util.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
peakCount() - Method in class org.elasticsearch.monitor.jvm.JvmStats.Threads
 
peek() - Method in class org.elasticsearch.util.collect.AbstractIterator
Returns the next element in the iteration without advancing the iteration, according to the contract of PeekingIterator.peek().
peek() - Method in class org.elasticsearch.util.collect.ForwardingQueue
 
peek() - Method in interface org.elasticsearch.util.collect.PeekingIterator
Returns the next element in the iteration, without advancing the iteration.
peek() - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
 
peek() - Method in class org.elasticsearch.util.gnu.trove.TByteStack
Returns the value at the top of the stack.
peek() - Method in class org.elasticsearch.util.gnu.trove.TDoubleStack
Returns the value at the top of the stack.
peek() - Method in class org.elasticsearch.util.gnu.trove.TFloatStack
Returns the value at the top of the stack.
peek() - Method in class org.elasticsearch.util.gnu.trove.TIntStack
Returns the value at the top of the stack.
peek() - Method in class org.elasticsearch.util.gnu.trove.TLongStack
Returns the value at the top of the stack.
peek() - Method in class org.elasticsearch.util.gnu.trove.TShortStack
Returns the value at the top of the stack.
peekingIterator(Iterator<? extends T>) - Static method in class org.elasticsearch.util.collect.Iterators
Returns a PeekingIterator backed by the given iterator.
PeekingIterator<E> - Interface in org.elasticsearch.util.collect
An iterator that supports a one-element lookahead while iterating.
peekNextLocalTask() - Static method in class org.elasticsearch.util.concurrent.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.
percent() - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
Get the Process cpu usage.
Percent - Class in org.elasticsearch.util
 
Percent(double) - Constructor for class org.elasticsearch.util.Percent
 
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.xcontent.MoreLikeThisFieldQueryBuilder
The percentage of terms to match.
percentTermsToMatch(float) - Method in class org.elasticsearch.index.query.xcontent.MoreLikeThisQueryBuilder
The percentage of terms to match.
performRecovery(Iterable<Translog.Operation>) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
performRecovery(Translog.Snapshot, boolean) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
PersianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
PersianAnalyzerProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.PersianAnalyzerProvider
 
phase() - Method in exception org.elasticsearch.index.engine.RecoveryEngineException
 
phase1(SnapshotIndexCommit) - Method in interface org.elasticsearch.index.engine.Engine.RecoveryHandler
 
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 org.elasticsearch.util.concurrent.jsr166y
A reusable synchronization barrier, similar in functionality to CyclicBarrier and CountDownLatch but supporting more flexible usage.
Phaser() - Constructor for class org.elasticsearch.util.concurrent.jsr166y.Phaser
Creates a new phaser without any initially registered parties, initial phase number 0, and no parent.
Phaser(int) - Constructor for class org.elasticsearch.util.concurrent.jsr166y.Phaser
Creates a new phaser with the given numbers of registered unarrived parties, initial phase number 0, and no parent.
Phaser(Phaser) - Constructor for class org.elasticsearch.util.concurrent.jsr166y.Phaser
Creates a new phaser with the given parent, without any initially registered parties.
Phaser(Phaser, int) - Constructor for class org.elasticsearch.util.concurrent.jsr166y.Phaser
Creates a new phaser with the given parent and numbers of registered unarrived parties.
phraseSlop(int) - Method in class org.elasticsearch.index.query.xcontent.FieldQueryBuilder
Sets the default slop for phrases.
phraseSlop(int) - Method in class org.elasticsearch.index.query.xcontent.QueryStringQueryBuilder
Sets the default slop for phrases.
pid() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
The process id.
ping(SinglePingRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
 
ping(SinglePingRequest, ActionListener<SinglePingResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
 
ping(BroadcastPingRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
 
ping(BroadcastPingRequest, ActionListener<BroadcastPingResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
 
ping(ReplicationPingRequest) - Method in interface org.elasticsearch.client.ClusterAdminClient
 
ping(ReplicationPingRequest, ActionListener<ReplicationPingResponse>) - Method in interface org.elasticsearch.client.ClusterAdminClient
 
ping(SinglePingRequest) - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
ping(SinglePingRequest, ActionListener<SinglePingResponse>) - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
ping(BroadcastPingRequest) - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
ping(BroadcastPingRequest, ActionListener<BroadcastPingResponse>) - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
ping(ReplicationPingRequest) - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
ping(ReplicationPingRequest, ActionListener<ReplicationPingResponse>) - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
ping(SinglePingRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
ping(SinglePingRequest, ActionListener<SinglePingResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
ping(BroadcastPingRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
ping(BroadcastPingRequest, ActionListener<BroadcastPingResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
ping(ReplicationPingRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
ping(ReplicationPingRequest, ActionListener<ReplicationPingResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
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
 
pingBroadcastRequest(String...) - Static method in class org.elasticsearch.client.Requests
 
pingReplicationRequest(String...) - Static method in class org.elasticsearch.client.Requests
 
pingSingleRequest(String) - Static method in class org.elasticsearch.client.Requests
 
PlainActionFuture<T> - Class in org.elasticsearch.action.support
 
PlainActionFuture() - Constructor for class org.elasticsearch.action.support.PlainActionFuture
 
PlainListenableActionFuture<T> - Class in org.elasticsearch.action.support
 
PlainListenableActionFuture(boolean, ThreadPool) - Constructor for class org.elasticsearch.action.support.PlainListenableActionFuture
 
PlainOperationRouting - Class in org.elasticsearch.index.routing.plain
 
PlainOperationRouting(Index, Settings, HashFunction) - Constructor for class org.elasticsearch.index.routing.plain.PlainOperationRouting
 
PlainOperationRoutingModule - Class in org.elasticsearch.index.routing.plain
 
PlainOperationRoutingModule() - Constructor for class org.elasticsearch.index.routing.plain.PlainOperationRoutingModule
 
PlainShardsIterator - Class in org.elasticsearch.cluster.routing
 
PlainShardsIterator(ShardId, List<ShardRouting>) - 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
 
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
 
plusSkippedClasses(Class...) - Method in class org.elasticsearch.util.inject.internal.SourceProvider
Returns a new instance that also skips moreClassesToSkip.
poll() - Method in class org.elasticsearch.util.collect.ForwardingQueue
 
poll(long, TimeUnit) - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
 
poll() - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
 
pollNextLocalTask() - Static method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Unschedules and returns, without executing, the next task queued by the current thread but not yet executed.
pollSubmission() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Removes and returns the next unexecuted submission if one is available.
pollTask() - Static method in class org.elasticsearch.util.concurrent.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.
poolSize() - Method in class org.elasticsearch.threadpool.ThreadPoolStats
Returns the current number of threads in the pool.
pop() - Method in class org.elasticsearch.util.gnu.trove.TByteStack
Removes and returns the value at the top of the stack.
pop() - Method in class org.elasticsearch.util.gnu.trove.TDoubleStack
Removes and returns the value at the top of the stack.
pop() - Method in class org.elasticsearch.util.gnu.trove.TFloatStack
Removes and returns the value at the top of the stack.
pop() - Method in class org.elasticsearch.util.gnu.trove.TIntStack
Removes and returns the value at the top of the stack.
pop() - Method in class org.elasticsearch.util.gnu.trove.TLongStack
Removes and returns the value at the top of the stack.
pop() - Method in class org.elasticsearch.util.gnu.trove.TShortStack
Removes and returns the value at the top of the stack.
popCachedStream(int) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
Removes a cached numeric token stream.
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.util.transport.PortsRange
 
PortsRange - Class in org.elasticsearch.util.transport
 
PortsRange(String) - Constructor for class org.elasticsearch.util.transport.PortsRange
 
PortsRange.PortCallback - Interface in org.elasticsearch.util.transport
 
pos - Variable in class org.elasticsearch.util.io.FastByteArrayInputStream
The index of the next character to read from the input stream buffer.
pos - Variable in class org.elasticsearch.util.io.FastCharArrayReader
The current buffer position.
pos - Variable in class org.elasticsearch.util.io.stream.BytesStreamInput
 
position - Variable in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
position() - Method in class org.elasticsearch.util.io.FastByteArrayInputStream
 
PositionIncrementGapAnalyzer - Interface in org.elasticsearch.index.analysis
 
positions - Variable in class org.elasticsearch.util.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
postInsertHook(boolean) - Method in class org.elasticsearch.util.gnu.trove.THash
After an insert, this hook is called to adjust the size/free values of the set and to perform rehashing if necessary.
postTags(String...) - Method in class org.elasticsearch.search.builder.SearchSourceHighlightBuilder
Explicitly set the post tags that will be used for highlighting.
postTags() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight
 
PRECISION_STEP - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.Defaults
 
precisionStep - Variable in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.Builder
 
precisionStep(int) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.Builder
 
precisionStep - Variable in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
 
precisionStep() - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
 
Preconditions - Class in org.elasticsearch.util.base
Simple static methods to be called at the start of your own methods to verify correct arguments and state.
Preconditions - Class in org.elasticsearch.util.inject.internal
Simple static methods to be called at the start of your own methods to verify correct arguments and state.
Preconditions - Class in org.elasticsearch.util
Simple static methods to be called at the start of your own methods to verify correct arguments and state.
Predicate<T> - Interface in org.elasticsearch.util.base
Determines a true or false value for a given input.
Predicates - Class in org.elasticsearch.util.base
Contains static factory methods for creating Predicate instances.
prefix() - Method in class org.elasticsearch.action.terms.TermsRequest
An optional prefix from which the terms iteration will start (in lex order).
prefix(String) - Method in class org.elasticsearch.action.terms.TermsRequest
An optional prefix from which the terms iteration will start (in lex order).
PREFIX - Static variable in class org.elasticsearch.index.query.IndexQueryParserService.Defaults
 
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, String) - Static method in class org.elasticsearch.index.query.xcontent.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.xcontent
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.xcontent.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.xcontent
 
PrefixFilterParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.PrefixFilterParser
 
prefixLength(int) - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisFieldQueryBuilder
 
prefixLength(int) - Method in class org.elasticsearch.index.query.xcontent.FuzzyLikeThisQueryBuilder
 
prefixQuery(String, String) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A Query that matches documents containing terms with a specified prefix.
PrefixQueryBuilder - Class in org.elasticsearch.index.query.xcontent
A Query that matches documents containing terms with a specified prefix.
PrefixQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.xcontent.PrefixQueryBuilder
A Query that matches documents containing terms with a specified prefix.
PrefixQueryParser - Class in org.elasticsearch.index.query.xcontent
 
PrefixQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.PrefixQueryParser
 
prepareSettings(Settings, boolean) - Static method in class org.elasticsearch.node.internal.InternalSettingsPerparer
 
preProcess(SearchContext) - Method in class org.elasticsearch.search.dfs.DfsPhase
 
preProcess(SearchContext) - Method in class org.elasticsearch.search.facets.FacetsPhase
 
preProcess(SearchContext) - Method in class org.elasticsearch.search.fetch.FetchPhase
 
preProcess(SearchContext) - Method in class org.elasticsearch.search.highlight.HighlightPhase
 
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.
preTags(String...) - Method in class org.elasticsearch.search.builder.SearchSourceHighlightBuilder
Explicitly set the pre tags that will be used for highlighting.
preTags() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight
 
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.util.StopWatch
Return a string with a table describing all tasks performed.
prettyPrint() - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
previous() - Method in class org.elasticsearch.util.collect.ForwardingListIterator
 
previous() - Method in class org.elasticsearch.util.gnu.trove.TLinkedList.IteratorImpl
Returns the value before the Iterator's index and moves the iterator back one index.
previousIndex() - Method in class org.elasticsearch.util.collect.ForwardingListIterator
 
previousIndex() - Method in class org.elasticsearch.util.gnu.trove.TLinkedList.IteratorImpl
Returns the previous element's index.
previousMasterNode() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
 
previousState() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
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
 
primaryActive() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterShardHealth
 
primaryDir() - Method in class org.elasticsearch.util.lucene.store.SwitchDirectory
Return the primary directory
primaryExtensions() - Method in class org.elasticsearch.util.lucene.store.SwitchDirectory
 
primaryInterface() - Method in class org.elasticsearch.monitor.network.NetworkInfo
 
PrimaryMissingActionException - Exception in org.elasticsearch.action
 
PrimaryMissingActionException(String) - Constructor for exception org.elasticsearch.action.PrimaryMissingActionException
 
PrimaryNotStartedActionException - Exception in org.elasticsearch.action
 
PrimaryNotStartedActionException(ShardId, String) - Constructor for exception org.elasticsearch.action.PrimaryNotStartedActionException
 
primaryShard() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
PrimeFinder - Class in org.elasticsearch.util.gnu.trove
Used to keep hash table capacities prime numbers.
PrimeFinder() - Constructor for class org.elasticsearch.util.gnu.trove.PrimeFinder
 
print() - Method in class org.elasticsearch.util.concurrent.highscalelib.ConcurrentAutoTable
A more verbose print than ConcurrentAutoTable.toString(), showing internal structure.
print() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Verbose printout of table internals, useful for debugging.
print() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Verbose printout of table internals, useful for debugging.
print() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Verbose printout of table internals, useful for debugging.
print() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Verbose printout of table internals, useful for debugging.
print() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingSetInt
Verbose printout of internal structure for debugging.
printer() - Method in class org.elasticsearch.util.joda.FormatDateTimeFormatter
 
println(String) - Method in class org.elasticsearch.util.lucene.LoggerInfoStream
Override only the method Lucene actually uses.
priorityThreadFactory(int, String) - Static method in class org.elasticsearch.util.concurrent.DynamicExecutors
A priority based thread factory, for all Thread priority constants: Thread.MIN_PRIORITY, Thread.NORM_PRIORITY, Thread.MAX_PRIORITY;

This factory is used instead of Executers.DefaultThreadFactory to allow manipulation of priority and thread owner name.

PrivateBinder - Interface in org.elasticsearch.util.inject
Returns a binder whose configuration information is hidden from its environment by default.
PrivateElements - Interface in org.elasticsearch.util.inject.spi
A private collection of elements that are hidden from the enclosing injector or module by default.
PrivateElementsImpl - Class in org.elasticsearch.util.inject.internal
 
PrivateElementsImpl(Object) - Constructor for class org.elasticsearch.util.inject.internal.PrivateElementsImpl
 
PrivateModule - Class in org.elasticsearch.util.inject
A module whose configuration information is hidden from its environment by default.
PrivateModule() - Constructor for class org.elasticsearch.util.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.stats.NodeStats
Process level statistics.
processAnalyzers(MapBinder<String, AnalyzerProviderFactory>, Map<String, Settings>) - Method in interface org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor
 
ProcessedClusterStateUpdateTask - Interface in org.elasticsearch.cluster
An extension interface to ClusterStateUpdateTask that allows to be notified when the cluster state update has been processed.
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) - 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
 
processModule(Module) - Method in class org.elasticsearch.plugins.AbstractPlugin
 
processModule(Module) - Method in interface org.elasticsearch.plugins.Plugin
 
processModules(Iterable<Module>) - Method in class org.elasticsearch.plugins.PluginsService
 
processPayload(Similarity) - Method in class org.elasticsearch.util.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
ProcessProbe - Interface in org.elasticsearch.monitor.process
 
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.Fd - Class in org.elasticsearch.monitor.process
 
ProcessStats.Mem - Class in org.elasticsearch.monitor.process
 
processTokenFilters(MapBinder<String, TokenFilterFactoryFactory>, Map<String, Settings>) - Method in interface org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor
 
processTokenizers(MapBinder<String, TokenizerFactoryFactory>, Map<String, Settings>) - Method in interface org.elasticsearch.index.analysis.AnalysisModule.AnalysisBinderProcessor
 
PropertiesSettingsLoader - Class in org.elasticsearch.util.settings.loader
Settings loader that loads (parses) the settings in a properties format.
PropertiesSettingsLoader() - Constructor for class org.elasticsearch.util.settings.loader.PropertiesSettingsLoader
 
PropertyPlaceholder - Class in org.elasticsearch.util
Utility class for working with Strings that have placeholder values in them.
PropertyPlaceholder(String, String) - Constructor for class org.elasticsearch.util.PropertyPlaceholder
Creates a new PropertyPlaceholderHelper that uses the supplied prefix and suffix.
PropertyPlaceholder(String, String, boolean) - Constructor for class org.elasticsearch.util.PropertyPlaceholder
Creates a new PropertyPlaceholderHelper that uses the supplied prefix and suffix.
PropertyPlaceholder.PlaceholderResolver - Interface in org.elasticsearch.util
Strategy interface used to resolve replacement values for placeholders contained in Strings.
PROPOSED - Static variable in interface org.elasticsearch.util.ThreadNameDeterminer
ThreadNameDeterminer that accepts the proposed thread name as is.
ProvidedBy - Annotation Type in org.elasticsearch.util.inject
A pointer to the default provider type for a type.
Provider<T> - Interface in org.elasticsearch.util.inject
An object capable of providing instances of type T.
ProviderBinding<T extends Provider<?>> - Interface in org.elasticsearch.util.inject.spi
A binding to a Provider that delegates to the binding for the provided type.
ProviderInstanceBinding<T> - Interface in org.elasticsearch.util.inject.spi
A binding to a provider instance.
ProviderInstanceBindingImpl<T> - Class in org.elasticsearch.util.inject.internal
 
ProviderInstanceBindingImpl(Injector, Key<T>, Object, InternalFactory<? extends T>, Scoping, Provider<? extends T>, Set<InjectionPoint>) - Constructor for class org.elasticsearch.util.inject.internal.ProviderInstanceBindingImpl
 
ProviderInstanceBindingImpl(Object, Key<T>, Scoping, Set<InjectionPoint>, Provider<? extends T>) - Constructor for class org.elasticsearch.util.inject.internal.ProviderInstanceBindingImpl
 
ProviderKeyBinding<T> - Interface in org.elasticsearch.util.inject.spi
A binding to a provider key.
ProviderLookup<T> - Class in org.elasticsearch.util.inject.spi
A lookup of the provider for a type.
ProviderLookup(Object, Key<T>) - Constructor for class org.elasticsearch.util.inject.spi.ProviderLookup
 
ProviderMethod<T> - Class in org.elasticsearch.util.inject.internal
A provider that invokes a method and returns its result.
ProviderMethodsModule - Class in org.elasticsearch.util.inject.internal
Creates bindings to methods annotated with @Provides.
providerOf(Type) - Static method in class org.elasticsearch.util.inject.util.Types
Returns a type modelling a Provider that provides elements of type elementType.
Providers - Class in org.elasticsearch.util.inject.util
Static utility methods for creating and working with instances of Provider.
ProviderWithDependencies<T> - Interface in org.elasticsearch.util.inject.spi
A provider with dependencies on other injected types.
Provides - Annotation Type in org.elasticsearch.util.inject
Annotates methods of a Module to create a provider method binding.
ProvisionException - Exception in org.elasticsearch.util.inject
Indicates that there was a runtime failure while providing an instance.
ProvisionException(Iterable<Message>) - Constructor for exception org.elasticsearch.util.inject.ProvisionException
Creates a ConfigurationException containing messages.
ProvisionException(String, Throwable) - Constructor for exception org.elasticsearch.util.inject.ProvisionException
 
ProvisionException(String) - Constructor for exception org.elasticsearch.util.inject.ProvisionException
 
PublicBooleanFilter - Class in org.apache.lucene.search
 
PublicBooleanFilter() - Constructor for class org.apache.lucene.search.PublicBooleanFilter
 
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
 
publishAddress() - Method in class org.elasticsearch.util.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
 
publishUrl() - Method in class org.elasticsearch.jmx.JmxService
 
push(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteStack
Pushes the value onto the top of the stack.
push(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleStack
Pushes the value onto the top of the stack.
push(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatStack
Pushes the value onto the top of the stack.
push(int) - Method in class org.elasticsearch.util.gnu.trove.TIntStack
Pushes the value onto the top of the stack.
push(long) - Method in class org.elasticsearch.util.gnu.trove.TLongStack
Pushes the value onto the top of the stack.
push(short) - Method in class org.elasticsearch.util.gnu.trove.TShortStack
Pushes the value onto the top of the stack.
PUT - Static variable in class org.elasticsearch.action.TransportActions.Admin.Indices.Mapping
 
put(IndexMetaData.Builder) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
put(IndexMetaData) - 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 interface org.elasticsearch.util.collect.BiMap
put(K, V) - Method in class org.elasticsearch.util.collect.EnumHashBiMap
 
put(K, V) - Method in class org.elasticsearch.util.collect.ForwardingMap
 
put(K, V) - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
put(K, V) - Method in class org.elasticsearch.util.collect.HashBiMap
 
put(K, V) - Method in class org.elasticsearch.util.collect.ImmutableBiMap.Builder
Associates key with value in the built bimap.
put(Class<T>, T) - Method in class org.elasticsearch.util.collect.ImmutableClassToInstanceMap.Builder
Associates key with value in the built map.
put(K, V) - Method in class org.elasticsearch.util.collect.ImmutableListMultimap.Builder
Adds a key-value mapping to the built multimap.
put(K, V) - Method in class org.elasticsearch.util.collect.ImmutableMap.Builder
Associates key with value in the built map.
put(K, V) - Method in class org.elasticsearch.util.collect.ImmutableMap
Guaranteed to throw an exception and leave the map unmodified.
put(K, V) - Method in class org.elasticsearch.util.collect.ImmutableMultimap.Builder
Adds a key-value mapping to the built multimap.
put(K, V) - Method in class org.elasticsearch.util.collect.ImmutableMultimap
Guaranteed to throw an exception and leave the multimap unmodified.
put(K, V) - Method in class org.elasticsearch.util.collect.ImmutableSetMultimap.Builder
Adds a key-value mapping to the built multimap if it is not already present.
put(K, V) - Method in class org.elasticsearch.util.collect.ImmutableSortedMap.Builder
Associates key with value in the built map.
put(K, V) - Method in class org.elasticsearch.util.collect.LinkedListMultimap
Stores a key-value pair in the multimap.
put(K, V) - Method in interface org.elasticsearch.util.collect.Multimap
Stores a key-value pair in the multimap.
put(long, T) - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
put(Long, T) - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
put(K, V) - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Maps the specified key to the specified value in this table.
put(long, T) - Method in interface org.elasticsearch.util.concurrent.ConcurrentMapLong
 
put(K, V) - Method in class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
put(TypeK, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Maps the specified key to the specified value in the table.
put(long, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Maps the specified key to the specified value in the table.
put(Long, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Auto-boxing version of NonBlockingHashMapLong.put(long, TypeV).
put(TypeK, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Maps the specified key to the specified value in the table.
put(TypeK, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Maps the specified key to the specified value in the table.
put(E) - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
Inserts the specified element at the tail of this queue.
put(Byte, Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Inserts a key/value pair into the map.
put(Byte, Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Inserts a key/value pair into the map.
put(Byte, Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Inserts a key/value pair into the map.
put(Byte, Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Inserts a key/value pair into the map.
put(Byte, Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Inserts a key/value pair into the map.
put(Byte, V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Inserts a key/value pair into the map.
put(Byte, Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Inserts a key/value pair into the map.
put(Double, Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Inserts a key/value pair into the map.
put(Double, Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Inserts a key/value pair into the map.
put(Double, Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Inserts a key/value pair into the map.
put(Double, Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Inserts a key/value pair into the map.
put(Double, Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Inserts a key/value pair into the map.
put(Double, V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Inserts a key/value pair into the map.
put(Double, Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Inserts a key/value pair into the map.
put(Float, Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Inserts a key/value pair into the map.
put(Float, Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Inserts a key/value pair into the map.
put(Float, Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Inserts a key/value pair into the map.
put(Float, Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Inserts a key/value pair into the map.
put(Float, Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Inserts a key/value pair into the map.
put(Float, V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Inserts a key/value pair into the map.
put(Float, Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Inserts a key/value pair into the map.
put(Integer, Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Inserts a key/value pair into the map.
put(Integer, Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Inserts a key/value pair into the map.
put(Integer, Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Inserts a key/value pair into the map.
put(Integer, Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Inserts a key/value pair into the map.
put(Integer, Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Inserts a key/value pair into the map.
put(Integer, V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Inserts a key/value pair into the map.
put(Integer, Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Inserts a key/value pair into the map.
put(Long, Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Inserts a key/value pair into the map.
put(Long, Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Inserts a key/value pair into the map.
put(Long, Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Inserts a key/value pair into the map.
put(Long, Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Inserts a key/value pair into the map.
put(Long, Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Inserts a key/value pair into the map.
put(Long, V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Inserts a key/value pair into the map.
put(Long, Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Inserts a key/value pair into the map.
put(V, Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Inserts a key/value pair into the map.
put(V, Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Inserts a key/value pair into the map.
put(V, Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Inserts a key/value pair into the map.
put(V, Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Inserts a key/value pair into the map.
put(V, Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Inserts a key/value pair into the map.
put(V, Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Inserts a key/value pair into the map.
put(Short, Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Inserts a key/value pair into the map.
put(Short, Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Inserts a key/value pair into the map.
put(Short, Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Inserts a key/value pair into the map.
put(Short, Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Inserts a key/value pair into the map.
put(Short, Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Inserts a key/value pair into the map.
put(Short, V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Inserts a key/value pair into the map.
put(Short, Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Inserts a key/value pair into the map.
put(byte, byte) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Inserts a key/value pair into the map.
put(byte, double) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Inserts a key/value pair into the map.
put(byte, float) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Inserts a key/value pair into the map.
put(byte, int) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Inserts a key/value pair into the map.
put(byte, long) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Inserts a key/value pair into the map.
put(byte, V) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Inserts a key/value pair into the map.
put(byte, short) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Inserts a key/value pair into the map.
put(double, byte) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Inserts a key/value pair into the map.
put(double, double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Inserts a key/value pair into the map.
put(double, float) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Inserts a key/value pair into the map.
put(double, int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Inserts a key/value pair into the map.
put(double, long) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Inserts a key/value pair into the map.
put(double, V) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Inserts a key/value pair into the map.
put(double, short) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Inserts a key/value pair into the map.
put(float, byte) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Inserts a key/value pair into the map.
put(float, double) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Inserts a key/value pair into the map.
put(float, float) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Inserts a key/value pair into the map.
put(float, int) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Inserts a key/value pair into the map.
put(float, long) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Inserts a key/value pair into the map.
put(float, V) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Inserts a key/value pair into the map.
put(float, short) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Inserts a key/value pair into the map.
put(K, V) - Method in class org.elasticsearch.util.gnu.trove.THashMap
Inserts a key/value pair into the map.
put(int, byte) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Inserts a key/value pair into the map.
put(int, double) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Inserts a key/value pair into the map.
put(int, float) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Inserts a key/value pair into the map.
put(int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Inserts a key/value pair into the map.
put(int, long) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Inserts a key/value pair into the map.
put(int, V) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Inserts a key/value pair into the map.
put(int, short) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Inserts a key/value pair into the map.
put(long, byte) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Inserts a key/value pair into the map.
put(long, double) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Inserts a key/value pair into the map.
put(long, float) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Inserts a key/value pair into the map.
put(long, int) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Inserts a key/value pair into the map.
put(long, long) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Inserts a key/value pair into the map.
put(long, V) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Inserts a key/value pair into the map.
put(long, short) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Inserts a key/value pair into the map.
put(K, byte) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Inserts a key/value pair into the map.
put(K, double) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Inserts a key/value pair into the map.
put(K, float) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Inserts a key/value pair into the map.
put(K, int) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Inserts a key/value pair into the map.
put(K, long) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Inserts a key/value pair into the map.
put(K, short) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Inserts a key/value pair into the map.
put(short, byte) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Inserts a key/value pair into the map.
put(short, double) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Inserts a key/value pair into the map.
put(short, float) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Inserts a key/value pair into the map.
put(short, int) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Inserts a key/value pair into the map.
put(short, long) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Inserts a key/value pair into the map.
put(short, V) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Inserts a key/value pair into the map.
put(short, short) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Inserts a key/value pair into the map.
put(K, V) - Method in class org.elasticsearch.util.MapBuilder
 
put(String, String) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Sets a setting with the provided setting key and value.
put(String, Class) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Sets a setting with the provided setting key and class as value.
put(String, boolean) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Sets the setting with the provided setting key and the boolean value.
put(String, int) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Sets the setting with the provided setting key and the int value.
put(String, long) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Sets the setting with the provided setting key and the long value.
put(String, float) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Sets the setting with the provided setting key and the float value.
put(String, double) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Sets the setting with the provided setting key and the double value.
put(String, long, TimeUnit) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Sets the setting with the provided setting key and the time value.
put(String, long, SizeUnit) - Method in class org.elasticsearch.util.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.util.settings.ImmutableSettings.Builder
Sets the setting group.
put(Settings) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Sets all the provided settings.
put(Map<String, String>) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Sets all the provided settings.
put(Properties) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Sets all the provided settings.
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<? extends K, ? extends V>) - Method in interface org.elasticsearch.util.collect.BiMap
putAll(Map<? extends K, ? extends V>) - Method in class org.elasticsearch.util.collect.ForwardingMap
 
putAll(K, Iterable<? extends V>) - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
putAll(Multimap<? extends K, ? extends V>) - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.elasticsearch.util.collect.ImmutableBiMap.Builder
Associates all of the given map's keys and values in the built bimap.
putAll(Map<? extends Class<? extends T>, ? extends T>) - Method in class org.elasticsearch.util.collect.ImmutableClassToInstanceMap.Builder
Associates all of map's keys and values in the built map.
putAll(K, Iterable<? extends V>) - Method in class org.elasticsearch.util.collect.ImmutableListMultimap.Builder
Stores a collection of values with the same key in the built multimap.
putAll(K, V...) - Method in class org.elasticsearch.util.collect.ImmutableListMultimap.Builder
Stores an array of values with the same key in the built multimap.
putAll(Multimap<? extends K, ? extends V>) - Method in class org.elasticsearch.util.collect.ImmutableListMultimap.Builder
Stores another multimap's entries in the built multimap.
putAll(Map<? extends K, ? extends V>) - Method in class org.elasticsearch.util.collect.ImmutableMap.Builder
Associates all of the given map's keys and values in the built map.
putAll(Map<? extends K, ? extends V>) - Method in class org.elasticsearch.util.collect.ImmutableMap
Guaranteed to throw an exception and leave the map unmodified.
putAll(K, Iterable<? extends V>) - Method in class org.elasticsearch.util.collect.ImmutableMultimap.Builder
Stores a collection of values with the same key in the built multimap.
putAll(K, V...) - Method in class org.elasticsearch.util.collect.ImmutableMultimap.Builder
Stores an array of values with the same key in the built multimap.
putAll(Multimap<? extends K, ? extends V>) - Method in class org.elasticsearch.util.collect.ImmutableMultimap.Builder
Stores another multimap's entries in the built multimap.
putAll(K, Iterable<? extends V>) - Method in class org.elasticsearch.util.collect.ImmutableMultimap
Guaranteed to throw an exception and leave the multimap unmodified.
putAll(Multimap<? extends K, ? extends V>) - Method in class org.elasticsearch.util.collect.ImmutableMultimap
Guaranteed to throw an exception and leave the multimap unmodified.
putAll(K, Iterable<? extends V>) - Method in class org.elasticsearch.util.collect.ImmutableSetMultimap.Builder
Stores a collection of values with the same key in the built multimap.
putAll(K, V...) - Method in class org.elasticsearch.util.collect.ImmutableSetMultimap.Builder
Stores an array of values with the same key in the built multimap.
putAll(Multimap<? extends K, ? extends V>) - Method in class org.elasticsearch.util.collect.ImmutableSetMultimap.Builder
Stores another multimap's entries in the built multimap.
putAll(Map<? extends K, ? extends V>) - Method in class org.elasticsearch.util.collect.ImmutableSortedMap.Builder
Associates all of the given map's keys and values in the built map.
putAll(K, Iterable<? extends V>) - Method in class org.elasticsearch.util.collect.LinkedListMultimap
 
putAll(Multimap<? extends K, ? extends V>) - Method in class org.elasticsearch.util.collect.LinkedListMultimap
 
putAll(K, Iterable<? extends V>) - Method in interface org.elasticsearch.util.collect.Multimap
Stores a collection of values with the same key.
putAll(Multimap<? extends K, ? extends V>) - Method in interface org.elasticsearch.util.collect.Multimap
Copies all of another multimap's key-value pairs into this multimap.
putAll(Map<? extends Long, ? extends T>) - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
putAll(Map<? extends K, ? extends V>) - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Copies all of the mappings from the specified map to this one.
putAll(Map<? extends K, ? extends V>) - Method in class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
putAll(Map<? extends TypeK, ? extends TypeV>) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Copies all of the mappings from the specified map to this one, replacing any existing mappings.
putAll(Map<? extends TypeK, ? extends TypeV>) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Copies all of the mappings from the specified map to this one, replacing any existing mappings.
putAll(Map<? extends TypeK, ? extends TypeV>) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Copies all of the mappings from the specified map to this one, replacing any existing mappings.
putAll(Map<? extends Byte, ? extends Byte>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Byte, ? extends Double>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Byte, ? extends Float>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Byte, ? extends Integer>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Byte, ? extends Long>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Byte, ? extends V>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Byte, ? extends Short>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Double, ? extends Byte>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Double, ? extends Double>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Double, ? extends Float>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Double, ? extends Integer>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Double, ? extends Long>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Double, ? extends V>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Double, ? extends Short>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Float, ? extends Byte>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Float, ? extends Double>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Float, ? extends Float>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Float, ? extends Integer>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Float, ? extends Long>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Float, ? extends V>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Float, ? extends Short>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Integer, ? extends Byte>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Integer, ? extends Double>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Integer, ? extends Float>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Integer, ? extends Integer>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Integer, ? extends Long>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Integer, ? extends V>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Integer, ? extends Short>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Long, ? extends Byte>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Long, ? extends Double>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Long, ? extends Float>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Long, ? extends Integer>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Long, ? extends Long>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Long, ? extends V>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Long, ? extends Short>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends V, ? extends Byte>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends V, ? extends Double>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends V, ? extends Float>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends V, ? extends Integer>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends V, ? extends Long>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends V, ? extends Short>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Short, ? extends Byte>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Short, ? extends Double>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Short, ? extends Float>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Short, ? extends Integer>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Short, ? extends Long>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Short, ? extends V>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(Map<? extends Short, ? extends Short>) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Copies the key/value mappings in map into this map.
putAll(TByteByteHashMap) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Put all the entries from the given map into this map.
putAll(TByteDoubleHashMap) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Put all the entries from the given map into this map.
putAll(TByteFloatHashMap) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Put all the entries from the given map into this map.
putAll(TByteIntHashMap) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Put all the entries from the given map into this map.
putAll(TByteLongHashMap) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Put all the entries from the given map into this map.
putAll(TByteObjectHashMap<V>) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Put all the entries from the given map into this map.
putAll(TByteShortHashMap) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Put all the entries from the given map into this map.
putAll(TDoubleByteHashMap) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Put all the entries from the given map into this map.
putAll(TDoubleDoubleHashMap) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Put all the entries from the given map into this map.
putAll(TDoubleFloatHashMap) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Put all the entries from the given map into this map.
putAll(TDoubleIntHashMap) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Put all the entries from the given map into this map.
putAll(TDoubleLongHashMap) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Put all the entries from the given map into this map.
putAll(TDoubleObjectHashMap<V>) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Put all the entries from the given map into this map.
putAll(TDoubleShortHashMap) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Put all the entries from the given map into this map.
putAll(TFloatByteHashMap) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Put all the entries from the given map into this map.
putAll(TFloatDoubleHashMap) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Put all the entries from the given map into this map.
putAll(TFloatFloatHashMap) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Put all the entries from the given map into this map.
putAll(TFloatIntHashMap) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Put all the entries from the given map into this map.
putAll(TFloatLongHashMap) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Put all the entries from the given map into this map.
putAll(TFloatObjectHashMap<V>) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Put all the entries from the given map into this map.
putAll(TFloatShortHashMap) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Put all the entries from the given map into this map.
putAll(Map<? extends K, ? extends V>) - Method in class org.elasticsearch.util.gnu.trove.THashMap
copies the key/value mappings in map into this map.
putAll(TIntByteHashMap) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Put all the entries from the given map into this map.
putAll(TIntDoubleHashMap) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Put all the entries from the given map into this map.
putAll(TIntFloatHashMap) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Put all the entries from the given map into this map.
putAll(TIntIntHashMap) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Put all the entries from the given map into this map.
putAll(TIntLongHashMap) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Put all the entries from the given map into this map.
putAll(TIntObjectHashMap<V>) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Put all the entries from the given map into this map.
putAll(TIntShortHashMap) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Put all the entries from the given map into this map.
putAll(TLongByteHashMap) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Put all the entries from the given map into this map.
putAll(TLongDoubleHashMap) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Put all the entries from the given map into this map.
putAll(TLongFloatHashMap) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Put all the entries from the given map into this map.
putAll(TLongIntHashMap) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Put all the entries from the given map into this map.
putAll(TLongLongHashMap) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Put all the entries from the given map into this map.
putAll(TLongObjectHashMap<V>) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Put all the entries from the given map into this map.
putAll(TLongShortHashMap) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Put all the entries from the given map into this map.
putAll(TObjectByteHashMap<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Put all the entries from the given map into this map.
putAll(TObjectDoubleHashMap<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Put all the entries from the given map into this map.
putAll(TObjectFloatHashMap<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Put all the entries from the given map into this map.
putAll(TObjectIntHashMap<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Put all the entries from the given map into this map.
putAll(TObjectLongHashMap<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Put all the entries from the given map into this map.
putAll(TObjectShortHashMap<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Put all the entries from the given map into this map.
putAll(TShortByteHashMap) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Put all the entries from the given map into this map.
putAll(TShortDoubleHashMap) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Put all the entries from the given map into this map.
putAll(TShortFloatHashMap) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Put all the entries from the given map into this map.
putAll(TShortIntHashMap) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Put all the entries from the given map into this map.
putAll(TShortLongHashMap) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Put all the entries from the given map into this map.
putAll(TShortObjectHashMap<V>) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Put all the entries from the given map into this map.
putAll(TShortShortHashMap) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Put all the entries from the given map into this map.
putAll(Map<K, V>) - Method in class org.elasticsearch.util.MapBuilder
 
putArray(String, String...) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Sets the setting with the provided setting key and an array of values.
putIfAbsent(K, V) - Method in class org.elasticsearch.util.collect.ForwardingConcurrentMap
 
putIfAbsent(long, T) - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
putIfAbsent(Long, T) - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
putIfAbsent(K, V) - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
putIfAbsent(long, T) - Method in interface org.elasticsearch.util.concurrent.ConcurrentMapLong
 
putIfAbsent(K, V) - Method in class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
putIfAbsent(TypeK, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Atomically, do a NonBlockingHashMap.put(TypeK, TypeV) if-and-only-if the key is not mapped.
putIfAbsent(long, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Atomically, do a NonBlockingHashMapLong.put(long, TypeV) if-and-only-if the key is not mapped.
putIfAbsent(Long, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Auto-boxing version of NonBlockingHashMapLong.putIfAbsent(long, TypeV).
putIfAbsent(TypeK, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Atomically, do a NonBlockingHashtable.put(TypeK, TypeV) if-and-only-if the key is not mapped.
putIfAbsent(TypeK, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Atomically, do a NonBlockingIdentityHashMap.put(TypeK, TypeV) if-and-only-if the key is not mapped.
putIfAbsent(byte, byte) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(byte, double) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(byte, float) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(byte, int) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(byte, long) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(byte, V) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(byte, short) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(double, byte) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(double, double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(double, float) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(double, int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(double, long) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(double, V) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(double, short) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(float, byte) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(float, double) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(float, float) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(float, int) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(float, long) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(float, V) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(float, short) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(K, V) - Method in class org.elasticsearch.util.gnu.trove.THashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(int, byte) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(int, double) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(int, float) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(int, long) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(int, V) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(int, short) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(long, byte) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(long, double) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(long, float) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(long, int) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(long, long) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(long, V) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(long, short) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(K, byte) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(K, double) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(K, float) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(K, int) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(K, long) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(K, short) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(short, byte) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(short, double) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(short, float) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(short, int) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(short, long) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(short, V) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putIfAbsent(short, short) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Inserts a key/value pair into the map if the specified key is not already associated with a value.
putInstance(Class<T>, T) - Method in interface org.elasticsearch.util.collect.ClassToInstanceMap
Maps the specified class to the specified value.
putInstance(Class<T>, T) - Method in class org.elasticsearch.util.collect.ImmutableClassToInstanceMap
Guaranteed to throw an exception and leave the map unmodified.
putInstance(Class<T>, T) - Method in class org.elasticsearch.util.collect.MutableClassToInstanceMap
 
putMapper(XContentMapper) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper
 
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.node.NodeIndicesAdminClient
 
putMapping(PutMappingRequest, ActionListener<PutMappingResponse>) - Method in class org.elasticsearch.client.node.NodeIndicesAdminClient
 
putMapping(PutMappingRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
putMapping(PutMappingRequest, ActionListener<PutMappingResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
putMapping(String, String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
putMapping(String[], String, String, boolean, TimeValue) - Method in class org.elasticsearch.cluster.metadata.MetaDataService
 
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.
PutMappingResponse - Class in org.elasticsearch.action.admin.indices.mapping.put
The response of put mapping operation.
putNodeAttribute(String, String) - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
 
putProperties(String, Properties) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Puts all the properties with keys starting with the provided prefix.
putTypeParser(String, XContentTypeParser) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapperParser
 
putVersion(int, int) - Method in class org.elasticsearch.util.lucene.versioned.ConcurrentVersionedMap
 
putVersion(int, int) - Method in class org.elasticsearch.util.lucene.versioned.ConcurrentVersionedMapLong
 
putVersion(int, int) - Method in class org.elasticsearch.util.lucene.versioned.NativeVersionedMap
 
putVersion(int, int) - Method in interface org.elasticsearch.util.lucene.versioned.VersionedMap
Puts (and replaces if it exists) the current key with the provided version.
putVersionIfAbsent(int, int) - Method in class org.elasticsearch.util.lucene.versioned.ConcurrentVersionedMap
 
putVersionIfAbsent(int, int) - Method in class org.elasticsearch.util.lucene.versioned.ConcurrentVersionedMapLong
 
putVersionIfAbsent(int, int) - Method in class org.elasticsearch.util.lucene.versioned.NativeVersionedMap
 
putVersionIfAbsent(int, int) - Method in interface org.elasticsearch.util.lucene.versioned.VersionedMap
Puts the version with the key only if it is absent.

Q

Queries - Class in org.elasticsearch.util.lucene.search
 
Queries() - Constructor for class org.elasticsearch.util.lucene.search.Queries
 
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(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() - Method in class org.elasticsearch.index.engine.Engine.DeleteByQuery
 
query(XContentQueryBuilder) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Constructs a new search source builder with a search query.
query() - Method in class org.elasticsearch.search.facets.SearchContextFacets.QueryFacet
 
query(Query) - Method in class org.elasticsearch.search.internal.SearchContext
 
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.xcontent.XContentIndexQueryParser.Defaults
 
QUERY_THEN_FETCH_TYPE - Static variable in class org.elasticsearch.action.search.type.ParsedScrollId
 
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.xcontent
A static factory for simple "import static" usage.
queryExecution(String) - Method in class org.elasticsearch.search.builder.SearchSourceFacetsBuilder
Controls the type of query facet execution.
queryFacets() - Method in class org.elasticsearch.search.facets.SearchContextFacets
 
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(XContentQueryBuilder) - Static method in class org.elasticsearch.index.query.xcontent.FilterBuilders
A filter that simply wraps a query.
QueryFilterBuilder - Class in org.elasticsearch.index.query.xcontent
A filter that simply wraps a query.
QueryFilterBuilder(XContentQueryBuilder) - Constructor for class org.elasticsearch.index.query.xcontent.QueryFilterBuilder
A filter that simply wraps a query.
QueryFilterParser - Class in org.elasticsearch.index.query.xcontent
 
QueryFilterParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.QueryFilterParser
 
queryHint(String) - Method in class org.elasticsearch.action.admin.cluster.ping.broadcast.BroadcastPingRequest
 
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.
queryHint - Variable in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
queryHint() - Method in class org.elasticsearch.action.support.broadcast.BroadcastOperationRequest
 
QueryParseContext - Class in org.elasticsearch.index.query.xcontent
 
QueryParseContext(Index, XContentQueryParserRegistry, MapperService, SimilarityService, IndexCache) - Constructor for class org.elasticsearch.index.query.xcontent.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.xcontent.XContentQueryParserRegistry
 
queryParser() - Method in class org.elasticsearch.search.internal.SearchContext
 
queryParserName(String) - Method in class org.elasticsearch.action.count.CountRequest
The query parse name to use.
queryParserName(String) - Method in class org.elasticsearch.action.deletebyquery.DeleteByQueryRequest
The query parse name to use.
queryParserName(String) - Method in class org.elasticsearch.action.deletebyquery.IndexDeleteByQueryRequest
 
queryParserName() - Method in class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryRequest
 
queryParserName() - Method in class org.elasticsearch.index.engine.Engine.DeleteByQuery
 
queryParserName() - Method in class org.elasticsearch.index.translog.Translog.DeleteByQuery
 
queryParserName(String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
An optional query parser name to use.
queryParserName() - Method in class org.elasticsearch.search.internal.SearchContext
 
queryParserName(String) - Method in class org.elasticsearch.search.internal.SearchContext
 
QueryParserNameParseElement - Class in org.elasticsearch.search.query
 
QueryParserNameParseElement() - Constructor for class org.elasticsearch.search.query.QueryParserNameParseElement
 
queryParserRegistry() - Method in class org.elasticsearch.index.query.xcontent.XContentIndexQueryParser
 
QueryParsers - Class in org.elasticsearch.index.query.support
 
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
 
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(FacetsPhase) - 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
 
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
 
querySource(QueryBuilder) - Method in class org.elasticsearch.action.deletebyquery.IndexDeleteByQueryRequest
 
querySource(byte[]) - Method in class org.elasticsearch.action.deletebyquery.IndexDeleteByQueryRequest
 
querySource() - Method in class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryRequest
 
queryString(String) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A query that parses a query string and runs it.
QueryStringQueryBuilder - Class in org.elasticsearch.index.query.xcontent
A query that parses a query string and runs it.
QueryStringQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.xcontent.QueryStringQueryBuilder
 
QueryStringQueryBuilder.Operator - Enum in org.elasticsearch.index.query.xcontent
 
QueryStringQueryParser - Class in org.elasticsearch.index.query.xcontent
 
QueryStringQueryParser(Index, Settings, AnalysisService) - Constructor for class org.elasticsearch.index.query.xcontent.QueryStringQueryParser
 
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.xcontent.XContentAllFieldMapper
 
queryStringTermQuery(Term) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
queryType() - Method in class org.elasticsearch.search.facets.SearchContextFacets
 
quietlyHelpJoin() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Possibly executes other tasks until this task is done.
quietlyInvoke() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Commences performing this task and awaits its completion if necessary, without returning its result or throwing an exception.
quietlyJoin() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Joins this task, without returning its result or throwing an exception.
quote(String) - Static method in class org.elasticsearch.util.Strings
Quote the given String with single quotes.
quoteIfString(Object) - Static method in class org.elasticsearch.util.Strings
Turn the given Object into a String with single quotes if it is a String; keeping the Object as-is else.

R

raiseNodeConnected(DiscoveryNode) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
 
raiseNodeDisconnected(DiscoveryNode) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
 
RamStore - Class in org.elasticsearch.index.store.ram
 
RamStore(ShardId, Settings) - Constructor for class org.elasticsearch.index.store.ram.RamStore
 
RamStoreModule - Class in org.elasticsearch.index.store.ram
 
RamStoreModule() - Constructor for class org.elasticsearch.index.store.ram.RamStoreModule
 
randomNodeName(URL) - Static method in class org.elasticsearch.util.Names
 
randomNodeName(InputStream) - Static method in class org.elasticsearch.util.Names
 
randomUUID() - Static method in class org.elasticsearch.util.UUID
Static factory to retrieve a type 4 (pseudo randomly generated) UUID.
rangeFilter(String, String, boolean, boolean) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Constructs a range query filter based on the mapper.
rangeFilter(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
rangeFilter(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
 
rangeFilter(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper
 
rangeFilter(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
rangeFilter(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper
 
rangeFilter(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper
 
rangeFilter(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper
 
rangeFilter(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
 
rangeFilter(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper
 
rangeFilter(String) - Static method in class org.elasticsearch.index.query.xcontent.FilterBuilders
A filter that restricts search results to values that are within the given range.
RangeFilterBuilder - Class in org.elasticsearch.index.query.xcontent
A filter that restricts search results to values that are within the given range.
RangeFilterBuilder(String) - Constructor for class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
A filter that restricts search results to values that are within the given range.
RangeFilterParser - Class in org.elasticsearch.index.query.xcontent
 
RangeFilterParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.RangeFilterParser
 
rangeQuery(String, String, boolean, boolean) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Constructs a range query based on the mapper.
rangeQuery(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
rangeQuery(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
 
rangeQuery(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper
 
rangeQuery(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
rangeQuery(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper
 
rangeQuery(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper
 
rangeQuery(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper
 
rangeQuery(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
 
rangeQuery(String, String, boolean, boolean) - Method in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper
 
rangeQuery(String) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A Query that matches documents within an range of terms.
RangeQueryBuilder - Class in org.elasticsearch.index.query.xcontent
A Query that matches documents within an range of terms.
RangeQueryBuilder(String) - Constructor for class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
A Query that matches documents within an range of terms.
RangeQueryParser - Class in org.elasticsearch.index.query.xcontent
 
RangeQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.RangeQueryParser
 
raw(byte[]) - Method in class org.elasticsearch.util.xcontent.builder.BinaryXContentBuilder
 
raw(byte[]) - Method in class org.elasticsearch.util.xcontent.builder.TextXContentBuilder
 
raw(byte[]) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
rawField(String, byte[]) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
read() - Method in class org.elasticsearch.gateway.fs.FsGateway
 
read() - Method in interface org.elasticsearch.gateway.Gateway
 
read() - Method in class org.elasticsearch.gateway.none.NoneGateway
 
read() - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
 
read(byte[], int, int) - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
 
read() - Method in class org.elasticsearch.util.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.util.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.util.io.FastByteArrayInputStream
Reads the next byte of data from this input stream.
read(byte[], int, int) - Method in class org.elasticsearch.util.io.FastByteArrayInputStream
Reads up to len bytes of data into an array of bytes from this input stream.
read() - Method in class org.elasticsearch.util.io.FastCharArrayReader
Reads a single character.
read(char[], int, int) - Method in class org.elasticsearch.util.io.FastCharArrayReader
Reads characters into a portion of an array.
read() - Method in class org.elasticsearch.util.io.FastStringReader
Reads a single character.
read(char[], int, int) - Method in class org.elasticsearch.util.io.FastStringReader
Reads characters into a portion of an array.
read() - Method in class org.elasticsearch.util.io.stream.BytesStreamInput
 
read(byte[], int, int) - Method in class org.elasticsearch.util.io.stream.BytesStreamInput
 
read() - Method in class org.elasticsearch.util.io.stream.DataInputStreamInput
 
read() - Method in class org.elasticsearch.util.io.stream.HandlesStreamInput
 
read(byte[]) - Method in class org.elasticsearch.util.io.stream.HandlesStreamInput
 
read(byte[], int, int) - Method in class org.elasticsearch.util.io.stream.HandlesStreamInput
 
read() - Method in class org.elasticsearch.util.io.stream.InputStreamStreamInput
 
read(byte[]) - Method in class org.elasticsearch.util.io.stream.InputStreamStreamInput
 
read(byte[], int, int) - Method in class org.elasticsearch.util.io.stream.InputStreamStreamInput
 
read(char[], int, int) - Method in class org.elasticsearch.util.lucene.all.AllEntries
 
read(byte[], int, int) - Method in class org.elasticsearch.util.lucene.store.InputStreamIndexInput
 
read() - Method in class org.elasticsearch.util.lucene.store.InputStreamIndexInput
 
readAggregatedDfs(StreamInput) - Static method in class org.elasticsearch.search.dfs.AggregatedDfs
 
readAliasAction(StreamInput) - Static method in class org.elasticsearch.cluster.metadata.AliasAction
 
readAllowed() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
readBoolean() - Method in class org.elasticsearch.util.io.stream.StreamInput
Reads a boolean.
readBoundTransportAddress(StreamInput) - Static method in class org.elasticsearch.util.transport.BoundTransportAddress
 
readByte() - Method in class org.elasticsearch.index.store.memory.ByteBufferIndexInput
 
readByte() - Method in class org.elasticsearch.index.store.memory.HeapIndexInput
 
readByte() - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
 
readByte() - Method in class org.elasticsearch.util.io.stream.BytesStreamInput
 
readByte() - Method in class org.elasticsearch.util.io.stream.DataInputStreamInput
 
readByte() - Method in class org.elasticsearch.util.io.stream.HandlesStreamInput
 
readByte() - Method in class org.elasticsearch.util.io.stream.InputStreamStreamInput
 
readByte() - Method in class org.elasticsearch.util.io.stream.StreamInput
Reads and returns a single byte.
readBytes(byte[], int, int) - Method in class org.elasticsearch.index.store.memory.ByteBufferIndexInput
 
readBytes(byte[], int, int) - Method in class org.elasticsearch.index.store.memory.HeapIndexInput
 
readBytes(byte[], int, int) - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
 
readBytes(byte[], int, int) - Method in class org.elasticsearch.util.io.stream.BytesStreamInput
 
readBytes(byte[], int, int) - Method in class org.elasticsearch.util.io.stream.DataInputStreamInput
 
readBytes(byte[], int, int) - Method in class org.elasticsearch.util.io.stream.HandlesStreamInput
 
readBytes(byte[], int, int) - Method in class org.elasticsearch.util.io.stream.InputStreamStreamInput
 
readBytes(byte[], int, int) - Method in class org.elasticsearch.util.io.stream.StreamInput
Reads a specified number of bytes into an array at the specified offset.
readClassDescriptor() - Method in class org.elasticsearch.util.io.ThrowableObjectInputStream
 
readClusterIndexHealth(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
readClusterName(StreamInput) - Static method in class org.elasticsearch.cluster.ClusterName
 
readCompressedString(StreamInput) - Static method in class org.elasticsearch.util.io.compression.CompressedString
 
readCountFacet(StreamInput) - Static method in class org.elasticsearch.search.facets.CountFacet
 
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
 
readDouble() - Method in class org.elasticsearch.util.io.stream.StreamInput
 
reader - Static variable in class org.apache.lucene.search.vectorhighlight.CustomFieldQuery
 
reader() - Method in interface org.elasticsearch.index.engine.Engine.Searcher
 
reader() - Method in class org.elasticsearch.util.lucene.all.AllEntries.Entry
 
reader() - Method in class org.elasticsearch.util.lucene.ReaderSearcherHolder
 
ReaderSearcherHolder - Class in org.elasticsearch.util.lucene
A very simple holder for a tuple of reader and searcher.
ReaderSearcherHolder(IndexReader) - Constructor for class org.elasticsearch.util.lucene.ReaderSearcherHolder
 
ReaderSearcherHolder(IndexReader, IndexSearcher) - Constructor for class org.elasticsearch.util.lucene.ReaderSearcherHolder
 
readExplanation(StreamInput) - Static method in class org.elasticsearch.util.lucene.Lucene
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteHashSetDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleHashSetDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatHashSetDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntHashSetDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongHashSetDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortHashSetDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TByteHashSet
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHashSet
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TFloatHashSet
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.THash
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.THashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.THashSet
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TIntHashSet
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TLongHashSet
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TObjectHash
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TShortHashSet
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
 
readExternal(ObjectInput) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
 
readFacets(StreamInput) - Static method in class org.elasticsearch.search.facets.Facets
 
readFd(StreamInput) - Static method in class org.elasticsearch.monitor.process.ProcessStats.Fd
 
readFetchSearchResult(StreamInput) - Static method in class org.elasticsearch.search.fetch.FetchSearchResult
 
readFieldTermsFreq(StreamInput) - Static method in class org.elasticsearch.action.terms.FieldTermsFreq
 
readFieldValue(StreamInput) - Static method in class org.elasticsearch.util.lucene.Lucene
 
readFloat() - Method in class org.elasticsearch.util.io.stream.StreamInput
 
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.info.NodeInfo
 
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.shutdown.TransportNodesShutdownAction.NodeShutdownRequest
 
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.ping.broadcast.BroadcastPingRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.ping.broadcast.BroadcastPingResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.ping.broadcast.BroadcastShardPingRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.ping.broadcast.BroadcastShardPingResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.IndexReplicationPingRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.IndexReplicationPingResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.ReplicationPingResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.ShardReplicationPingRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.ShardReplicationPingResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.ping.single.SinglePingRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.cluster.ping.single.SinglePingResponse
 
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.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.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.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.gateway.snapshot.IndexGatewaySnapshotRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.IndexGatewaySnapshotResponse
 
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.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.status.IndicesStatusResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
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.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.get.GetField
 
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.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.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.ShardOperationRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.single.SingleOperationRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.support.single.TransportSingleOperationAction.ShardSingleOperationRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.terms.FieldTermsFreq
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.terms.TermFreq
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.terms.TermsRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.action.terms.TermsResponse
 
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.NodeMappingCreatedAction.NodeMappingCreatedResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.cluster.ClusterName
 
readFrom(StreamInput, Settings, DiscoveryNode) - Static method in class org.elasticsearch.cluster.ClusterState.Builder
 
readFrom(StreamInput) - Method in class org.elasticsearch.cluster.metadata.AliasAction
 
readFrom(StreamInput, Settings) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
readFrom(StreamInput, Settings) - Static method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
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, 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.discovery.zen.ping.ZenPing.PingResponse
 
readFrom(StreamInput) - Method in class org.elasticsearch.index.Index
 
readFrom(StreamInput) - Method in class org.elasticsearch.index.shard.ShardId
 
readFrom(StreamInput) - Method in class org.elasticsearch.index.translog.memory.MemorySnapshot
 
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.monitor.jvm.JvmInfo.Mem
 
readFrom(StreamInput) - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
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
 
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.Fd
 
readFrom(StreamInput) - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
readFrom(StreamInput) - Method in class org.elasticsearch.monitor.process.ProcessStats
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.dfs.AggregatedDfs
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facets.CountFacet
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.facets.Facets
 
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.highlight.HighlightField
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
readFrom(StreamInput, TIntObjectHashMap<SearchShardTarget>) - 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) - 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.Scroll
 
readFrom(StreamInput) - Method in class org.elasticsearch.search.SearchShardTarget
 
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.transport.TransportInfo
 
readFrom(StreamInput) - Method in class org.elasticsearch.transport.TransportStats
 
readFrom(StreamInput) - Method in class org.elasticsearch.util.io.BooleanStreamable
 
readFrom(StreamInput) - Method in class org.elasticsearch.util.io.compression.CompressedString
 
readFrom(StreamInput) - Method in class org.elasticsearch.util.io.stream.LongStreamable
 
readFrom(StreamInput) - Method in interface org.elasticsearch.util.io.stream.Streamable
 
readFrom(StreamInput) - Method in class org.elasticsearch.util.io.stream.StringStreamable
 
readFrom(StreamInput) - Method in class org.elasticsearch.util.io.stream.VoidStreamable
 
readFrom(StreamInput) - Method in class org.elasticsearch.util.Percent
 
readFrom(StreamInput) - Method in class org.elasticsearch.util.SizeValue
 
readFrom(StreamInput) - Method in class org.elasticsearch.util.TimeValue
 
readFrom(StreamInput) - Method in class org.elasticsearch.util.transport.BoundTransportAddress
 
readFrom(StreamInput) - Method in class org.elasticsearch.util.transport.DummyTransportAddress
 
readFrom(StreamInput) - Method in class org.elasticsearch.util.transport.InetSocketTransportAddress
 
readFrom(StreamInput) - Method in class org.elasticsearch.util.transport.LocalTransportAddress
 
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
 
readFully(byte[]) - Method in class org.elasticsearch.util.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
 
readGetField(StreamInput) - Static method in class org.elasticsearch.action.get.GetField
 
readHighlightField(StreamInput) - Static method in class org.elasticsearch.search.highlight.HighlightField
 
readIndexName(StreamInput) - Static method in class org.elasticsearch.index.Index
 
readIndexShardStatus(StreamInput) - Static method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
readInetSocketTransportAddress(StreamInput) - Static method in class org.elasticsearch.util.transport.InetSocketTransportAddress
 
readInt() - Method in class org.elasticsearch.util.io.stream.StreamInput
Reads four bytes and returns an int.
readInternalSearchResponse(StreamInput) - Static method in class org.elasticsearch.search.internal.InternalSearchResponse
 
readJvmInfo(StreamInput) - Static method in class org.elasticsearch.monitor.jvm.JvmInfo
 
readJvmStats(StreamInput) - Static method in class org.elasticsearch.monitor.jvm.JvmStats
 
readLong() - Method in class org.elasticsearch.util.io.stream.StreamInput
Reads eight bytes and returns a long.
readMap(XContentParser) - Static method in class org.elasticsearch.util.xcontent.support.XContentMapConverter
 
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
 
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
 
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
 
readNodeShutdownResponse(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.node.shutdown.NodesShutdownResponse.NodeShutdownResponse
 
readNodeStats(StreamInput) - Static method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
 
readOnly() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashSet
Atomically make the set immutable.
readOnlyRoutingNodes() - Method in class org.elasticsearch.cluster.ClusterState
Returns a built (on demand) routing nodes view of the routing table.
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
 
readQueryFetchSearchResult(StreamInput) - Static method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
 
readQuerySearchResult(StreamInput) - Static method in class org.elasticsearch.search.query.QuerySearchResult
 
readScroll(StreamInput) - Static method in class org.elasticsearch.search.Scroll
 
readSearchHit(StreamInput) - Static method in class org.elasticsearch.search.internal.InternalSearchHit
 
readSearchHit(StreamInput, TIntObjectHashMap<SearchShardTarget>) - Static method in class org.elasticsearch.search.internal.InternalSearchHit
 
readSearchHitField(StreamInput) - Static method in class org.elasticsearch.search.internal.InternalSearchHitField
 
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
 
readSettingsFromStream(StreamInput) - Static method in class org.elasticsearch.util.settings.ImmutableSettings
 
readSettingsFromStream(StreamInput, Settings) - Static method in class org.elasticsearch.util.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
 
readShort() - Method in class org.elasticsearch.util.io.stream.StreamInput
 
readSizeValue(StreamInput) - Static method in class org.elasticsearch.util.SizeValue
 
readStreamHeader() - Method in class org.elasticsearch.util.io.ThrowableObjectInputStream
 
readSwap(StreamInput) - Static method in class org.elasticsearch.monitor.os.OsInfo.Swap
 
readSwap(StreamInput) - Static method in class org.elasticsearch.monitor.os.OsStats.Swap
 
readTermFreq(StreamInput) - Static method in class org.elasticsearch.action.terms.TermFreq
 
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.util.TimeValue
 
readTopDocs(StreamInput) - Static method in class org.elasticsearch.util.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.util.io.stream.BytesStreamInput
 
readUTF() - Method in class org.elasticsearch.util.io.stream.HandlesStreamInput
 
readUTF() - Method in class org.elasticsearch.util.io.stream.StreamInput
Reads a string.
readVInt() - Method in class org.elasticsearch.util.io.stream.StreamInput
Reads an int stored in variable-length format.
readVLong() - Method in class org.elasticsearch.util.io.stream.StreamInput
Reads a long stored in variable-length format.
ready() - Method in class org.elasticsearch.util.io.FastCharArrayReader
Tells whether this stream is ready to be read.
ready() - Method in class org.elasticsearch.util.io.FastStringReader
Tells whether this stream is ready to be read.
ready() - Method in class org.elasticsearch.util.lucene.all.AllEntries
 
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
 
received(long) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
 
ReceiveTimeoutTransportException - Exception in org.elasticsearch.transport
 
ReceiveTimeoutTransportException(DiscoveryNode, String) - Constructor for exception org.elasticsearch.transport.ReceiveTimeoutTransportException
 
recover(Engine.RecoveryHandler) - Method in interface org.elasticsearch.index.engine.Engine
 
recover(Engine.RecoveryHandler) - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
recover() - Method in class org.elasticsearch.index.gateway.fs.FsIndexShardGateway
 
recover() - Method in interface org.elasticsearch.index.gateway.IndexShardGateway
Recovers the state of the shard from the gateway.
recover() - Method in class org.elasticsearch.index.gateway.IndexShardGatewayService
Recovers the state of the shard from the gateway.
recover() - 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
 
RecoverFilesRecoveryException - Exception in org.elasticsearch.index.shard.recovery
 
RecoverFilesRecoveryException(ShardId, int, SizeValue, Throwable) - Constructor for exception org.elasticsearch.index.shard.recovery.RecoverFilesRecoveryException
 
recovering() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
RecoveryAction - Class in org.elasticsearch.index.shard.recovery
 
RecoveryAction(ShardId, Settings, ThreadPool, TransportService, IndexShard, Store, RecoveryThrottler) - Constructor for class org.elasticsearch.index.shard.recovery.RecoveryAction
 
recoveryDone(ShardId, String) - Method in class org.elasticsearch.indices.recovery.throttler.RecoveryThrottler
 
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.index.shard.recovery
 
RecoveryFailedException(ShardId, DiscoveryNode, DiscoveryNode, Throwable) - Constructor for exception org.elasticsearch.index.shard.recovery.RecoveryFailedException
 
RecoveryThrottler - Class in org.elasticsearch.indices.recovery.throttler
 
RecoveryThrottler(Settings) - Constructor for class org.elasticsearch.indices.recovery.throttler.RecoveryThrottler
 
RecursiveAction - Class in org.elasticsearch.util.concurrent.jsr166y
A recursive resultless ForkJoinTask.
RecursiveAction() - Constructor for class org.elasticsearch.util.concurrent.jsr166y.RecursiveAction
 
recursiveBinding() - Method in class org.elasticsearch.util.inject.internal.Errors
 
recursiveImplementationType() - Method in class org.elasticsearch.util.inject.internal.Errors
 
recursiveProviderType() - Method in class org.elasticsearch.util.inject.internal.Errors
 
RecursiveTask<V> - Class in org.elasticsearch.util.concurrent.jsr166y
A recursive result-bearing ForkJoinTask.
RecursiveTask() - Constructor for class org.elasticsearch.util.concurrent.jsr166y.RecursiveTask
 
RED - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
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
 
reenableAutoCompaction(boolean) - Method in class org.elasticsearch.util.gnu.trove.THash
Re-enable auto-compaction after it was disabled via THash.tempDisableAutoCompaction().
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() - 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 - Static variable in class org.elasticsearch.action.TransportActions.Admin.Indices
 
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.node.NodeIndicesAdminClient
 
refresh(RefreshRequest, ActionListener<RefreshResponse>) - Method in class org.elasticsearch.client.node.NodeIndicesAdminClient
 
refresh(RefreshRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
refresh(RefreshRequest, ActionListener<RefreshResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
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
 
RefreshFailedEngineException - Exception in org.elasticsearch.index.engine
 
RefreshFailedEngineException(ShardId, Throwable) - Constructor for exception org.elasticsearch.index.engine.RefreshFailedEngineException
 
refreshInterval() - Method in class org.elasticsearch.index.engine.robin.RobinEngine
 
refreshInterval() - Method in interface org.elasticsearch.index.engine.ScheduledRefreshableEngine
 
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.
RefreshResponse - Class in org.elasticsearch.action.admin.indices.refresh
The response of a refresh action.
regexp() - Method in class org.elasticsearch.action.terms.TermsRequest
An optional regular expression to filter out terms (only the ones that match the regexp will return).
regexp(String) - Method in class org.elasticsearch.action.terms.TermsRequest
An optional regular expression to filter out terms (only the ones that match the regexp will return).
register() - Method in class org.elasticsearch.util.concurrent.jsr166y.Phaser
Adds a new unarrived party to this phaser.
register(MembersInjector<? super I>) - Method in interface org.elasticsearch.util.inject.spi.TypeEncounter
Registers a members injector for type I.
register(InjectionListener<? super I>) - Method in interface org.elasticsearch.util.inject.spi.TypeEncounter
Registers an injection listener for type I.
registerHandler(RestRequest.Method, String, HttpServerHandler) - Method in class org.elasticsearch.http.HttpServer
 
registerHandler(RestRequest.Method, String, RestHandler) - Method in class org.elasticsearch.rest.RestController
 
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
 
rehash() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
 
rehash() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
 
rehash() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
 
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TByteHashSet
Expands the set to accommodate new values.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Expands the set to accommodate new values.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatHashSet
Expands the set to accommodate new values.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.THash
Rehashes the set.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.THashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.THashSet
Expands the set to accommodate new values.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TIntHashSet
Expands the set to accommodate new values.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TLongHashSet
Expands the set to accommodate new values.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TShortHashSet
Expands the set to accommodate new values.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
rehashes the map to the new capacity.
rehash(int) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
rehashes the map to the new capacity.
reinitialize() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Resets the internal bookkeeping state of this task, allowing a subsequent fork.
rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.elasticsearch.util.concurrent.DynamicThreadPoolExecutor.ForceQueuePolicy
 
rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.elasticsearch.util.concurrent.DynamicThreadPoolExecutor.TimedBlockingPolicy
 
Releasable - Interface in org.elasticsearch.util.lease
 
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.translog.memory.MemorySnapshot
 
release() - Method in class org.elasticsearch.search.internal.SearchContext
 
release() - Method in interface org.elasticsearch.util.concurrent.resource.AcquirableResource
Releases the resource, will close it if there are no more acquirers and it is marked for close.
release() - Method in class org.elasticsearch.util.concurrent.resource.BlockingAcquirableResource
Releases the resource, will close it if there are no more acquirers.
release() - Method in class org.elasticsearch.util.concurrent.resource.NonBlockingAcquirableResource
 
release() - Method in interface org.elasticsearch.util.lease.Releasable
 
release() - Method in class org.elasticsearch.util.lucene.ReaderSearcherHolder
 
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
 
releaseShardFailures(Collection<ShardSearchFailure>) - Method in class org.elasticsearch.action.search.type.TransportSearchCache
 
relocate(String) - Method in class org.elasticsearch.cluster.routing.MutableShardRouting
 
relocated() - 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
 
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
 
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
 
remainingCapacity() - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
Always returns Integer.MAX_VALUE because a LinkedTransferQueue is not capacity constrained.
RemoteTransportException - Exception in org.elasticsearch.transport
 
RemoteTransportException(String, Throwable) - Constructor for exception org.elasticsearch.transport.RemoteTransportException
 
RemoteTransportException(String, TransportAddress, String, Throwable) - Constructor for exception org.elasticsearch.transport.RemoteTransportException
 
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
 
remove(TimeoutClusterStateListener) - Method in interface org.elasticsearch.cluster.ClusterService
 
remove(String) - Method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
remove(String) - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Builder
 
remove() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
 
remove(ClusterStateListener) - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
remove(TimeoutClusterStateListener) - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
remove() - Method in class org.elasticsearch.index.mapper.xcontent.ContentPath
 
remove(long) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
 
remove(Object, int) - Method in class org.elasticsearch.util.collect.ConcurrentHashMultiset
Removes a number of occurrences of the specified element from this multiset.
remove(Object) - Method in class org.elasticsearch.util.collect.ForwardingCollection
 
remove(Object, Object) - Method in class org.elasticsearch.util.collect.ForwardingConcurrentMap
 
remove() - Method in class org.elasticsearch.util.collect.ForwardingIterator
 
remove(int) - Method in class org.elasticsearch.util.collect.ForwardingList
 
remove(Object) - Method in class org.elasticsearch.util.collect.ForwardingMap
 
remove(Object, Object) - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
remove(Object, int) - Method in class org.elasticsearch.util.collect.ForwardingMultiset
 
remove() - Method in class org.elasticsearch.util.collect.ForwardingQueue
 
remove(Object) - Method in class org.elasticsearch.util.collect.ImmutableCollection
Guaranteed to throw an exception and leave the collection unmodified.
remove(int) - Method in class org.elasticsearch.util.collect.ImmutableList
Guaranteed to throw an exception and leave the list unmodified.
remove(Object) - Method in class org.elasticsearch.util.collect.ImmutableMap
Guaranteed to throw an exception and leave the map unmodified.
remove(Object, Object) - Method in class org.elasticsearch.util.collect.ImmutableMultimap
Guaranteed to throw an exception and leave the multimap unmodified.
remove(Object, int) - Method in class org.elasticsearch.util.collect.ImmutableMultiset
Guaranteed to throw an exception and leave the collection unmodified.
remove(Object, Object) - Method in class org.elasticsearch.util.collect.LinkedListMultimap
 
remove(Object, Object) - Method in interface org.elasticsearch.util.collect.Multimap
Removes a key-value pair from the multimap.
remove(Object, int) - Method in interface org.elasticsearch.util.collect.Multiset
Removes a number of occurrences of the specified element from this multiset.
remove(Object) - Method in interface org.elasticsearch.util.collect.Multiset
Removes a single occurrence of the specified element from this multiset, if present.
remove() - Method in interface org.elasticsearch.util.collect.PeekingIterator
remove() - Method in class org.elasticsearch.util.collect.UnmodifiableIterator
Guaranteed to throw an exception and leave the underlying data unmodified.
remove(long) - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
remove(Object) - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
remove(Object, Object) - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
remove(Object) - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Removes the key (and its corresponding value) from this map.
remove(Object, Object) - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
remove(long) - Method in interface org.elasticsearch.util.concurrent.ConcurrentMapLong
 
remove(Object) - Method in class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
remove(Object, Object) - Method in class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
remove(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Removes the key (and its corresponding value) from this map.
remove(Object, Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Atomically do a NonBlockingHashMap.remove(Object) if-and-only-if the key is mapped to a value which is equals to the given value.
remove() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong.IteratorLong
Remove last key returned by NonBlockingHashMapLong.IteratorLong.next() or NonBlockingHashMapLong.IteratorLong.nextLong().
remove(long) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Removes the key (and its corresponding value) from this map.
remove(long, Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Atomically do a NonBlockingHashMapLong.remove(long) if-and-only-if the key is mapped to a value which is equals to the given value.
remove(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Auto-boxing version of NonBlockingHashMapLong.remove(long).
remove(Object, Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Auto-boxing version of NonBlockingHashMapLong.remove(long,Object).
remove(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashSet
Remove o from the set.
remove(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Removes the key (and its corresponding value) from this map.
remove(Object, Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Atomically do a NonBlockingHashtable.remove(Object) if-and-only-if the key is mapped to a value which is equals to the given value.
remove(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Removes the key (and its corresponding value) from this map.
remove(Object, Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Atomically do a NonBlockingIdentityHashMap.remove(Object) if-and-only-if the key is mapped to a value which is equals to the given value.
remove(Object) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingSetInt
Remove o from the set.
remove(int) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingSetInt
Remove i from the set.
remove(Object) - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
Removes a single instance of the specified element from this queue, if it is present.
remove(Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Deletes a key/value pair from the map.
remove(Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Deletes a key/value pair from the map.
remove(Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteHashSetDecorator
Deletes a value from the set.
remove(Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Deletes a key/value pair from the map.
remove(Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Deletes a key/value pair from the map.
remove(Byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Deletes a key/value pair from the map.
remove(Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Deletes a key/value pair from the map.
remove(Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Deletes a key/value pair from the map.
remove(Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleHashSetDecorator
Deletes a value from the set.
remove(Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Deletes a key/value pair from the map.
remove(Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Deletes a key/value pair from the map.
remove(Double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Deletes a key/value pair from the map.
remove(Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Deletes a key/value pair from the map.
remove(Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Deletes a key/value pair from the map.
remove(Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatHashSetDecorator
Deletes a value from the set.
remove(Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Deletes a key/value pair from the map.
remove(Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Deletes a key/value pair from the map.
remove(Float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Deletes a key/value pair from the map.
remove(Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Deletes a key/value pair from the map.
remove(Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Deletes a key/value pair from the map.
remove(Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntHashSetDecorator
Deletes a value from the set.
remove(Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Deletes a key/value pair from the map.
remove(Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Deletes a key/value pair from the map.
remove(Integer) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Deletes a key/value pair from the map.
remove(Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Deletes a key/value pair from the map.
remove(Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Deletes a key/value pair from the map.
remove(Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongHashSetDecorator
Deletes a value from the set.
remove(Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Deletes a key/value pair from the map.
remove(Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Deletes a key/value pair from the map.
remove(Long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Deletes a key/value pair from the map.
remove(Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Deletes a key/value pair from the map.
remove(Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Deletes a key/value pair from the map.
remove(Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortHashSetDecorator
Deletes a value from the set.
remove(Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Deletes a key/value pair from the map.
remove(Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Deletes a key/value pair from the map.
remove(Short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Deletes a key/value pair from the map.
remove(int) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Removes the value at offset from the list.
remove(int, int) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Removes length values from the list, starting at offset
remove(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Deletes a key/value pair from the map.
remove(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Deletes a key/value pair from the map.
remove(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Deletes a key/value pair from the map.
remove(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteHashSet
Removes val from the set.
remove(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Deletes a key/value pair from the map.
remove(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Deletes a key/value pair from the map.
remove(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Deletes a key/value pair from the map.
remove(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Deletes a key/value pair from the map.
remove(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Removes the value at offset from the list.
remove(int, int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Removes length values from the list, starting at offset
remove(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Deletes a key/value pair from the map.
remove(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Deletes a key/value pair from the map.
remove(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Deletes a key/value pair from the map.
remove(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Removes val from the set.
remove(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Deletes a key/value pair from the map.
remove(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Deletes a key/value pair from the map.
remove(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Deletes a key/value pair from the map.
remove(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Deletes a key/value pair from the map.
remove(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Removes the value at offset from the list.
remove(int, int) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Removes length values from the list, starting at offset
remove(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Deletes a key/value pair from the map.
remove(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Deletes a key/value pair from the map.
remove(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Deletes a key/value pair from the map.
remove(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatHashSet
Removes val from the set.
remove(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Deletes a key/value pair from the map.
remove(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Deletes a key/value pair from the map.
remove(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Deletes a key/value pair from the map.
remove(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.THashMap
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.THashSet
Removes obj from the set.
remove(int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Removes the value at offset from the list.
remove(int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Removes length values from the list, starting at offset
remove(int) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Deletes a key/value pair from the map.
remove(int) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Deletes a key/value pair from the map.
remove(int) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Deletes a key/value pair from the map.
remove(int) - Method in class org.elasticsearch.util.gnu.trove.TIntHashSet
Removes val from the set.
remove(int) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Deletes a key/value pair from the map.
remove(int) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Deletes a key/value pair from the map.
remove(int) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Deletes a key/value pair from the map.
remove(int) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Deletes a key/value pair from the map.
remove() - Method in class org.elasticsearch.util.gnu.trove.TLinkedList.IteratorImpl
Removes the current element in the list and shrinks its size accordingly.
remove(Object) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Removes the specified element from the list.
remove(int) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Removes the value at offset from the list.
remove(int, int) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Removes length values from the list, starting at offset
remove(long) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Deletes a key/value pair from the map.
remove(long) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Deletes a key/value pair from the map.
remove(long) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Deletes a key/value pair from the map.
remove(long) - Method in class org.elasticsearch.util.gnu.trove.TLongHashSet
Removes val from the set.
remove(long) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Deletes a key/value pair from the map.
remove(long) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Deletes a key/value pair from the map.
remove(long) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Deletes a key/value pair from the map.
remove(long) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Deletes a key/value pair from the map.
remove(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Deletes a key/value pair from the map.
remove(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Deletes a key/value pair from the map.
remove(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Deletes a key/value pair from the map.
remove(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Deletes a key/value pair from the map.
remove(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Deletes a key/value pair from the map.
remove(K) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Deletes a key/value pair from the map.
remove(int) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Removes the value at offset from the list.
remove(int, int) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Removes length values from the list, starting at offset
remove(short) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Deletes a key/value pair from the map.
remove(short) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Deletes a key/value pair from the map.
remove(short) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Deletes a key/value pair from the map.
remove(short) - Method in class org.elasticsearch.util.gnu.trove.TShortHashSet
Removes val from the set.
remove(short) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Deletes a key/value pair from the map.
remove(short) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Deletes a key/value pair from the map.
remove(short) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Deletes a key/value pair from the map.
remove(short) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Deletes a key/value pair from the map.
remove(Object) - Method in class org.elasticsearch.util.IdentityHashSet
Removes the specified element from this set if it is present.
remove() - Method in class org.elasticsearch.util.inject.internal.UnmodifiableIterator
Guaranteed to throw an exception and leave the underlying data unmodified.
remove(Object) - Method in class org.elasticsearch.util.MapBackedSet
 
remove(K) - Method in class org.elasticsearch.util.MapBuilder
 
remove(String) - Method in class org.elasticsearch.util.settings.ImmutableSettings.Builder
Removes the provided setting.
removeAlias(String, String) - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
Adds an alias to the index.
removeAll(Collection<?>) - Method in class org.elasticsearch.util.collect.ForwardingCollection
 
removeAll(Object) - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
removeAll(Collection<?>) - Method in class org.elasticsearch.util.collect.ImmutableCollection
Guaranteed to throw an exception and leave the collection unmodified.
removeAll(Object) - Method in class org.elasticsearch.util.collect.ImmutableListMultimap
Guaranteed to throw an exception and leave the multimap unmodified.
removeAll(Object) - Method in class org.elasticsearch.util.collect.ImmutableMultimap
Guaranteed to throw an exception and leave the multimap unmodified.
removeAll(Object) - Method in class org.elasticsearch.util.collect.ImmutableSetMultimap
Guaranteed to throw an exception and leave the multimap unmodified.
removeAll(Iterable<?>, Collection<?>) - Static method in class org.elasticsearch.util.collect.Iterables
Removes, from an iterable, every element that belongs to the provided collection.
removeAll(Iterator<?>, Collection<?>) - Static method in class org.elasticsearch.util.collect.Iterators
Traverses an iterator and removes every element that belongs to the provided collection.
removeAll(Object) - Method in class org.elasticsearch.util.collect.LinkedListMultimap
Removes all values associated with a given key.
removeAll(Object) - Method in interface org.elasticsearch.util.collect.ListMultimap
Removes all values associated with a given key.
removeAll(Object) - Method in interface org.elasticsearch.util.collect.Multimap
Removes all values associated with a given key.
removeAll(Collection<?>) - Method in interface org.elasticsearch.util.collect.Multiset
removeAll(Object) - Method in interface org.elasticsearch.util.collect.SetMultimap
Removes all values associated with a given key.
removeAll(Object) - Method in interface org.elasticsearch.util.collect.SortedSetMultimap
Removes all values associated with a given key.
removeAll(byte[]) - Method in class org.elasticsearch.util.gnu.trove.TByteHashSet
Removes all of the elements in array from the set.
removeAll(double[]) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Removes all of the elements in array from the set.
removeAll(float[]) - Method in class org.elasticsearch.util.gnu.trove.TFloatHashSet
Removes all of the elements in array from the set.
removeAll(Collection<?>) - Method in class org.elasticsearch.util.gnu.trove.THashSet
Removes all of the elements in collection from the set.
removeAll(int[]) - Method in class org.elasticsearch.util.gnu.trove.TIntHashSet
Removes all of the elements in array from the set.
removeAll(long[]) - Method in class org.elasticsearch.util.gnu.trove.TLongHashSet
Removes all of the elements in array from the set.
removeAll(short[]) - Method in class org.elasticsearch.util.gnu.trove.TShortHashSet
Removes all of the elements in array from the set.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TByteHash
Releases the element currently stored at index.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHash
Releases the element currently stored at index.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatHash
Releases the element currently stored at index.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.THash
Delete the record at index.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.THashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TIntHash
Releases the element currently stored at index.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TLongHash
Releases the element currently stored at index.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectHash
 
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TPrimitiveHash
Delete the record at index.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TShortHash
Releases the element currently stored at index.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
removes the mapping at index from the map.
removeByShardId(int) - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
removeConnectionListener(TransportConnectionListener) - Method in class org.elasticsearch.transport.TransportService
 
removeCurrentReference() - Method in class org.elasticsearch.util.inject.internal.ConstructionContext
 
removed() - Method in class org.elasticsearch.cluster.node.DiscoveryNodes.Delta
 
REMOVED - Static variable in class org.elasticsearch.util.gnu.trove.TObjectHash
 
REMOVED - Static variable in class org.elasticsearch.util.gnu.trove.TPrimitiveHash
flag indicating that the value of a slot in the hashtable was deleted
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.util.Strings
Remove duplicate Strings from the given array.
removeElement(Map.Entry<K, V>) - Method in class org.elasticsearch.util.gnu.trove.THashMap.EntryView
 
removeElement(K) - Method in class org.elasticsearch.util.gnu.trove.THashMap.KeyView
 
removeElement(V) - Method in class org.elasticsearch.util.gnu.trove.THashMap.ValueView
 
removeExactly(Object, int) - Method in class org.elasticsearch.util.collect.ConcurrentHashMultiset
Removes exactly the specified number of occurrences of element, or makes no change if this is not possible.
removeFilter(SettingsFilter.Filter) - Method in class org.elasticsearch.util.settings.SettingsFilter
 
removeFirst() - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Remove and return the first element in the list.
removeHandler(String) - Method in class org.elasticsearch.transport.TransportService
 
removeLast() - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Remove and return the last element in the list.
removeLifecycleListener(LifecycleListener) - Method in class org.elasticsearch.util.component.AbstractLifecycleComponent
 
removeLifecycleListener(LifecycleListener) - Method in interface org.elasticsearch.util.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(IndicesLifecycle.Listener) - Method in interface org.elasticsearch.indices.IndicesLifecycle
Remove a listener.
removeListener(IndicesLifecycle.Listener) - Method in class org.elasticsearch.indices.InternalIndicesLifecycle
 
removeMapping(String) - Method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
removeNodeAttribute(String) - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
 
removeOperation() - Method in enum org.elasticsearch.action.ThreadingModel
 
removePlugin(String) - Method in class org.elasticsearch.plugins.PluginManager
 
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
 
render(String) - Method in class org.elasticsearch.util.jline.ANSI.Renderer
 
replace(K, V) - Method in class org.elasticsearch.util.collect.ForwardingConcurrentMap
 
replace(K, V, V) - Method in class org.elasticsearch.util.collect.ForwardingConcurrentMap
 
replace(Long, T, T) - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
replace(Long, T) - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
replace(K, V, V) - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
replace(K, V) - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
replace(K, V) - Method in class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
replace(K, V, V) - Method in class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
replace(TypeK, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Atomically do a put(key,val) if-and-only-if the key is mapped to some value already.
replace(TypeK, TypeV, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Atomically do a put(key,newValue) if-and-only-if the key is mapped a value which is equals to oldValue.
replace(long, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Atomically do a put(key,val) if-and-only-if the key is mapped to some value already.
replace(long, TypeV, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Atomically do a put(key,newValue) if-and-only-if the key is mapped a value which is equals to oldValue.
replace(Long, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Auto-boxing version of NonBlockingHashMapLong.replace(long, TypeV).
replace(Long, TypeV, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Auto-boxing version of NonBlockingHashMapLong.replace(long, TypeV).
replace(TypeK, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Atomically do a put(key,val) if-and-only-if the key is mapped to some value already.
replace(TypeK, TypeV, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Atomically do a put(key,newValue) if-and-only-if the key is mapped a value which is equals to oldValue.
replace(TypeK, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Atomically do a put(key,val) if-and-only-if the key is mapped to some value already.
replace(TypeK, TypeV, TypeV) - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Atomically do a put(key,newValue) if-and-only-if the key is mapped a value which is equals to oldValue.
replace(String, String, String) - Static method in class org.elasticsearch.util.Strings
Replace all occurences of a substring within a string with another string.
replaceDefaultDiscoModule(Class<? extends Module>) - Method in class org.elasticsearch.discovery.DiscoveryModule
 
replacePlaceholders(String, Properties) - Method in class org.elasticsearch.util.PropertyPlaceholder
Replaces all placeholders of format ${name} with the corresponding property from the supplied Properties.
replacePlaceholders(String, PropertyPlaceholder.PlaceholderResolver) - Method in class org.elasticsearch.util.PropertyPlaceholder
Replaces all placeholders of format ${name} with the value returned from the supplied PropertyPlaceholder.PlaceholderResolver.
replacePropertyPlaceholders() - Method in class org.elasticsearch.util.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:
replaceValues(K, Iterable<? extends V>) - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class org.elasticsearch.util.collect.ImmutableListMultimap
Guaranteed to throw an exception and leave the multimap unmodified.
replaceValues(K, Iterable<? extends V>) - Method in class org.elasticsearch.util.collect.ImmutableMultimap
Guaranteed to throw an exception and leave the multimap unmodified.
replaceValues(K, Iterable<? extends V>) - Method in class org.elasticsearch.util.collect.ImmutableSetMultimap
Guaranteed to throw an exception and leave the multimap unmodified.
replaceValues(K, Iterable<? extends V>) - Method in class org.elasticsearch.util.collect.LinkedHashMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in class org.elasticsearch.util.collect.LinkedListMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in interface org.elasticsearch.util.collect.ListMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in interface org.elasticsearch.util.collect.Multimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in interface org.elasticsearch.util.collect.SetMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in interface org.elasticsearch.util.collect.SortedSetMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
REPLICATION - Static variable in class org.elasticsearch.action.TransportActions.Admin.Cluster.Ping
 
ReplicationPingRequest - Class in org.elasticsearch.action.admin.cluster.ping.replication
 
ReplicationPingRequest(String...) - Constructor for class org.elasticsearch.action.admin.cluster.ping.replication.ReplicationPingRequest
 
ReplicationPingResponse - Class in org.elasticsearch.action.admin.cluster.ping.replication
 
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
 
reprobes() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Get and clear the current count of reprobes.
reprobes() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Get and clear the current count of reprobes.
reprobes() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Get and clear the current count of reprobes.
reprobes() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Get and clear the current count of reprobes.
request - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
request - Variable in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.ShardOperationRequest
 
request() - Method in class org.elasticsearch.action.support.single.TransportSingleOperationAction.ShardSingleOperationRequest
 
requestId() - Method in exception org.elasticsearch.transport.ResponseHandlerNotFoundTransportException
 
requestInjection(Object) - Method in class org.elasticsearch.util.inject.AbstractModule
 
requestInjection(TypeLiteral<T>, T) - Method in interface org.elasticsearch.util.inject.Binder
Upon successful creation, the Injector will inject instance fields and methods of the given object.
requestInjection(Object) - Method in interface org.elasticsearch.util.inject.Binder
Upon successful creation, the Injector will inject instance fields and methods of the given object.
requestInjection(Object) - Method in class org.elasticsearch.util.inject.PrivateModule
 
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.util.inject.AbstractModule
 
requestStaticInjection(Class<?>...) - Method in interface org.elasticsearch.util.inject.Binder
Upon successful creation, the Injector will inject static fields and methods in the given classes.
requestStaticInjection(Class<?>...) - Method in class org.elasticsearch.util.inject.PrivateModule
 
requireBinding(Key<?>) - Method in class org.elasticsearch.util.inject.AbstractModule
Adds a dependency from this module to key.
requireBinding(Class<?>) - Method in class org.elasticsearch.util.inject.AbstractModule
Adds a dependency from this module to type.
requireBinding(Key<?>) - Method in class org.elasticsearch.util.inject.PrivateModule
Instructs Guice to require a binding to the given key.
requireBinding(Class<?>) - Method in class org.elasticsearch.util.inject.PrivateModule
Instructs Guice to require a binding to the given type.
Required - Annotation Type in org.elasticsearch.util
The presence of this annotation on a method parameter indicates that null is an acceptable value for that parameter.
requiredAverageNumberOfShardsPerNode() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
requiresSnapshotScheduling() - Method in class org.elasticsearch.index.gateway.fs.FsIndexShardGateway
 
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.none.NoneIndexShardGateway
 
reroute(ClusterState) - Method in class org.elasticsearch.cluster.routing.strategy.DefaultShardsRoutingStrategy
 
reroute(ClusterState) - Method in interface org.elasticsearch.cluster.routing.strategy.ShardsRoutingStrategy
Reroutes the routing table based on the live nodes.
reset() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
 
reset() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
Resets the iterator.
reset() - Method in class org.elasticsearch.gateway.fs.FsGateway
 
reset() - Method in interface org.elasticsearch.gateway.Gateway
 
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.xcontent.ContentPath
 
reset(XContentParser, Document, String, byte[], DocumentMapper.ParseListener) - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
 
reset() - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.CachedNumericTokenStream
Reset the filter as well as the input TokenStream.
reset(XContentParser) - Method in class org.elasticsearch.index.query.xcontent.QueryParseContext
 
reset() - Method in class org.elasticsearch.transport.netty.ChannelBufferStreamInput
 
reset() - Method in class org.elasticsearch.util.concurrent.ThreadBarrier.BarrierTimer
resets (clears) this timer before next execution.
reset(Throwable) - Method in class org.elasticsearch.util.concurrent.ThreadBarrier
Resets the barrier to its initial state.
reset() - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Sets the size of the list to 0, but does not change its capacity.
reset() - Method in class org.elasticsearch.util.gnu.trove.TByteStack
Clears the stack without releasing its internal capacity allocation.
reset() - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Sets the size of the list to 0, but does not change its capacity.
reset() - Method in class org.elasticsearch.util.gnu.trove.TDoubleStack
Clears the stack without releasing its internal capacity allocation.
reset() - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Sets the size of the list to 0, but does not change its capacity.
reset() - Method in class org.elasticsearch.util.gnu.trove.TFloatStack
Clears the stack without releasing its internal capacity allocation.
reset() - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Sets the size of the list to 0, but does not change its capacity.
reset() - Method in class org.elasticsearch.util.gnu.trove.TIntStack
Clears the stack without releasing its internal capacity allocation.
reset() - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Sets the size of the list to 0, but does not change its capacity.
reset() - Method in class org.elasticsearch.util.gnu.trove.TLongStack
Clears the stack without releasing its internal capacity allocation.
reset() - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Sets the size of the list to 0, but does not change its capacity.
reset() - Method in class org.elasticsearch.util.gnu.trove.TShortStack
Clears the stack without releasing its internal capacity allocation.
reset() - Method in class org.elasticsearch.util.inject.internal.Stopwatch
Resets and returns elapsed time in milliseconds.
reset() - Method in class org.elasticsearch.util.io.FastByteArrayInputStream
Resets the buffer to the marked position.
reset() - Method in class org.elasticsearch.util.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.util.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.util.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.util.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.util.io.stream.BytesStreamInput
 
reset() - Method in class org.elasticsearch.util.io.stream.BytesStreamOutput
 
reset() - Method in class org.elasticsearch.util.io.stream.DataInputStreamInput
 
reset() - Method in class org.elasticsearch.util.io.stream.DataOutputStreamOutput
 
reset() - Method in class org.elasticsearch.util.io.stream.HandlesStreamInput
 
reset(StreamInput) - Method in class org.elasticsearch.util.io.stream.HandlesStreamInput
 
reset() - Method in class org.elasticsearch.util.io.stream.HandlesStreamOutput
 
reset() - Method in class org.elasticsearch.util.io.stream.InputStreamStreamInput
 
reset() - Method in class org.elasticsearch.util.io.stream.OutputStreamStreamOutput
 
reset() - Method in class org.elasticsearch.util.io.stream.StreamInput
Resets the stream.
reset() - Method in class org.elasticsearch.util.io.stream.StreamOutput
 
reset() - Method in class org.elasticsearch.util.lucene.all.AllEntries
 
reset() - Method in class org.elasticsearch.util.xcontent.builder.BinaryXContentBuilder
 
reset() - Method in class org.elasticsearch.util.xcontent.builder.TextXContentBuilder
 
reset() - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
resetAndLog(String) - Method in class org.elasticsearch.util.inject.internal.Stopwatch
Resets and logs elapsed time in milliseconds.
resetQuick() - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Sets the size of the list to 0, but does not change its capacity.
resetQuick() - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Sets the size of the list to 0, but does not change its capacity.
resetQuick() - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Sets the size of the list to 0, but does not change its capacity.
resetQuick() - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Sets the size of the list to 0, but does not change its capacity.
resetQuick() - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Sets the size of the list to 0, but does not change its capacity.
resetQuick() - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Sets the size of the list to 0, but does not change its capacity.
resident() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
resolve() - Method in interface org.elasticsearch.util.network.NetworkService.CustomNameResolver
 
resolveBindHostAddress(String) - Method in class org.elasticsearch.util.network.NetworkService
 
resolveBindHostAddress(String, String) - Method in class org.elasticsearch.util.network.NetworkService
 
resolveClass(ObjectStreamClass) - Method in class org.elasticsearch.util.io.ThrowableObjectInputStream
 
resolveConfig(String) - Method in class org.elasticsearch.env.Environment
 
resolveConfigAndLoadToString(String) - Method in class org.elasticsearch.env.Environment
 
resolveInetAddress(String, String, String) - Method in class org.elasticsearch.util.network.NetworkService
 
resolvePlaceholder(String) - Method in interface org.elasticsearch.util.PropertyPlaceholder.PlaceholderResolver
Resolves the supplied placeholder name into the replacement value.
resolvePublishHostAddress(String) - Method in class org.elasticsearch.util.network.NetworkService
 
resolvePublishHostAddress(String, String) - Method in class org.elasticsearch.util.network.NetworkService
 
resolveTypeVariable(Type, Class<?>, TypeVariable) - Static method in class org.elasticsearch.util.inject.internal.MoreTypes
 
resource() - Method in interface org.elasticsearch.util.concurrent.resource.AcquirableResource
 
resource() - Method in class org.elasticsearch.util.concurrent.resource.BlockingAcquirableResource
 
resource() - Method in class org.elasticsearch.util.concurrent.resource.NonBlockingAcquirableResource
 
ResourceDMBean - Class in org.elasticsearch.jmx
 
ResourceDMBean(Object, ESLogger) - Constructor for class org.elasticsearch.jmx.ResourceDMBean
 
RESPONSE_TYPE - Static variable in class org.elasticsearch.transport.Transport.Helper
 
ResponseHandlerFailureTransportException - Exception in org.elasticsearch.transport
 
ResponseHandlerFailureTransportException(String) - Constructor for exception org.elasticsearch.transport.ResponseHandlerFailureTransportException
 
ResponseHandlerFailureTransportException(String, Throwable) - Constructor for exception org.elasticsearch.transport.ResponseHandlerFailureTransportException
 
ResponseHandlerNotFoundTransportException - Exception in org.elasticsearch.transport
 
ResponseHandlerNotFoundTransportException(long) - Constructor for exception org.elasticsearch.transport.ResponseHandlerNotFoundTransportException
 
RestActionModule - Class in org.elasticsearch.rest.action
 
RestActionModule() - 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
 
RESTART - Static variable in class org.elasticsearch.action.TransportActions.Admin.Cluster.Node
 
restart(DiscoveryNode) - Method in class org.elasticsearch.discovery.zen.fd.MasterFaultDetection
 
RestBroadcastPingAction - Class in org.elasticsearch.rest.action.admin.cluster.ping.broadcast
 
RestBroadcastPingAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.ping.broadcast.RestBroadcastPingAction
 
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
 
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
 
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
 
restContentBuilder(RestRequest) - Static method in class org.elasticsearch.rest.action.support.RestXContentBuilder
 
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
 
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
 
RestHandler - Interface in org.elasticsearch.rest
 
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
 
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
 
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
 
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
 
restoreRecoveryState(IndexShardState) - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
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
 
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
 
RestReplicationPingAction - Class in org.elasticsearch.rest.action.admin.cluster.ping.replication
 
RestReplicationPingAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.ping.replication.RestReplicationPingAction
 
RestRequest - Interface in org.elasticsearch.rest
 
RestRequest.Method - Enum in org.elasticsearch.rest
 
RestResponse - Interface in org.elasticsearch.rest
 
RestResponse.Status - Enum 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
 
RestSinglePingAction - Class in org.elasticsearch.rest.action.admin.cluster.ping.single
 
RestSinglePingAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.admin.cluster.ping.single.RestSinglePingAction
 
RestTermsAction - Class in org.elasticsearch.rest.action.terms
 
RestTermsAction(Settings, Client, RestController) - Constructor for class org.elasticsearch.rest.action.terms.RestTermsAction
 
RestUtils - Class in org.elasticsearch.rest.support
 
RestUtils() - Constructor for class org.elasticsearch.rest.support.RestUtils
 
RestXContentBuilder - Class in org.elasticsearch.rest.action.support
 
RestXContentBuilder() - Constructor for class org.elasticsearch.rest.action.support.RestXContentBuilder
 
result - Variable in class org.elasticsearch.util.Unicode.UTF16Result
 
resumeEncoding() - Method in class org.elasticsearch.util.Base64.OutputStream
Resumes encoding of the stream.
retainAll(Collection<?>) - Method in class org.elasticsearch.util.collect.ForwardingCollection
 
retainAll(Collection<?>) - Method in class org.elasticsearch.util.collect.ImmutableCollection
Guaranteed to throw an exception and leave the collection unmodified.
retainAll(Iterable<?>, Collection<?>) - Static method in class org.elasticsearch.util.collect.Iterables
Removes, from an iterable, every element that does not belong to the provided collection.
retainAll(Iterator<?>, Collection<?>) - Static method in class org.elasticsearch.util.collect.Iterators
Traverses an iterator and removes every element that does not belong to the provided collection.
retainAll(Collection<?>) - Method in interface org.elasticsearch.util.collect.Multiset
retainAll(byte[]) - Method in class org.elasticsearch.util.gnu.trove.TByteHashSet
Removes any values in the set which are not contained in array.
retainAll(double[]) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Removes any values in the set which are not contained in array.
retainAll(float[]) - Method in class org.elasticsearch.util.gnu.trove.TFloatHashSet
Removes any values in the set which are not contained in array.
retainAll(Collection<?>) - Method in class org.elasticsearch.util.gnu.trove.THashSet
Removes any values in the set which are not contained in collection.
retainAll(int[]) - Method in class org.elasticsearch.util.gnu.trove.TIntHashSet
Removes any values in the set which are not contained in array.
retainAll(long[]) - Method in class org.elasticsearch.util.gnu.trove.TLongHashSet
Removes any values in the set which are not contained in array.
retainAll(short[]) - Method in class org.elasticsearch.util.gnu.trove.TShortHashSet
Removes any values in the set which are not contained in array.
retainEntries(TByteByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TByteDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TByteFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TByteIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TByteLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TByteObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TByteShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TDoubleByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TDoubleDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TDoubleFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TDoubleIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TDoubleLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TDoubleObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TDoubleShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TFloatByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TFloatDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TFloatFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TFloatIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TFloatLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TFloatObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TFloatShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TObjectObjectProcedure<K, V>) - Method in class org.elasticsearch.util.gnu.trove.THashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TIntByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TIntDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TIntFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TIntIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TIntLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TIntObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TIntShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TLongByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TLongDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TLongFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TLongIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TLongLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TLongObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TLongShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TObjectByteProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TObjectDoubleProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TObjectFloatProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TObjectIntProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TObjectLongProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TObjectShortProcedure<K>) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TShortByteProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TShortDoubleProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TShortFloatProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TShortIntProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TShortLongProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TShortObjectProcedure<V>) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Retains only those entries in the map for which the procedure returns a true value.
retainEntries(TShortShortProcedure) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Retains only those entries in the map for which the procedure returns a true value.
retransSegs() - Method in class org.elasticsearch.monitor.network.NetworkStats.Tcp
 
retrieve(String) - Method in class org.elasticsearch.util.path.PathTrie
 
retrieve(String, Map<String, String>) - Method in class org.elasticsearch.util.path.PathTrie
 
retrieve(String[], int, Map<String, String>) - Method in class org.elasticsearch.util.path.PathTrie.TrieNode
 
returns(Matcher<? super Class<?>>) - Static method in class org.elasticsearch.util.inject.matcher.Matchers
Returns a matcher which matches methods with matching return types.
ReusableIterator<E> - Interface in org.elasticsearch.util
 
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
 
reusableTokenStream(String, Reader) - Method in class org.elasticsearch.util.lucene.all.AllAnalyzer
 
reverse(List<T>) - Static method in class org.elasticsearch.util.collect.Iterables
Adapts a list to an iterable with reversed iteration order.
reverse() - Method in class org.elasticsearch.util.collect.Ordering
Returns the reverse of this ordering; the Ordering equivalent to Collections.reverseOrder(Comparator).
reverse() - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Reverse the order of the elements in the list.
reverse(int, int) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Reverse the order of the elements in the range of the list.
reverse() - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Reverse the order of the elements in the list.
reverse(int, int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Reverse the order of the elements in the range of the list.
reverse() - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Reverse the order of the elements in the list.
reverse(int, int) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Reverse the order of the elements in the range of the list.
reverse() - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Reverse the order of the elements in the list.
reverse(int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Reverse the order of the elements in the range of the list.
reverse() - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Reverse the order of the elements in the list.
reverse(int, int) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Reverse the order of the elements in the range of the list.
reverse() - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Reverse the order of the elements in the list.
reverse(int, int) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Reverse the order of the elements in the range of the list.
REVERSE - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
reverseOrder() - Static method in class org.elasticsearch.util.collect.ImmutableSortedMap
Returns a builder that creates immutable sorted maps whose keys are ordered by the reverse of their natural ordering.
reverseOrder() - Static method in class org.elasticsearch.util.collect.ImmutableSortedSet
Returns a builder that creates immutable sorted sets whose elements are ordered by the reverse of their natural ordering.
rewind() - Method in interface org.elasticsearch.util.ReusableIterator
 
rewrite(Query) - Method in class org.elasticsearch.search.dfs.CachedDfSource
 
rewrite(Query) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
rewrite(IndexReader) - Method in class org.elasticsearch.util.lucene.search.CustomBoostFactorQuery
 
rewrite(IndexReader) - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
rightValue() - Method in interface org.elasticsearch.util.collect.MapDifference.ValueDifference
Returns the value from the right map (possibly null).
RobinEngine - Class in org.elasticsearch.index.engine.robin
 
RobinEngine(ShardId, Settings, Store, SnapshotDeletionPolicy, Translog, MergePolicyProvider, MergeSchedulerProvider, AnalysisService, SimilarityService) - 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
 
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
 
rootNode() - Method in class org.elasticsearch.index.mapper.xcontent.XContentTypeParser.ParserContext
 
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
 
RoutingNode - Class in org.elasticsearch.cluster.routing
 
RoutingNode(String) - Constructor for class org.elasticsearch.cluster.routing.RoutingNode
 
RoutingNode(String, List<MutableShardRouting>) - Constructor for class org.elasticsearch.cluster.routing.RoutingNode
 
routingNodes() - Method in class org.elasticsearch.cluster.ClusterState
 
RoutingNodes - Class in org.elasticsearch.cluster.routing
 
RoutingNodes(MetaData, RoutingTable) - Constructor for class org.elasticsearch.cluster.routing.RoutingNodes
 
routingNodes(MetaData) - Method in class org.elasticsearch.cluster.routing.RoutingTable
 
RoutingService - Class in org.elasticsearch.cluster.routing
 
RoutingService(Settings, ThreadPool, ClusterService, ShardsRoutingStrategy) - 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() - 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.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 org.elasticsearch.threadpool.support.AbstractThreadPool.FutureRunnable
 
run() - Method in class org.elasticsearch.util.base.internal.Finalizer
Loops continuously, pulling references off the queue and cleaning them up.
run() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinWorkerThread
This method is required to be public, but should never be called explicitly.
run() - Method in class org.elasticsearch.util.concurrent.ThreadBarrier.BarrierTimer
 
run() - Method in class org.elasticsearch.util.ThreadRenamingRunnable
 
run(Timeout) - Method in interface org.elasticsearch.util.timer.TimerTask
Executed after the delay specified with Timer.newTimeout(TimerTask, long, java.util.concurrent.TimeUnit).
RussianAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
RussianAnalyzerProvider(Index, Settings, 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

SafeArray<T> - Interface in org.elasticsearch.util
An array that is safe in terms of size.
SafeArray.Procedure<T> - Interface in org.elasticsearch.util
 
safeClose(IndexReader) - Static method in class org.elasticsearch.util.lucene.Lucene
Closes the index reader, returning false if it failed to close.
safeClose(IndexWriter) - Static method in class org.elasticsearch.util.lucene.Lucene
Closes the index writer, returning false if it failed to close.
sameTranslogNewOperations() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.Snapshot
Indicates that the same translog exists, but new operations have been appended to it.
ScalingThreadPool - Class in org.elasticsearch.threadpool.scaling
 
ScalingThreadPool() - Constructor for class org.elasticsearch.threadpool.scaling.ScalingThreadPool
 
ScalingThreadPool(Settings) - Constructor for class org.elasticsearch.threadpool.scaling.ScalingThreadPool
 
ScalingThreadPoolExecutor - Class in org.elasticsearch.util.concurrent
 
ScalingThreadPoolExecutor(int, int, TimeValue, ThreadFactory, ScheduledExecutorService, TimeValue) - Constructor for class org.elasticsearch.util.concurrent.ScalingThreadPoolExecutor
 
ScalingThreadPoolManagement - Class in org.elasticsearch.threadpool.scaling
 
ScalingThreadPoolManagement(ThreadPool) - Constructor for class org.elasticsearch.threadpool.scaling.ScalingThreadPoolManagement
 
ScalingThreadPoolModule - Class in org.elasticsearch.threadpool.scaling
 
ScalingThreadPoolModule() - Constructor for class org.elasticsearch.threadpool.scaling.ScalingThreadPoolModule
 
schedule(Runnable, long, TimeUnit) - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
schedule(Callable<V>, long, TimeUnit) - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
schedule(Runnable, TimeValue) - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
schedule(Runnable, long, TimeUnit) - Method in interface org.elasticsearch.threadpool.ThreadPool
Creates and executes a one-shot action that becomes enabled after the given delay.
schedule(Callable<V>, long, TimeUnit) - Method in interface org.elasticsearch.threadpool.ThreadPool
Creates and executes a ScheduledFuture that becomes enabled after the given delay.
schedule(Runnable, TimeValue) - Method in interface org.elasticsearch.threadpool.ThreadPool
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface org.elasticsearch.threadpool.ThreadPool
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period; that is executions will commence after initialDelay then initialDelay+period, then initialDelay + 2 * period, and so on.
scheduledExecutorService - Variable in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
ScheduledRefreshableEngine - Interface in org.elasticsearch.index.engine
 
schedulerActiveCount() - Method in class org.elasticsearch.threadpool.ThreadPoolStats
The approximate number of threads that are actively executing scheduled tasks.
schedulerPoolSize() - Method in class org.elasticsearch.threadpool.ThreadPoolStats
The size of the scheduler thread pool.
schedulerThreads() - Method in class org.elasticsearch.threadpool.ThreadPoolInfo
The size of scheduler threads.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
scheduleWithFixedDelay(Runnable, TimeValue) - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface org.elasticsearch.threadpool.ThreadPool
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given delay between the termination of one execution and the commencement of the next.
scheduleWithFixedDelay(Runnable, TimeValue) - Method in interface org.elasticsearch.threadpool.ThreadPool
 
Scope - Interface in org.elasticsearch.util.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.util.inject.Scope
Scopes a provider.
SCOPE_ALREADY_SET - Static variable in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
ScopeAnnotation - Annotation Type in org.elasticsearch.util.inject
Annotates annotations which are used for scoping.
scopeAnnotationOnAbstractType(Class<? extends Annotation>, Class<?>, Object) - Method in class org.elasticsearch.util.inject.internal.Errors
 
ScopeBinding - Class in org.elasticsearch.util.inject.spi
Registration of a scope annotation with the scope that implements it.
ScopedBindingBuilder - Interface in org.elasticsearch.util.inject.binder
See the EDSL examples at Binder.
scopeNotFound(Class<? extends Annotation>) - Method in class org.elasticsearch.util.inject.internal.Errors
 
Scopes - Class in org.elasticsearch.util.inject
Built-in scope implementations.
Scoping - Class in org.elasticsearch.util.inject.internal
References a scope, either directly (as a scope instance), or indirectly (as a scope annotation).
score() - Method in class org.elasticsearch.util.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
ScoreDocQueue - Class in org.elasticsearch.search.controller
Same as lucene HitQueue.
ScoreDocQueue(int) - Constructor for class org.elasticsearch.search.controller.ScoreDocQueue
 
scoreOrdered() - Method in class org.elasticsearch.search.highlight.SearchContextHighlight
 
scorer(IndexReader, boolean, boolean) - Method in class org.elasticsearch.util.lucene.all.AllTermQuery.AllTermWeight
 
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() - 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() - 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.
SEARCH - Static variable in class org.elasticsearch.action.TransportActions
 
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.node.NodeClient
 
search(SearchRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.node.NodeClient
 
search(SearchRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
search(SearchRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
search(SearchRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
search(SearchRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
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, Collector) - Method in class org.elasticsearch.search.internal.ContextIndexSearcher
 
SEARCH_SCROLL - Static variable in class org.elasticsearch.action.TransportActions
 
searchAnalyzer() - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
A smart analyzer used for searching that takes into account specific analyzers configured per FieldMapper.
searchAnalyzer() - Method in interface org.elasticsearch.index.mapper.DocumentMapper
The default search analyzer to be used.
searchAnalyzer() - Method in interface org.elasticsearch.index.mapper.FieldMapper
The analyzer that will be used to search the field.
searchAnalyzer() - Method in class org.elasticsearch.index.mapper.MapperService
 
searchAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper.Builder
 
searchAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper.Builder
 
searchAnalyzer() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
searchAnalyzer - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
searchAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
searchAnalyzer(NamedAnalyzer) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.OpenBuilder
 
searchAnalyzer - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
searchAnalyzer() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
searchCache - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction
 
SearchContext - Class in org.elasticsearch.search.internal
 
SearchContext(long, SearchShardTarget, TimeValue, String[], Engine.Searcher, IndexService) - 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.facets
 
SearchContextFacets(SearchContextFacets.QueryExecutionType, List<SearchContextFacets.QueryFacet>) - Constructor for class org.elasticsearch.search.facets.SearchContextFacets
 
SearchContextFacets.Facet - Class in org.elasticsearch.search.facets
 
SearchContextFacets.Facet() - Constructor for class org.elasticsearch.search.facets.SearchContextFacets.Facet
 
SearchContextFacets.QueryExecutionType - Enum in org.elasticsearch.search.facets
 
SearchContextFacets.QueryFacet - Class in org.elasticsearch.search.facets
 
SearchContextFacets.QueryFacet(String, Query) - Constructor for class org.elasticsearch.search.facets.SearchContextFacets.QueryFacet
 
SearchContextHighlight - Class in org.elasticsearch.search.highlight
 
SearchContextHighlight(List<SearchContextHighlight.ParsedHighlightField>, String[], String[], boolean, boolean) - Constructor for class org.elasticsearch.search.highlight.SearchContextHighlight
 
SearchContextHighlight.ParsedHighlightField - Class in org.elasticsearch.search.highlight
 
SearchContextHighlight.ParsedHighlightField(String, int, int) - Constructor for class org.elasticsearch.search.highlight.SearchContextHighlight.ParsedHighlightField
 
SearchContextMissingException - Exception in org.elasticsearch.search
 
SearchContextMissingException(long) - Constructor for exception org.elasticsearch.search.SearchContextMissingException
 
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.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
 
searcher() - Method in class org.elasticsearch.util.lucene.ReaderSearcherHolder
 
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
 
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.
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() - 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.
SearchRequest - Class in org.elasticsearch.action.search
A request to execute search against one or more indices (or all).
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.
SearchResponse - Class in org.elasticsearch.action.search
A response of a search request.
SearchResponse(InternalSearchResponse, String, int, int, ShardSearchFailure[]) - Constructor for class org.elasticsearch.action.search.SearchResponse
 
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.node.NodeClient
 
searchScroll(SearchScrollRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.node.NodeClient
 
searchScroll(SearchScrollRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
searchScroll(SearchScrollRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
searchScroll(SearchScrollRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
searchScroll(SearchScrollRequest, ActionListener<SearchResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
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.
searchService - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction
 
SearchService - Class in org.elasticsearch.search
 
SearchService(Settings, ClusterService, IndicesService, TimerService, 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) - Method in interface org.elasticsearch.index.routing.OperationRouting
 
searchShards(ClusterState, String) - Method in class org.elasticsearch.index.routing.plain.PlainOperationRouting
 
searchShards(ClusterState, String[], String) - Method in interface org.elasticsearch.indices.IndicesService
Gets all the "searchable" shards on all the given indices.
searchShards(ClusterState, String[], String) - Method in class org.elasticsearch.indices.InternalIndicesService
 
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.xcontent.QueryParseContext
 
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() - 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.
SearchSourceBuilder.Order - Enum in org.elasticsearch.search.builder
 
SearchSourceBuilderException - Exception in org.elasticsearch.search.builder
 
SearchSourceBuilderException(String) - Constructor for exception org.elasticsearch.search.builder.SearchSourceBuilderException
 
SearchSourceBuilderException(String, Throwable) - Constructor for exception org.elasticsearch.search.builder.SearchSourceBuilderException
 
SearchSourceFacetsBuilder - Class in org.elasticsearch.search.builder
A search source facets builder.
SearchSourceFacetsBuilder() - Constructor for class org.elasticsearch.search.builder.SearchSourceFacetsBuilder
 
SearchSourceHighlightBuilder - Class in org.elasticsearch.search.builder
A builder for search highlighting.
SearchSourceHighlightBuilder() - Constructor for class org.elasticsearch.search.builder.SearchSourceHighlightBuilder
 
searchSourceLength() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
 
searchSourceOffset() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
 
searchSourceUnsafe() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
 
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.
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.util.lucene.store.SwitchDirectory
Return the secondary directory
seconds() - Method in class org.elasticsearch.util.TimeValue
 
secondsFrac() - Method in class org.elasticsearch.util.TimeValue
 
seek(long) - Method in class org.elasticsearch.index.store.memory.ByteBufferIndexInput
 
seek(long) - Method in class org.elasticsearch.index.store.memory.ByteBufferIndexOutput
 
seek(long) - Method in class org.elasticsearch.index.store.memory.HeapIndexInput
 
seek(long) - Method in class org.elasticsearch.index.store.memory.HeapIndexOutput
 
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
 
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, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.local.LocalTransport
 
sendRequest(DiscoveryNode, long, String, Streamable, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.netty.NettyTransport
 
sendRequest(DiscoveryNode, long, String, Streamable, TransportResponseHandler<T>) - Method in interface org.elasticsearch.transport.Transport
 
sendRequest(DiscoveryNode, String, Streamable, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
 
sendRequest(DiscoveryNode, String, Streamable, TimeValue, 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(Throwable) - Method in class org.elasticsearch.transport.local.LocalTransportChannel
 
sendResponse(Streamable) - 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(Throwable) - Method in interface org.elasticsearch.transport.TransportChannel
 
sent(long) - Method in interface org.elasticsearch.transport.TransportServiceAdapter
 
serializableCopy(Member) - Static method in class org.elasticsearch.util.inject.internal.MoreTypes
Returns a type that's functionally equal but not necessarily equal according to Object.equals.
Serializers - Class in org.elasticsearch.util.io
 
SerialMergeSchedulerProvider - Class in org.elasticsearch.index.merge.scheduler
 
SerialMergeSchedulerProvider(ShardId, Settings) - Constructor for class org.elasticsearch.index.merge.scheduler.SerialMergeSchedulerProvider
 
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(int, E) - Method in class org.elasticsearch.util.collect.ForwardingList
 
set(E) - Method in class org.elasticsearch.util.collect.ForwardingListIterator
 
set(int, E) - Method in class org.elasticsearch.util.collect.ImmutableList
Guaranteed to throw an exception and leave the list unmodified.
set(V) - Method in class org.elasticsearch.util.concurrent.AbstractFuture
Subclasses should invoke this method to set the result of the computation to value.
set(long) - Method in class org.elasticsearch.util.concurrent.highscalelib.ConcurrentAutoTable
Atomically set the sum of the striped counters to specified value.
set(int, byte) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Sets the value at the specified offset.
set(int, byte[]) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Replace the values in the list starting at offset with the contents of the values array.
set(int, byte[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Replace the values in the list starting at offset with length values from the values array, starting at valOffset.
set(int, double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Sets the value at the specified offset.
set(int, double[]) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Replace the values in the list starting at offset with the contents of the values array.
set(int, double[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Replace the values in the list starting at offset with length values from the values array, starting at valOffset.
set(int, float) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Sets the value at the specified offset.
set(int, float[]) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Replace the values in the list starting at offset with the contents of the values array.
set(int, float[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Replace the values in the list starting at offset with length values from the values array, starting at valOffset.
set(int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Sets the value at the specified offset.
set(int, int[]) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Replace the values in the list starting at offset with the contents of the values array.
set(int, int[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Replace the values in the list starting at offset with length values from the values array, starting at valOffset.
set(T) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList.IteratorImpl
Replaces the current element in the list with linkable
set(int, long) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Sets the value at the specified offset.
set(int, long[]) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Replace the values in the list starting at offset with the contents of the values array.
set(int, long[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Replace the values in the list starting at offset with length values from the values array, starting at valOffset.
set(int, short) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Sets the value at the specified offset.
set(int, short[]) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Replace the values in the list starting at offset with the contents of the values array.
set(int, short[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Replace the values in the list starting at offset with length values from the values array, starting at valOffset.
set(boolean) - Method in class org.elasticsearch.util.io.BooleanStreamable
 
set(long) - Method in class org.elasticsearch.util.io.stream.LongStreamable
 
set(String) - Method in class org.elasticsearch.util.io.stream.StringStreamable
 
set(T) - Method in class org.elasticsearch.util.ThreadLocals.CleanableValue
 
setAnalyzer(Analyzer) - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
setAsyncMode(boolean) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Establishes local first-in-first-out scheduling mode for forked tasks that are never joined.
setAttribute(Attribute) - Method in class org.elasticsearch.jmx.ResourceDMBean
 
setAttributes(AttributeList) - Method in class org.elasticsearch.jmx.ResourceDMBean
 
setAutoCompactionFactor(float) - Method in class org.elasticsearch.util.gnu.trove.THash
The auto-compaction factor controls whether and when a table performs a THash.compact() automatically after a certain number of remove operations.
setBinding(BindingImpl<T>) - Method in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
setBoostTerms(boolean) - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
setBoostTermsFactor(float) - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
setCount(E, int) - Method in class org.elasticsearch.util.collect.ConcurrentHashMultiset
Adds or removes occurrences of element such that the ConcurrentHashMultiset.count(java.lang.Object) of the element becomes count.
setCount(E, int, int) - Method in class org.elasticsearch.util.collect.ConcurrentHashMultiset
Sets the number of occurrences of element to newCount, but only if the count is currently oldCount.
setCount(E, int) - Method in class org.elasticsearch.util.collect.ForwardingMultiset
 
setCount(E, int, int) - Method in class org.elasticsearch.util.collect.ForwardingMultiset
 
setCount(E, int) - Method in class org.elasticsearch.util.collect.ImmutableMultiset.Builder
Adds or removes the necessary occurrences of an element such that the element attains the desired count.
setCount(E, int) - Method in class org.elasticsearch.util.collect.ImmutableMultiset
Guaranteed to throw an exception and leave the collection unmodified.
setCount(E, int, int) - Method in class org.elasticsearch.util.collect.ImmutableMultiset
Guaranteed to throw an exception and leave the collection unmodified.
setCount(E, int) - Method in interface org.elasticsearch.util.collect.Multiset
Adds or removes the necessary occurrences of an element such that the element attains the desired count.
setCount(E, int, int) - Method in interface org.elasticsearch.util.collect.Multiset
Conditionally sets the count of an element to a new value, as described in Multiset.setCount(Object, int), provided that the element has the expected current count.
setCurrentReference(T) - Method in class org.elasticsearch.util.inject.internal.ConstructionContext
 
setDefaultFactory(ESLoggerFactory) - Static method in class org.elasticsearch.util.logging.ESLoggerFactory
Changes the default factory.
setDependency(Dependency) - Method in class org.elasticsearch.util.inject.internal.InternalContext
 
setDoubleValue(double) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.CachedNumericTokenStream
 
setEnabled(boolean) - Static method in class org.elasticsearch.util.jline.ANSI
 
setError(byte) - Static method in class org.elasticsearch.transport.Transport.Helper
 
setException(Throwable) - Method in class org.elasticsearch.util.concurrent.AbstractFuture
Subclasses should invoke this method to set the result of the computation to an error, throwable.
setFloatValue(float) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.CachedNumericTokenStream
 
setFollow(boolean) - Method in class org.elasticsearch.util.logging.log4j.ConsoleAppender
Sets whether the appender honors reassignments of System.out or System.err made after configuration.
setFreqCurrentDoc() - Method in class org.elasticsearch.util.lucene.all.AllTermQuery.AllTermWeight.AllTermSpanScorer
 
setIntValue(int) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.CachedNumericTokenStream
 
setLength(int) - Method in class org.elasticsearch.util.Unicode.UTF16Result
 
setLikeText(String) - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
setLongValue(long) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.CachedNumericTokenStream
 
setMaintainsParallelism(boolean) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Sets whether this pool dynamically maintains its target parallelism level.
setMaxDocFreq(int) - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
setMaximumPoolSize(int) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Sets the maximum number of threads allowed to exist in the pool.
setMaxMergeDocs(int) - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy.MergePolicyParams
 
setMaxQueryTerms(int) - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
setMaxSmallSegments(int) - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy.MergePolicyParams
 
setMaxSmallSegments(int) - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy
 
setMaxWordLen(int) - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
setMergeFactor(int) - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy.MergePolicyParams
 
setMergeFactor(int) - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy
 
setMergePolicyParams(BalancedSegmentMergePolicy.MergePolicyParams) - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy
 
setMinDocFreq(int) - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
setMinTermFrequency(int) - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
setMinWordLen(int) - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
setMoreLikeFields(String[]) - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
SetMultimap<K,V> - Interface in org.elasticsearch.util.collect
A Multimap that cannot hold duplicate key-value pairs.
setNext(TLinkable) - Method in interface org.elasticsearch.util.gnu.trove.TLinkable
Sets the linked list node after this one.
setNext(TLinkable) - Method in class org.elasticsearch.util.gnu.trove.TLinkableAdapter
Sets the linked list node after this one.
setNext(LZFChunk) - Method in class org.elasticsearch.util.io.compression.lzf.LZFChunk
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.util.lucene.docidset.DocIdSetCollector
 
setNextReader(IndexReader, int) - Method in class org.elasticsearch.util.lucene.Lucene.CountCollector
 
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
 
setNumLargeSegments(int) - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy.MergePolicyParams
 
setNumLargeSegments(int) - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy
 
setOf(Type) - Static method in class org.elasticsearch.util.inject.util.Types
Returns a type modelling a Set whose elements are of type elementType.
setParallelism(int) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Sets the target parallelism level of this pool.
setPartialExpunge(boolean) - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy.MergePolicyParams
 
setPartialExpunge(boolean) - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy
 
setPercentTermsToMatch(float) - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
setPositionIncrementGap(int) - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
 
setPositionIncrementGap(int) - Method in interface org.elasticsearch.index.analysis.PositionIncrementGapAnalyzer
 
setPrevious(TLinkable) - Method in interface org.elasticsearch.util.gnu.trove.TLinkable
Sets the linked list node before this one.
setPrevious(TLinkable) - Method in class org.elasticsearch.util.gnu.trove.TLinkableAdapter
Sets the linked list node before this one.
setProxyDelegates(T) - Method in class org.elasticsearch.util.inject.internal.ConstructionContext
 
setQuick(int, byte) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Sets the value at the specified offset without doing any bounds checking.
setQuick(int, double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Sets the value at the specified offset without doing any bounds checking.
setQuick(int, float) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Sets the value at the specified offset without doing any bounds checking.
setQuick(int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Sets the value at the specified offset without doing any bounds checking.
setQuick(int, long) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Sets the value at the specified offset without doing any bounds checking.
setQuick(int, short) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Sets the value at the specified offset without doing any bounds checking.
setRawResult(V) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Forces the given value to be returned as a result.
setRawResult(Void) - Method in class org.elasticsearch.util.concurrent.jsr166y.RecursiveAction
Requires null completion value.
setRawResult(V) - Method in class org.elasticsearch.util.concurrent.jsr166y.RecursiveTask
 
setRequest(byte) - Static method in class org.elasticsearch.transport.Transport.Helper
 
setResponse(byte) - Static method in class org.elasticsearch.transport.Transport.Helper
 
Sets - Class in org.elasticsearch.util.collect
Static utility methods pertaining to Set instances.
Sets.SetView<E> - Class in org.elasticsearch.util.collect
An unmodifiable view of a set which may be backed by other sets; this view will change as the backing sets do.
setScorer(Scorer) - Method in class org.elasticsearch.util.lucene.docidset.DocIdSetCollector
 
setScorer(Scorer) - Method in class org.elasticsearch.util.lucene.Lucene.CountCollector
 
setSeed(long) - Method in class org.elasticsearch.util.concurrent.jsr166y.ThreadLocalRandom
Throws UnsupportedOperationException.
setSimilarity(Similarity) - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
setStopWords(Set<?>) - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
setTarget(String) - Method in class org.elasticsearch.util.logging.log4j.ConsoleAppender
Sets the value of the Target option.
setThreadNameDeterminer(ThreadNameDeterminer) - Static method in class org.elasticsearch.util.ThreadRenamingRunnable
Sets the ThreadNameDeterminer which overrides the proposed new thread name.
setThreadPoolExecutor(ThreadPoolExecutor) - Method in class org.elasticsearch.util.concurrent.DynamicThreadPoolExecutor.DynamicQueue
Sets the executor this queue belongs to.
setTieBreaker(float) - Method in class org.elasticsearch.index.query.support.MultiFieldMapperQueryParser
 
SETTING - Static variable in class org.elasticsearch.cluster.ClusterName
 
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
 
settings() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
The settings of the node.
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(Map) - Method in class org.elasticsearch.action.admin.indices.create.CreateIndexRequest
The settings to crete the index with (either json/yaml/properties format)
settings() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
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() - 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() - Method in class org.elasticsearch.transport.netty.NettyTransport
 
settings - Variable in class org.elasticsearch.util.component.AbstractComponent
 
Settings - Interface in org.elasticsearch.util.settings
Immutable settings allowing to control the configuration.
Settings.Builder - Interface in org.elasticsearch.util.settings
A settings builder interface.
settingsBuilder() - Static method in class org.elasticsearch.util.settings.ImmutableSettings
Returns a builder to be used in order to build settings.
SettingsException - Exception in org.elasticsearch.util.settings
A generic failure to handle settings.
SettingsException(String) - Constructor for exception org.elasticsearch.util.settings.SettingsException
 
SettingsException(String, Throwable) - Constructor for exception org.elasticsearch.util.settings.SettingsException
 
SettingsFilter - Class in org.elasticsearch.util.settings
 
SettingsFilter(Settings) - Constructor for class org.elasticsearch.util.settings.SettingsFilter
 
SettingsFilter.Filter - Interface in org.elasticsearch.util.settings
 
SettingsLoader - Interface in org.elasticsearch.util.settings.loader
Provides the ability to load settings (in the form of a simple Map) from the actual source content that represents them.
SettingsLoaderFactory - Class in org.elasticsearch.util.settings.loader
A settings loader factory automatically trying to identify what type of SettingsLoader to use.
SettingsModule - Class in org.elasticsearch.util.settings
A module that binds the provided settings to the Settings interface.
SettingsModule(Settings) - Constructor for class org.elasticsearch.util.settings.SettingsModule
 
setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Sets the handler for internal worker threads that terminate due to unrecoverable errors encountered while executing tasks.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TByteHash
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHash
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatHash
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.THash
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.THashMap
initialize the value array of the map.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TIntHash
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TLongHash
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectHash
initializes the Object set of this hash table.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TPrimitiveHash
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TShortHash
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUseClean(boolean) - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectory
 
setUseCompoundFile(boolean) - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy.MergePolicyParams
 
setUseDisMax(boolean) - Method in class org.elasticsearch.index.query.support.MultiFieldMapperQueryParser
 
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(V) - Method in class org.elasticsearch.util.collect.ForwardingMapEntry
 
setValue(byte) - Method in class org.elasticsearch.util.gnu.trove.TByteByteIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(double) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(float) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(int) - Method in class org.elasticsearch.util.gnu.trove.TByteIntIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(long) - Method in class org.elasticsearch.util.gnu.trove.TByteLongIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(V) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(short) - Method in class org.elasticsearch.util.gnu.trove.TByteShortIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(byte) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(double) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(float) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(long) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(V) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(short) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(byte) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(double) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(float) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(int) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(long) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(V) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(short) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(byte) - Method in class org.elasticsearch.util.gnu.trove.TIntByteIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(double) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(float) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(int) - Method in class org.elasticsearch.util.gnu.trove.TIntIntIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(long) - Method in class org.elasticsearch.util.gnu.trove.TIntLongIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(V) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(short) - Method in class org.elasticsearch.util.gnu.trove.TIntShortIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(byte) - Method in class org.elasticsearch.util.gnu.trove.TLongByteIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(double) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(float) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(int) - Method in class org.elasticsearch.util.gnu.trove.TLongIntIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(long) - Method in class org.elasticsearch.util.gnu.trove.TLongLongIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(V) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(short) - Method in class org.elasticsearch.util.gnu.trove.TLongShortIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(byte) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(double) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(float) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(int) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(long) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(short) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(byte) - Method in class org.elasticsearch.util.gnu.trove.TShortByteIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(double) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(float) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(int) - Method in class org.elasticsearch.util.gnu.trove.TShortIntIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(long) - Method in class org.elasticsearch.util.gnu.trove.TShortLongIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(V) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectIterator
Replace the value of the mapping at the iterator's position with the specified value.
setValue(short) - Method in class org.elasticsearch.util.gnu.trove.TShortShortIterator
Replace the value of the mapping at the iterator's position with the specified value.
shard() - Method in class org.elasticsearch.action.search.ShardSearchFailure
The search shard target the failure occured 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.
ShardDeleteByQueryRequest(String, byte[], String, String[], int) - Constructor for class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryRequest
 
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
 
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 - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
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, Comparable[]) - 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
 
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.none.NoneIndexGateway
 
shardId() - Method in class org.elasticsearch.action.admin.cluster.ping.replication.ShardReplicationPingRequest
 
shardId() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
 
shardId() - Method in class org.elasticsearch.action.deletebyquery.ShardDeleteByQueryRequest
 
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.ShardOperationRequest
 
shardId() - Method in class org.elasticsearch.action.support.single.TransportSingleOperationAction.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.PlainShardsIterator
 
shardId() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
 
shardId() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
 
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.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
 
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
 
shardModules() - 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() - Method in class org.elasticsearch.plugins.PluginsService
 
shardOperation(BroadcastShardPingRequest) - Method in class org.elasticsearch.action.admin.cluster.ping.broadcast.TransportBroadcastPingAction
 
shardOperation(SinglePingRequest, int) - Method in class org.elasticsearch.action.admin.cluster.ping.single.TransportSinglePingAction
 
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(ShardOptimizeRequest) - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
shardOperation(ShardRefreshRequest) - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
shardOperation(TransportIndicesStatusAction.IndexShardStatusRequest) - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
 
shardOperation(ShardCountRequest) - Method in class org.elasticsearch.action.count.TransportCountAction
 
shardOperation(GetRequest, int) - Method in class org.elasticsearch.action.get.TransportGetAction
 
shardOperation(ShardRequest) - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
shardOperation(Request, int) - Method in class org.elasticsearch.action.support.single.TransportSingleOperationAction
 
shardOperation(ShardTermsRequest) - Method in class org.elasticsearch.action.terms.TransportTermsAction
 
ShardOperationFailedException - Interface in org.elasticsearch.action
An exception indicating that a failure occurred performing an operation on the shard.
shardOperationOnBackup(TransportShardReplicationOperationAction<ShardReplicationPingRequest, ShardReplicationPingResponse>.ShardOperationRequest) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportShardReplicationPingAction
 
shardOperationOnBackup(TransportShardReplicationOperationAction<ShardGatewaySnapshotRequest, ShardGatewaySnapshotResponse>.ShardOperationRequest) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportShardGatewaySnapshotAction
 
shardOperationOnBackup(TransportShardReplicationOperationAction<DeleteRequest, DeleteResponse>.ShardOperationRequest) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
shardOperationOnBackup(TransportShardReplicationOperationAction<ShardDeleteByQueryRequest, ShardDeleteByQueryResponse>.ShardOperationRequest) - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
shardOperationOnBackup(TransportShardReplicationOperationAction<IndexRequest, IndexResponse>.ShardOperationRequest) - Method in class org.elasticsearch.action.index.TransportIndexAction
 
shardOperationOnBackup(TransportShardReplicationOperationAction<Request, Response>.ShardOperationRequest) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
shardOperationOnPrimary(TransportShardReplicationOperationAction<ShardReplicationPingRequest, ShardReplicationPingResponse>.ShardOperationRequest) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportShardReplicationPingAction
 
shardOperationOnPrimary(TransportShardReplicationOperationAction<ShardGatewaySnapshotRequest, ShardGatewaySnapshotResponse>.ShardOperationRequest) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportShardGatewaySnapshotAction
 
shardOperationOnPrimary(TransportShardReplicationOperationAction<DeleteRequest, DeleteResponse>.ShardOperationRequest) - Method in class org.elasticsearch.action.delete.TransportDeleteAction
 
shardOperationOnPrimary(TransportShardReplicationOperationAction<ShardDeleteByQueryRequest, ShardDeleteByQueryResponse>.ShardOperationRequest) - Method in class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
shardOperationOnPrimary(TransportShardReplicationOperationAction<IndexRequest, IndexResponse>.ShardOperationRequest) - Method in class org.elasticsearch.action.index.TransportIndexAction
 
shardOperationOnPrimary(TransportShardReplicationOperationAction<Request, Response>.ShardOperationRequest) - Method in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
ShardReplicationOperationRequest - Class in org.elasticsearch.action.support.replication
 
ShardReplicationOperationRequest() - Constructor for class org.elasticsearch.action.support.replication.ShardReplicationOperationRequest
 
ShardReplicationPingRequest - Class in org.elasticsearch.action.admin.cluster.ping.replication
 
ShardReplicationPingRequest(IndexReplicationPingRequest, int) - Constructor for class org.elasticsearch.action.admin.cluster.ping.replication.ShardReplicationPingRequest
 
ShardReplicationPingRequest(String, int) - Constructor for class org.elasticsearch.action.admin.cluster.ping.replication.ShardReplicationPingRequest
 
ShardReplicationPingResponse - Class in org.elasticsearch.action.admin.cluster.ping.replication
 
shardRouting() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
ShardRouting - Interface in org.elasticsearch.cluster.routing
 
ShardRoutingState - Enum in org.elasticsearch.cluster.routing
 
shards() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterIndexHealth
 
shards(BroadcastPingRequest, ClusterState) - Method in class org.elasticsearch.action.admin.cluster.ping.broadcast.TransportBroadcastPingAction
 
shards(IndexReplicationPingRequest) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportIndexReplicationPingAction
 
shards(ClusterState, ShardReplicationPingRequest) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportShardReplicationPingAction
 
shards(ClearIndicesCacheRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
The refresh request works against *all* shards.
shards(FlushRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
The refresh request works against *all* shards.
shards(IndexGatewaySnapshotRequest) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportIndexGatewaySnapshotAction
 
shards(ClusterState, ShardGatewaySnapshotRequest) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportShardGatewaySnapshotAction
 
shards(OptimizeRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
The refresh request works against *all* shards.
shards(RefreshRequest, ClusterState) - 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.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(IndicesStatusRequest, ClusterState) - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
Status goes across *all* shards.
shards(CountRequest, ClusterState) - Method in class org.elasticsearch.action.count.TransportCountAction
 
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, IndexRequest) - Method in class org.elasticsearch.action.index.TransportIndexAction
 
shards(Request, ClusterState) - 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(TermsRequest, ClusterState) - Method in class org.elasticsearch.action.terms.TransportTermsAction
 
shards() - Method in class org.elasticsearch.cluster.routing.IndexRoutingTable
 
shards() - Method in class org.elasticsearch.cluster.routing.IndexShardRoutingTable
 
shards() - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
shards(ClusterState, String, String) - Method in class org.elasticsearch.index.routing.plain.PlainOperationRouting
 
shardSafe(int) - Method in interface org.elasticsearch.index.service.IndexService
 
shardSafe(int) - Method in class org.elasticsearch.index.service.InternalIndexService
 
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
 
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() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
A shard iterator with just this shard in it.
ShardsIterator - Interface in org.elasticsearch.cluster.routing
 
shardsIts - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
shardsOfType(ShardRoutingState) - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
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
 
ShardsRoutingStrategy - Interface in org.elasticsearch.cluster.routing.strategy
 
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, ShardsRoutingStrategy, ThreadPool) - Constructor for class org.elasticsearch.cluster.action.shard.ShardStateAction
 
ShardStatus - Class in org.elasticsearch.action.admin.indices.status
 
ShardStatus.Docs - Class in org.elasticsearch.action.admin.indices.status
 
ShardStatus.Docs() - Constructor for class org.elasticsearch.action.admin.indices.status.ShardStatus.Docs
 
shardsWithState(ShardRoutingState...) - Method in class org.elasticsearch.cluster.routing.RoutingNode
 
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.dfs.DfsSearchResult
 
shardTarget() - Method in class org.elasticsearch.search.fetch.FetchSearchResult
 
shardTarget() - Method in class org.elasticsearch.search.fetch.QueryFetchSearchResult
 
shardTarget() - Method in class org.elasticsearch.search.internal.SearchContext
 
shardTarget() - Method in class org.elasticsearch.search.query.QuerySearchResult
 
shardTarget() - Method in interface org.elasticsearch.search.SearchPhaseResult
 
share() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
ShingleTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
ShingleTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ShingleTokenFilterFactory
 
shortField(String) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
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
 
shortSummary() - Method in class org.elasticsearch.util.StopWatch
Return a short description of the total running time.
shortToBytes(int) - Static method in class org.elasticsearch.util.Numbers
Converts an int to a byte array.
shortValue() - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentParser
 
shortValue() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
should(XContentFilterBuilder) - Method in class org.elasticsearch.index.query.xcontent.BoolFilterBuilder
Adds a filter that should appear in the matching documents.
should(XContentQueryBuilder) - Method in class org.elasticsearch.index.query.xcontent.BoolQueryBuilder
Adds a query that should appear in the matching documents.
shouldBreakTermEnumeration(Object) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Return true if this term value indicates breaking out of term enumeration on this field.
shouldBreakTermEnumeration(Object) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
Never break on this term enumeration value.
shouldBreakTermEnumeration(Object) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
Breaks on this text if its null.
shuffle(Random) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Shuffle the elements of the list using the specified random number generator.
shuffle(Random) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Shuffle the elements of the list using the specified random number generator.
shuffle(Random) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Shuffle the elements of the list using the specified random number generator.
shuffle(Random) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Shuffle the elements of the list using the specified random number generator.
shuffle(Random) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Shuffle the elements of the list using the specified random number generator.
shuffle(Random) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Shuffle the elements of the list using the specified random number generator.
SHUTDOWN - Static variable in class org.elasticsearch.action.TransportActions.Admin.Cluster.Node
 
shutdown() - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
shutdown() - Method in interface org.elasticsearch.threadpool.ThreadPool
Initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
shutdown() - Method in class org.elasticsearch.util.concurrent.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.util.concurrent.ScalingThreadPoolExecutor
 
shutdownNow() - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
shutdownNow() - Method in interface org.elasticsearch.threadpool.ThreadPool
Attempts to stop all actively executing tasks, halts the processing of waiting tasks, and returns a list of the tasks that were awaiting execution.
shutdownNow() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Attempts to cancel and/or stop all tasks, and reject all subsequently submitted tasks.
shutdownNow() - Method in class org.elasticsearch.util.concurrent.ScalingThreadPoolExecutor
 
sigar() - Method in class org.elasticsearch.monitor.sigar.SigarService
 
sigarAvailable() - Method in class org.elasticsearch.monitor.sigar.SigarService
 
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
 
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.xcontent.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
 
SimpleAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
SimpleAnalyzerProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.SimpleAnalyzerProvider
 
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
 
SimpleFsStore - Class in org.elasticsearch.index.store.fs
 
SimpleFsStore(ShardId, Settings, Environment, String) - Constructor for class org.elasticsearch.index.store.fs.SimpleFsStore
 
SimpleFsStoreModule - Class in org.elasticsearch.index.store.fs
 
SimpleFsStoreModule() - Constructor for class org.elasticsearch.index.store.fs.SimpleFsStoreModule
 
SimpleHashFunction - Class in org.elasticsearch.index.routing.hash.simple
 
SimpleHashFunction() - Constructor for class org.elasticsearch.index.routing.hash.simple.SimpleHashFunction
 
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
 
SINGLE - Static variable in class org.elasticsearch.action.TransportActions.Admin.Cluster.Ping
 
SINGLE_INSTANCE_AND_SCOPE - Static variable in class org.elasticsearch.util.inject.internal.AbstractBindingBuilder
 
SingleOperationRequest - Class in org.elasticsearch.action.support.single
 
SingleOperationRequest() - Constructor for class org.elasticsearch.action.support.single.SingleOperationRequest
 
SingleOperationRequest(String, String, String) - Constructor for class org.elasticsearch.action.support.single.SingleOperationRequest
 
SinglePingRequest - Class in org.elasticsearch.action.admin.cluster.ping.single
 
SinglePingRequest(String) - Constructor for class org.elasticsearch.action.admin.cluster.ping.single.SinglePingRequest
 
SinglePingRequest(String, String, String) - Constructor for class org.elasticsearch.action.admin.cluster.ping.single.SinglePingRequest
 
SinglePingResponse - Class in org.elasticsearch.action.admin.cluster.ping.single
 
SinglePingResponse() - Constructor for class org.elasticsearch.action.admin.cluster.ping.single.SinglePingResponse
 
SINGLETON - Static variable in class org.elasticsearch.util.inject.Scopes
One instance per Injector.
Singleton - Annotation Type in org.elasticsearch.util.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.util.inject.internal.Scoping
 
SINGLETON_INSTANCE - Static variable in class org.elasticsearch.util.inject.internal.Scoping
 
singletonIterator(T) - Static method in class org.elasticsearch.util.collect.Iterators
Returns an iterator containing only value.
size() - Method in class org.elasticsearch.action.terms.TermsRequest
The number of term / doc freq pairs to return per field.
size(int) - Method in class org.elasticsearch.action.terms.TermsRequest
The number of term / doc freq pairs to return per field.
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
 
size() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotIndexCommits
 
size(SegmentInfo) - Method in class org.elasticsearch.index.merge.policy.BalancedSegmentMergePolicy
 
size() - Method in class org.elasticsearch.index.translog.memory.MemorySnapshot
 
size() - Method in class org.elasticsearch.index.translog.memory.MemoryTranslog
 
size() - Method in interface org.elasticsearch.index.translog.Translog
Returns the number of operations in the transaction log.
size() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
The number of translog operations in the snapshot.
size(int) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
The number of search hits to return.
size() - Method in class org.elasticsearch.search.internal.SearchContext
 
size(int) - Method in class org.elasticsearch.search.internal.SearchContext
 
size() - Method in class org.elasticsearch.search.query.QuerySearchResult
 
size(int) - Method in class org.elasticsearch.search.query.QuerySearchResult
 
size() - Method in class org.elasticsearch.util.collect.ConcurrentHashMultiset
size() - Method in class org.elasticsearch.util.collect.ForwardingCollection
 
size() - Method in class org.elasticsearch.util.collect.ForwardingMap
 
size() - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
size() - Method in class org.elasticsearch.util.collect.ImmutableBiMap
 
size() - Method in class org.elasticsearch.util.collect.ImmutableMultimap
 
size() - Method in class org.elasticsearch.util.collect.ImmutableMultiset
 
size() - Method in class org.elasticsearch.util.collect.ImmutableSortedMap
 
size(Iterable<?>) - Static method in class org.elasticsearch.util.collect.Iterables
Returns the number of elements in iterable.
size(Iterator<?>) - Static method in class org.elasticsearch.util.collect.Iterators
Returns the number of elements remaining in iterator.
size() - Method in class org.elasticsearch.util.collect.LinkedListMultimap
 
size() - Method in interface org.elasticsearch.util.collect.Multimap
Returns the number of key-value pairs in the multimap.
size() - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
size() - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Returns the number of key-value mappings in this map.
size() - Method in class org.elasticsearch.util.concurrent.ConcurrentSafeArray
 
size() - Method in class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
size() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Returns the number of key-value mappings in this map.
size() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Returns the number of key-value mappings in this map.
size() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashSet
Current count of elements in the set.
size() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Returns the number of key-value mappings in this map.
size() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Returns the number of key-value mappings in this map.
size() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingSetInt
Current count of elements in the set.
size() - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
Returns the number of elements in this queue.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteHashSetDecorator
Returns the number of entries in the set.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleHashSetDecorator
Returns the number of entries in the set.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatHashSetDecorator
Returns the number of entries in the set.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntHashSetDecorator
Returns the number of entries in the set.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongHashSetDecorator
Returns the number of entries in the set.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortHashSetDecorator
Returns the number of entries in the set.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Returns the number of entries in the map.
size() - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Returns the number of values in the list.
size() - Method in class org.elasticsearch.util.gnu.trove.TByteStack
Returns the current depth of the stack.
size() - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Returns the number of values in the list.
size() - Method in class org.elasticsearch.util.gnu.trove.TDoubleStack
Returns the current depth of the stack.
size() - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Returns the number of values in the list.
size() - Method in class org.elasticsearch.util.gnu.trove.TFloatStack
Returns the current depth of the stack.
size() - Method in class org.elasticsearch.util.gnu.trove.THash
Returns the number of distinct elements in this collection.
size() - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Returns the number of values in the list.
size() - Method in class org.elasticsearch.util.gnu.trove.TIntStack
Returns the current depth of the stack.
size() - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Returns the number of elements in the list.
size() - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Returns the number of values in the list.
size() - Method in class org.elasticsearch.util.gnu.trove.TLongStack
Returns the current depth of the stack.
size() - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Returns the number of values in the list.
size() - Method in class org.elasticsearch.util.gnu.trove.TShortStack
Returns the current depth of the stack.
size() - Method in class org.elasticsearch.util.IdentityHashSet
Returns the number of elements in this set (its cardinality).
size() - Method in class org.elasticsearch.util.inject.internal.Errors
 
size() - Method in class org.elasticsearch.util.io.FastByteArrayOutputStream
Returns the current size of the buffer.
size() - Method in class org.elasticsearch.util.io.FastCharArrayWriter
Returns the current size of the buffer.
size() - Method in class org.elasticsearch.util.io.FastDataOutputStream
Returns the current value of the counter written, the number of bytes written to this data output stream so far.
size() - Method in class org.elasticsearch.util.io.stream.BytesStreamOutput
Returns the current size of the buffer.
size() - Method in class org.elasticsearch.util.jline.ANSI.Buffer
 
size() - Method in class org.elasticsearch.util.MapBackedSet
 
size() - Method in interface org.elasticsearch.util.SafeArray
 
sizeActive() - Method in class org.elasticsearch.cluster.routing.PlainShardsIterator
 
sizeActive() - Method in interface org.elasticsearch.cluster.routing.ShardsIterator
 
SizeHeaderFrameDecoder - Class in org.elasticsearch.transport.netty
 
SizeHeaderFrameDecoder() - Constructor for class org.elasticsearch.transport.netty.SizeHeaderFrameDecoder
 
SizeParseElement - Class in org.elasticsearch.search.query
 
SizeParseElement() - Constructor for class org.elasticsearch.search.query.SizeParseElement
 
SizeUnit - Enum in org.elasticsearch.util
A SizeUnit represents size at a given unit of granularity and provides utility methods to convert across units.
SizeValue - Class in org.elasticsearch.util
 
SizeValue(long) - Constructor for class org.elasticsearch.util.SizeValue
 
SizeValue(long, SizeUnit) - Constructor for class org.elasticsearch.util.SizeValue
 
skip(long) - Method in class org.elasticsearch.util.io.FastByteArrayInputStream
Skips n bytes of input from this input stream.
skip(long) - Method in class org.elasticsearch.util.io.FastCharArrayReader
Skips characters.
skip(long) - Method in class org.elasticsearch.util.io.FastStringReader
Skips the specified number of characters in the stream.
skipChildren() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
skipChildren() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
skipChildren() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
skipNulls() - Method in class org.elasticsearch.util.base.Joiner
Returns a joiner with the same behavior as this joiner, except automatically skipping over any provided null elements.
skipSources(Class...) - Method in interface org.elasticsearch.util.inject.Binder
Returns a binder that skips classesToSkip when identify the calling code.
skipSources(Class...) - Method in interface org.elasticsearch.util.inject.PrivateBinder
 
skipTo(int) - Method in class org.elasticsearch.index.translog.memory.MemorySnapshot
 
skipTo(int) - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
 
Slf4jESLogger - Class in org.elasticsearch.util.logging.slf4j
 
Slf4jESLogger(String, Logger) - Constructor for class org.elasticsearch.util.logging.slf4j.Slf4jESLogger
 
Slf4jESLoggerFactory - Class in org.elasticsearch.util.logging.slf4j
 
Slf4jESLoggerFactory() - Constructor for class org.elasticsearch.util.logging.slf4j.Slf4jESLoggerFactory
 
slop(int) - Method in class org.elasticsearch.index.query.xcontent.SpanNearQueryBuilder
 
smartFieldMappers(String) - Method in class org.elasticsearch.index.query.xcontent.QueryParseContext
 
smartName(String) - Method in class org.elasticsearch.index.mapper.DocumentFieldMappers
Tries to find first based on DocumentFieldMappers.fullName(String), then by DocumentFieldMappers.indexName(String).
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.
smartNameFieldMappers(String) - Method in class org.elasticsearch.index.mapper.MapperService
Same as MapperService.smartName(String), except it returns just the field mappers.
SNAPSHOT - Static variable in class org.elasticsearch.action.TransportActions.Admin.Indices.Gateway
 
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.fs.FsIndexShardGateway
 
snapshot(IndexShardGateway.Snapshot) - Method in interface org.elasticsearch.index.gateway.IndexShardGateway
Snapshots the given shard into the gateway.
snapshot() - 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.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.memory.MemoryTranslog
 
snapshot(Translog.Snapshot) - Method in class org.elasticsearch.index.translog.memory.MemoryTranslog
 
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.
snapshotBuild() - Static 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
 
snapshots() - Method in class org.elasticsearch.index.deletionpolicy.SnapshotDeletionPolicy
Snapshots all the current commits in the index.
SoftFilterCache - Class in org.elasticsearch.index.cache.filter.soft
A soft reference based filter cache that has soft keys on the IndexReader.
SoftFilterCache(Index, Settings, ThreadPool) - Constructor for class org.elasticsearch.index.cache.filter.soft.SoftFilterCache
 
softKeys() - Method in class org.elasticsearch.util.collect.MapMaker
Specifies that each key (not value) stored in the map should be wrapped in a SoftReference (by default, strong references are used).
softValues() - Method in class org.elasticsearch.util.collect.MapMaker
Specifies that each value (not key) stored in the map should be wrapped in a SoftReference (by default, strong references are used).
sort(String, SearchSourceBuilder.Order) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Adds a sort against the given field name and the sort ordering.
sort(String, boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Add a sort against the given field name and if it should be revered or not.
sort(String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Add a sort against the given field name.
sort(String, String) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Add a sort against the given field name of the given type.
sort(String, String, boolean) - Method in class org.elasticsearch.search.builder.SearchSourceBuilder
Add a sort against the given field name and if it should be revered or not.
sort(Sort) - Method in class org.elasticsearch.search.internal.SearchContext
 
sort() - Method in class org.elasticsearch.search.internal.SearchContext
 
sort() - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Sort the values in the list (ascending) using the Sun quicksort implementation.
sort(int, int) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Sort a slice of the list (ascending) using the Sun quicksort implementation.
sort() - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Sort the values in the list (ascending) using the Sun quicksort implementation.
sort(int, int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Sort a slice of the list (ascending) using the Sun quicksort implementation.
sort() - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Sort the values in the list (ascending) using the Sun quicksort implementation.
sort(int, int) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Sort a slice of the list (ascending) using the Sun quicksort implementation.
sort() - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Sort the values in the list (ascending) using the Sun quicksort implementation.
sort(int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Sort a slice of the list (ascending) using the Sun quicksort implementation.
sort() - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Sort the values in the list (ascending) using the Sun quicksort implementation.
sort(int, int) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Sort a slice of the list (ascending) using the Sun quicksort implementation.
sort() - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Sort the values in the list (ascending) using the Sun quicksort implementation.
sort(int, int) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Sort a slice of the list (ascending) using the Sun quicksort implementation.
sortDocs(Collection<? extends QuerySearchResultProvider>) - Method in class org.elasticsearch.search.controller.SearchPhaseController
 
sortedCopy(Iterable<E>) - Method in class org.elasticsearch.util.collect.Ordering
Returns a copy of the given iterable sorted by this ordering.
sortedNodesLeastToHigh() - Method in class org.elasticsearch.cluster.routing.RoutingNodes
 
SortedSetMultimap<K,V> - Interface in org.elasticsearch.util.collect
A SetMultimap whose set of values for a given key are kept sorted; that is, they comprise a SortedSet.
sortedShardList - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
SortParseElement - Class in org.elasticsearch.search.query
 
SortParseElement() - Constructor for class org.elasticsearch.search.query.SortParseElement
 
sortStringArray(String[]) - Static method in class org.elasticsearch.util.Strings
Turn given source String array into sorted array.
sortType() - Method in class org.elasticsearch.action.terms.TermsRequest
The type of sorting for term / doc freq.
sortType(TermsRequest.SortType) - Method in class org.elasticsearch.action.terms.TermsRequest
The type of sorting for term / doc freq.
sortType(String) - Method in class org.elasticsearch.action.terms.TermsRequest
Sets the string representation of the sort type.
sortType() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
sortType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
sortType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
 
sortType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper
 
sortType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
sortType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper
 
sortType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper
 
sortType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper
 
sortType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
 
sortType() - Method in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper
 
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() - Method in class org.elasticsearch.action.get.GetResponse
The source of the document if exists.
source(Map) - Method in class org.elasticsearch.action.index.IndexRequest
Writes the Map as a JSON.
source(Map, XContentType) - Method in class org.elasticsearch.action.index.IndexRequest
Writes 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(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(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, 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() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
The source that caused this cluster event to be raised.
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.Index
 
source() - Method in class org.elasticsearch.index.mapper.ParsedDocument
 
source() - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
 
source() - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
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() - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
source() - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
source(byte[]) - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
source(byte[], int, int) - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
source() - Method in interface org.elasticsearch.search.SearchHit
The source of the document (can be null).
sourceAsMap() - Method in class org.elasticsearch.action.get.GetResponse
The source of the document (As a map).
sourceAsMap() - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
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.search.internal.InternalSearchHit
 
sourceAsString() - Method in interface org.elasticsearch.search.SearchHit
The source of the document as string (can be null).
sourceField(XContentSourceFieldMapper.Builder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper.Builder
 
SourceFieldMapper - Interface in org.elasticsearch.index.mapper
A mapper that maps the actual source of a generated document.
sourceFieldMappers() - Method in class org.elasticsearch.index.mapper.MapperService
 
sourceLength() - Method in class org.elasticsearch.action.search.SearchRequest
 
sourceLength() - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
sourceMapper() - Method in interface org.elasticsearch.index.mapper.DocumentMapper
 
sourceMapper() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
sourceOffset() - Method in class org.elasticsearch.action.search.SearchRequest
 
sourceOffset() - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
SourceProvider - Class in org.elasticsearch.util.inject.internal
Provides access to the calling line of code.
SourceProvider() - Constructor for class org.elasticsearch.util.inject.internal.SourceProvider
 
spanFirstQuery(XContentSpanQueryBuilder, int) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
 
SpanFirstQueryBuilder - Class in org.elasticsearch.index.query.xcontent
 
SpanFirstQueryBuilder(XContentSpanQueryBuilder, int) - Constructor for class org.elasticsearch.index.query.xcontent.SpanFirstQueryBuilder
 
SpanFirstQueryParser - Class in org.elasticsearch.index.query.xcontent
 
SpanFirstQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.SpanFirstQueryParser
 
spanNearQuery() - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
 
SpanNearQueryBuilder - Class in org.elasticsearch.index.query.xcontent
 
SpanNearQueryBuilder() - Constructor for class org.elasticsearch.index.query.xcontent.SpanNearQueryBuilder
 
SpanNearQueryParser - Class in org.elasticsearch.index.query.xcontent
 
SpanNearQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.SpanNearQueryParser
 
spanNotQuery() - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
 
SpanNotQueryBuilder - Class in org.elasticsearch.index.query.xcontent
 
SpanNotQueryBuilder() - Constructor for class org.elasticsearch.index.query.xcontent.SpanNotQueryBuilder
 
SpanNotQueryParser - Class in org.elasticsearch.index.query.xcontent
 
SpanNotQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.SpanNotQueryParser
 
spanOrQuery() - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
 
SpanOrQueryBuilder - Class in org.elasticsearch.index.query.xcontent
 
SpanOrQueryBuilder() - Constructor for class org.elasticsearch.index.query.xcontent.SpanOrQueryBuilder
 
SpanOrQueryParser - Class in org.elasticsearch.index.query.xcontent
 
SpanOrQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.SpanOrQueryParser
 
spanTermQuery(String, String) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
 
spanTermQuery(String, int) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
 
spanTermQuery(String, long) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
 
spanTermQuery(String, float) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
 
spanTermQuery(String, double) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
 
SpanTermQueryBuilder - Class in org.elasticsearch.index.query.xcontent
 
SpanTermQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.xcontent.SpanTermQueryBuilder
 
SpanTermQueryBuilder(String, int) - Constructor for class org.elasticsearch.index.query.xcontent.SpanTermQueryBuilder
 
SpanTermQueryBuilder(String, long) - Constructor for class org.elasticsearch.index.query.xcontent.SpanTermQueryBuilder
 
SpanTermQueryBuilder(String, float) - Constructor for class org.elasticsearch.index.query.xcontent.SpanTermQueryBuilder
 
SpanTermQueryBuilder(String, double) - Constructor for class org.elasticsearch.index.query.xcontent.SpanTermQueryBuilder
 
SpanTermQueryParser - Class in org.elasticsearch.index.query.xcontent
 
SpanTermQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.SpanTermQueryParser
 
spawn() - Method in interface org.elasticsearch.http.HttpServerHandler
 
spawn() - Method in class org.elasticsearch.transport.BaseTransportRequestHandler
 
spawn() - Method in class org.elasticsearch.transport.BaseTransportResponseHandler
 
spawn() - Method in class org.elasticsearch.transport.PlainTransportFuture
 
spawn() - Method in interface org.elasticsearch.transport.TransportRequestHandler
 
spawn() - Method in interface org.elasticsearch.transport.TransportResponseHandler
 
spawn() - Method in class org.elasticsearch.transport.VoidTransportResponseHandler
 
split(String, String) - Static method in class org.elasticsearch.util.Strings
Split a String at the first occurrence of the delimiter.
splitArrayElementsIntoProperties(String[], String) - Static method in class org.elasticsearch.util.Strings
Take an array Strings and split each element based on the given delimiter.
splitArrayElementsIntoProperties(String[], String, String) - Static method in class org.elasticsearch.util.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
 
splitTypes(String) - Static method in class org.elasticsearch.rest.action.support.RestActions
 
StackTraceElements - Class in org.elasticsearch.util.inject.internal
Creates stack trace elements for members.
StackTraceElements() - Constructor for class org.elasticsearch.util.inject.internal.StackTraceElements
 
Stage - Enum in org.elasticsearch.util.inject
The stage we're running in.
STANDARD_ANALYZER - Static variable in class org.elasticsearch.util.lucene.Lucene
 
StandardAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
StandardAnalyzerProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StandardAnalyzerProvider
 
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.bootstrap.Bootstrap
hook for JSVC
start() - Method in class org.elasticsearch.client.transport.TransportClientClusterService
 
start(DiscoveryNode) - 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.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.util.component.AbstractLifecycleComponent
 
start() - Method in interface org.elasticsearch.util.component.LifecycleComponent
 
start() - Method in class org.elasticsearch.util.StopWatch
Start an unnamed task.
start(String) - Method in class org.elasticsearch.util.StopWatch
Start a named task.
start() - Method in class org.elasticsearch.util.timer.HashedWheelTimer
Starts the background thread explicitly.
startArray(String) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
startArray() - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
startConstruction() - Method in class org.elasticsearch.util.inject.internal.ConstructionContext
 
started() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
started() - Method in interface org.elasticsearch.cluster.routing.ShardRouting
 
started - Variable in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
started() - Method in class org.elasticsearch.util.component.Lifecycle
Returns true if the state is started.
startFinalizer(Class<?>, Object) - Static method in class org.elasticsearch.util.base.internal.Finalizer
Starts the Finalizer thread.
startObject(String) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
startObject() - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
startRecovery(DiscoveryNode, DiscoveryNode, boolean) - Method in class org.elasticsearch.index.shard.recovery.RecoveryAction
 
startsWithIgnoreCase(String, String) - Static method in class org.elasticsearch.util.Strings
Test if the given String starts with the specified prefix, ignoring upper/lower case.
startTime() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
state() - Method in class org.elasticsearch.action.admin.cluster.state.ClusterStateResponse
 
state() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
STATE - Static variable in class org.elasticsearch.action.TransportActions.Admin.Cluster
 
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.node.NodeClusterAdminClient
 
state(ClusterStateRequest, ActionListener<ClusterStateResponse>) - Method in class org.elasticsearch.client.node.NodeClusterAdminClient
 
state(ClusterStateRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
state(ClusterStateRequest, ActionListener<ClusterStateResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClusterAdminClient
 
state() - Method in class org.elasticsearch.cluster.ClusterChangedEvent
 
state() - Method in interface org.elasticsearch.cluster.ClusterService
 
state(ClusterState) - Method in class org.elasticsearch.cluster.ClusterState.Builder
 
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
 
state() - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
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.util.component.Lifecycle
 
StaticInjectionRequest - Class in org.elasticsearch.util.inject.spi
A request to inject the static fields and methods of a type.
STATS - Static variable in class org.elasticsearch.action.TransportActions.Admin.Cluster.Node
 
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.threadpool.support.AbstractThreadPool
 
stats() - Method in interface org.elasticsearch.threadpool.ThreadPool
 
stats() - Method in class org.elasticsearch.transport.TransportService
 
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 - Static variable in class org.elasticsearch.action.TransportActions.Admin.Indices
 
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.node.NodeIndicesAdminClient
 
status(IndicesStatusRequest, ActionListener<IndicesStatusResponse>) - Method in class org.elasticsearch.client.node.NodeIndicesAdminClient
 
status(IndicesStatusRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
status(IndicesStatusRequest, ActionListener<IndicesStatusResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportIndicesAdminClient
 
status() - Method in interface org.elasticsearch.rest.RestResponse
 
status() - Method in class org.elasticsearch.rest.Utf8RestResponse
 
status() - Method in class org.elasticsearch.rest.XContentRestResponse
 
stop() - Method in class org.elasticsearch.bootstrap.Bootstrap
hook for JSVC
stop() - 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.
stop() - Method in class org.elasticsearch.util.component.AbstractLifecycleComponent
 
stop() - Method in interface org.elasticsearch.util.component.LifecycleComponent
 
stop() - Method in class org.elasticsearch.util.StopWatch
Stop the current task.
stop() - Method in class org.elasticsearch.util.timer.HashedWheelTimer
 
stop() - Method in interface org.elasticsearch.util.timer.Timer
Releases all resources acquired by this Timer and cancels all tasks which were scheduled but not executed yet.
StopAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
StopAnalyzerProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StopAnalyzerProvider
 
stopped() - Method in class org.elasticsearch.util.component.Lifecycle
Returns true if the state is stopped.
StopTokenFilterFactory - Class in org.elasticsearch.index.analysis
 
StopTokenFilterFactory(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.StopTokenFilterFactory
 
Stopwatch - Class in org.elasticsearch.util.inject.internal
Enables simple performance monitoring.
Stopwatch() - Constructor for class org.elasticsearch.util.inject.internal.Stopwatch
 
StopWatch - Class in org.elasticsearch.util
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.util.StopWatch
Construct a new stop watch.
StopWatch(String) - Constructor for class org.elasticsearch.util.StopWatch
Construct a new stop watch with the given id.
StopWatch.TaskInfo - Class in org.elasticsearch.util
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.xcontent.MoreLikeThisFieldQueryBuilder
Set the set of stopwords.
stopWords(String...) - Method in class org.elasticsearch.index.query.xcontent.MoreLikeThisQueryBuilder
Set the set of stopwords.
store() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
store(Field.Store) - Method in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper.Builder
 
store(Field.Store) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper.Builder
 
STORE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper.Defaults
 
store - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
store(Field.Store) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
STORE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Defaults
 
store(Field.Store) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.OpenBuilder
 
store - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
store() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
STORE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper.Defaults
 
store(Field.Store) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.Builder
 
STORE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper.Defaults
 
STORE - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper.Defaults
 
store() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
Store<T extends org.apache.lucene.store.Directory> - Interface in org.elasticsearch.index.store
 
stored() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
stored() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
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
 
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) - Constructor for class org.elasticsearch.index.store.StoreModule
 
storeSize() - Method in class org.elasticsearch.action.admin.indices.status.IndexShardStatus
 
storeSize() - Method in class org.elasticsearch.action.admin.indices.status.IndexStatus
 
storeSize() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
Streamable - Interface in org.elasticsearch.util.io.stream
 
streamDone(ShardId, String) - Method in class org.elasticsearch.indices.recovery.throttler.RecoveryThrottler
 
StreamInput - Class in org.elasticsearch.util.io.stream
 
StreamInput() - Constructor for class org.elasticsearch.util.io.stream.StreamInput
 
StreamOutput - Class in org.elasticsearch.util.io.stream
 
StreamOutput() - Constructor for class org.elasticsearch.util.io.stream.StreamOutput
 
Streams - Class in org.elasticsearch.util.io
Simple utility methods for file and stream copying.
Streams() - Constructor for class org.elasticsearch.util.io.Streams
 
string() - Method in class org.elasticsearch.util.io.compression.CompressedString
 
string() - Method in class org.elasticsearch.util.xcontent.builder.BinaryXContentBuilder
 
string() - Method in class org.elasticsearch.util.xcontent.builder.TextXContentBuilder
 
string() - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
stringBuilder() - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
A string builder that can be used to construct complex names for example.
StringBuilderWriter - Class in org.elasticsearch.util.io
A Writer based on StringBuilder.
StringBuilderWriter() - Constructor for class org.elasticsearch.util.io.StringBuilderWriter
Construct a new StringBuilder instance with default capacity.
StringBuilderWriter(int) - Constructor for class org.elasticsearch.util.io.StringBuilderWriter
Construct a new StringBuilder instance with the specified capacity.
StringBuilderWriter(StringBuilder) - Constructor for class org.elasticsearch.util.io.StringBuilderWriter
Construct a new instance with the specified StringBuilder.
StringBuilderWriter.Cached - Class in org.elasticsearch.util.io
A thread local based cache of StringBuilderWriter.
StringBuilderWriter.Cached() - Constructor for class org.elasticsearch.util.io.StringBuilderWriter.Cached
 
stringField(String) - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
StringRestResponse - Class in org.elasticsearch.rest
 
StringRestResponse(RestResponse.Status) - Constructor for class org.elasticsearch.rest.StringRestResponse
 
StringRestResponse(RestResponse.Status, String) - Constructor for class org.elasticsearch.rest.StringRestResponse
 
Strings - Class in org.elasticsearch.util.inject.internal
String utilities.
Strings - Class in org.elasticsearch.util
 
StringStreamable - Class in org.elasticsearch.util.io.stream
 
StringStreamable() - Constructor for class org.elasticsearch.util.io.stream.StringStreamable
 
StringStreamable(String) - Constructor for class org.elasticsearch.util.io.stream.StringStreamable
 
stripFilenameExtension(String) - Static method in class org.elasticsearch.util.Strings
Strip the filename extension from the given path, e.g.
STYLED_POST_TAGS - Static variable in class org.elasticsearch.search.highlight.HighlighterParseElement
 
subclassesOf(Class<?>) - Static method in class org.elasticsearch.util.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 org.elasticsearch.util.collect.ForwardingList
 
subList(int, int) - Method in class org.elasticsearch.util.collect.ImmutableList
Returns an immutable list of the elements between the specified fromIndex, inclusive, and toIndex, exclusive.
subList(int, int) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Returns a sublist of this list.
subList(int, int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Returns a sublist of this list.
subList(int, int) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Returns a sublist of this list.
subList(int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Returns a sublist of this list.
subList(int, int) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Returns a sublist of this list.
subList(int, int) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Returns a sublist of this list.
subMap(K, K) - Method in class org.elasticsearch.util.collect.ForwardingSortedMap
 
subMap(K, K) - Method in class org.elasticsearch.util.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys ranges from fromKey, inclusive, to toKey, exclusive.
submit(Callable<T>) - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
submit(Callable<T>, FutureListener<T>) - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
submit(Runnable, T) - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
submit(Runnable, T, FutureListener<T>) - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
submit(Runnable) - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
submit(Runnable, FutureListener<?>) - Method in class org.elasticsearch.threadpool.support.AbstractThreadPool
 
submit(Callable<T>) - Method in interface org.elasticsearch.threadpool.ThreadPool
Submits a value-returning task for execution and returns a Future representing the pending results of the task.
submit(Runnable, T) - Method in interface org.elasticsearch.threadpool.ThreadPool
Submits a Runnable task for execution and returns a Future representing that task.
submit(Runnable) - Method in interface org.elasticsearch.threadpool.ThreadPool
Submits a Runnable task for execution and returns a Future representing that task.
submit(Callable<T>, FutureListener<T>) - Method in interface org.elasticsearch.threadpool.ThreadPool
 
submit(Runnable, T, FutureListener<T>) - Method in interface org.elasticsearch.threadpool.ThreadPool
 
submit(Runnable, FutureListener<?>) - Method in interface org.elasticsearch.threadpool.ThreadPool
 
submit(Callable<T>) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
 
submit(Runnable, T) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
 
submit(Runnable) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
 
submit(ForkJoinTask<T>) - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinPool
Submits a ForkJoinTask for execution.
submitRequest(DiscoveryNode, String, Streamable, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
 
submitRequest(DiscoveryNode, String, Streamable, TimeValue, TransportResponseHandler<T>) - Method in class org.elasticsearch.transport.TransportService
 
submitStateUpdateTask(String, ClusterStateUpdateTask) - Method in interface org.elasticsearch.cluster.ClusterService
 
submitStateUpdateTask(String, ClusterStateUpdateTask) - Method in class org.elasticsearch.cluster.service.InternalClusterService
 
subSequence(int, int) - Method in class org.elasticsearch.util.io.FastStringReader
 
subSequence(int, int) - Method in class org.elasticsearch.util.lucene.analysis.CharSequenceTermAttribute
 
subSet(E, E) - Method in class org.elasticsearch.util.collect.ForwardingSortedSet
 
subSet(E, E) - Method in class org.elasticsearch.util.collect.ImmutableSortedSet
substringMatch(CharSequence, int, CharSequence) - Static method in class org.elasticsearch.util.Strings
Test whether the given string matches the given substring at the given index.
subtypeNotProvided(Class<? extends Provider<?>>, Class<?>) - Method in class org.elasticsearch.util.inject.internal.Errors
 
subtypeOf(Type) - Static method in class org.elasticsearch.util.inject.util.Types
Returns a type that represents an unknown type that extends bound.
successfulShards() - Method in class org.elasticsearch.action.admin.cluster.ping.replication.IndexReplicationPingResponse
 
successfulShards() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.IndexGatewaySnapshotResponse
The number of successful shards the gateway snapshot operation was performed 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.util.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.none.NoneGateway
 
suggestUseCompoundFile() - Method in class org.elasticsearch.index.store.fs.MmapFsStore
 
suggestUseCompoundFile() - Method in class org.elasticsearch.index.store.fs.NioFsStore
 
suggestUseCompoundFile() - Method in class org.elasticsearch.index.store.fs.SimpleFsStore
 
suggestUseCompoundFile() - Method in class org.elasticsearch.index.store.memory.ByteBufferStore
Its better to not use the compound format when using the Ram store.
suggestUseCompoundFile() - Method in class org.elasticsearch.index.store.memory.HeapStore
Its better to not use the compound format when using the Ram store.
suggestUseCompoundFile() - Method in class org.elasticsearch.index.store.ram.RamStore
Its better to not use the compound format when using the Ram store.
suggestUseCompoundFile() - Method in interface org.elasticsearch.index.store.Store
The store can suggest the best setting for compound file the MergePolicy will use.
suggestUseCompoundFile() - Method in class org.elasticsearch.index.store.support.AbstractStore
Returns true by default.
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
 
SUN_OS - Static variable in class org.elasticsearch.util.OsUtils
True iff running on SunOS.
supertypeOf(Type) - Static method in class org.elasticsearch.util.inject.util.Types
Returns a type that represents an unknown supertype of bound.
Supplier<T> - Interface in org.elasticsearch.util.base
A class that can supply objects of a single type.
Suppliers - Class in org.elasticsearch.util.base
Useful suppliers.
suspendEncoding() - Method in class org.elasticsearch.util.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
 
SwitchDirectory - Class in org.elasticsearch.util.lucene.store
A Directory instance that switches files between two other Directory instances.
SwitchDirectory(Set<String>, Directory, Directory, boolean) - Constructor for class org.elasticsearch.util.lucene.store.SwitchDirectory
 
sync(Directory, String) - Static method in class org.elasticsearch.util.lucene.Directories
 
sync(String) - Method in class org.elasticsearch.util.lucene.store.SwitchDirectory
 
syncFile(File) - Static method in class org.elasticsearch.util.io.FileSystemUtils
 
synchronizedBiMap(BiMap<K, V>) - Static method in class org.elasticsearch.util.collect.Maps
Returns a synchronized (thread-safe) bimap backed by the specified bimap.
synchronizedListMultimap(ListMultimap<K, V>) - Static method in class org.elasticsearch.util.collect.Multimaps
Returns a synchronized (thread-safe) ListMultimap backed by the specified multimap.
synchronizedMultimap(Multimap<K, V>) - Static method in class org.elasticsearch.util.collect.Multimaps
Returns a synchronized (thread-safe) multimap backed by the specified multimap.
synchronizedSetMultimap(SetMultimap<K, V>) - Static method in class org.elasticsearch.util.collect.Multimaps
Returns a synchronized (thread-safe) SetMultimap backed by the specified multimap.
synchronizedSortedSetMultimap(SortedSetMultimap<K, V>) - Static method in class org.elasticsearch.util.collect.Multimaps
Returns a synchronized (thread-safe) SortedSetMultimap backed by the specified multimap.
synchronizedSupplier(Supplier<T>) - Static method in class org.elasticsearch.util.base.Suppliers
Returns a supplier whose get() method synchronizes on delegate before calling it, making it thread-safe.
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.util.logging.log4j.ConsoleAppender
 
SYSTEM_OUT - Static variable in class org.elasticsearch.util.logging.log4j.ConsoleAppender
 
systemProperties() - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 

T

tagsSchema(String) - Method in class org.elasticsearch.search.builder.SearchSourceHighlightBuilder
Set a tag scheme that encapsulates a built in pre and post tags.
tailMap(K) - Method in class org.elasticsearch.util.collect.ForwardingSortedMap
 
tailMap(K) - Method in class org.elasticsearch.util.collect.ImmutableSortedMap
This method returns a ImmutableSortedMap, consisting of the entries whose keys are greater than or equals to fromKey.
tailSet(E) - Method in class org.elasticsearch.util.collect.ForwardingSortedSet
 
tailSet(E) - Method in class org.elasticsearch.util.collect.ImmutableSortedSet
take() - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
 
target() - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
 
target - Variable in class org.elasticsearch.util.logging.log4j.ConsoleAppender
 
taskCount() - Method in class org.elasticsearch.util.StopWatch
Return the number of tasks timed.
taskInfo() - Method in class org.elasticsearch.util.StopWatch
Return an array of the data for tasks performed.
TByteArrayList - Class in org.elasticsearch.util.gnu.trove
A resizable, array-backed list of byte primitives.
TByteArrayList() - Constructor for class org.elasticsearch.util.gnu.trove.TByteArrayList
Creates a new TByteArrayList instance with the default capacity.
TByteArrayList(int) - Constructor for class org.elasticsearch.util.gnu.trove.TByteArrayList
Creates a new TByteArrayList instance with the specified capacity.
TByteArrayList(byte[]) - Constructor for class org.elasticsearch.util.gnu.trove.TByteArrayList
Creates a new TByteArrayList instance whose capacity is the greater of the length of values and DEFAULT_CAPACITY and whose initial contents are the specified values.
TByteByteHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for byte keys and byte values.
TByteByteHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Creates a new TByteByteHashMap instance with the default capacity and load factor.
TByteByteHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Creates a new TByteByteHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TByteByteHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Creates a new TByteByteHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TByteByteHashMap(TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Creates a new TByteByteHashMap instance with the default capacity and load factor.
TByteByteHashMap(int, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Creates a new TByteByteHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TByteByteHashMap(int, float, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Creates a new TByteByteHashMap instance with a prime value at or near the specified capacity and load factor.
TByteByteHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TByteByteHashMap conform to the java.util.Map API.
TByteByteHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TByteByteHashMapDecorator(TByteByteHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TByteByteIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type byte and byte.
TByteByteIterator(TByteByteHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TByteByteIterator
Creates an iterator over the specified map
TByteByteProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type byte and byte.
TByteDoubleHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for byte keys and double values.
TByteDoubleHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Creates a new TByteDoubleHashMap instance with the default capacity and load factor.
TByteDoubleHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Creates a new TByteDoubleHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TByteDoubleHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Creates a new TByteDoubleHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TByteDoubleHashMap(TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Creates a new TByteDoubleHashMap instance with the default capacity and load factor.
TByteDoubleHashMap(int, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Creates a new TByteDoubleHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TByteDoubleHashMap(int, float, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Creates a new TByteDoubleHashMap instance with a prime value at or near the specified capacity and load factor.
TByteDoubleHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TByteDoubleHashMap conform to the java.util.Map API.
TByteDoubleHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TByteDoubleHashMapDecorator(TByteDoubleHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TByteDoubleIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type byte and double.
TByteDoubleIterator(TByteDoubleHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TByteDoubleIterator
Creates an iterator over the specified map
TByteDoubleProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type byte and double.
TByteFloatHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for byte keys and float values.
TByteFloatHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Creates a new TByteFloatHashMap instance with the default capacity and load factor.
TByteFloatHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Creates a new TByteFloatHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TByteFloatHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Creates a new TByteFloatHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TByteFloatHashMap(TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Creates a new TByteFloatHashMap instance with the default capacity and load factor.
TByteFloatHashMap(int, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Creates a new TByteFloatHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TByteFloatHashMap(int, float, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Creates a new TByteFloatHashMap instance with a prime value at or near the specified capacity and load factor.
TByteFloatHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TByteFloatHashMap conform to the java.util.Map API.
TByteFloatHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TByteFloatHashMapDecorator(TByteFloatHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TByteFloatIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type byte and float.
TByteFloatIterator(TByteFloatHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TByteFloatIterator
Creates an iterator over the specified map
TByteFloatProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type byte and float.
TByteFunction - Interface in org.elasticsearch.util.gnu.trove
Interface for functions that accept and return one byte primitive.
TByteHash - Class in org.elasticsearch.util.gnu.trove
An open addressed hashing implementation for byte primitives.
TByteHash() - Constructor for class org.elasticsearch.util.gnu.trove.TByteHash
Creates a new TByteHash instance with the default capacity and load factor.
TByteHash(int) - Constructor for class org.elasticsearch.util.gnu.trove.TByteHash
Creates a new TByteHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TByteHash(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TByteHash
Creates a new TByteHash instance with a prime value at or near the specified capacity and load factor.
TByteHash(TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteHash
Creates a new TByteHash instance with the default capacity and load factor.
TByteHash(int, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteHash
Creates a new TByteHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TByteHash(int, float, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteHash
Creates a new TByteHash instance with a prime value at or near the specified capacity and load factor.
TByteHashingStrategy - Interface in org.elasticsearch.util.gnu.trove
Interface to support pluggable hashing strategies in maps and sets.
TByteHashSet - Class in org.elasticsearch.util.gnu.trove
An open addressed set implementation for byte primitives.
TByteHashSet() - Constructor for class org.elasticsearch.util.gnu.trove.TByteHashSet
Creates a new TByteHashSet instance with the default capacity and load factor.
TByteHashSet(int) - Constructor for class org.elasticsearch.util.gnu.trove.TByteHashSet
Creates a new TByteHashSet instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TByteHashSet(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TByteHashSet
Creates a new TByteHashSet instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TByteHashSet(byte[]) - Constructor for class org.elasticsearch.util.gnu.trove.TByteHashSet
Creates a new TByteHashSet instance containing the elements of array.
TByteHashSet(TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteHashSet
Creates a new TByteHash instance with the default capacity and load factor.
TByteHashSet(int, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteHashSet
Creates a new TByteHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TByteHashSet(int, float, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteHashSet
Creates a new TByteHash instance with a prime value at or near the specified capacity and load factor.
TByteHashSet(byte[], TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteHashSet
Creates a new TByteHashSet instance containing the elements of array.
TByteHashSetDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TByteHashSet conform to the java.util.Set API.
TByteHashSetDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TByteHashSetDecorator
FOR EXTERNALIZATION ONLY!!
TByteHashSetDecorator(TByteHashSet) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TByteHashSetDecorator
Creates a wrapper that decorates the specified primitive set.
TByteIntHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for byte keys and int values.
TByteIntHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Creates a new TByteIntHashMap instance with the default capacity and load factor.
TByteIntHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Creates a new TByteIntHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TByteIntHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Creates a new TByteIntHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TByteIntHashMap(TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Creates a new TByteIntHashMap instance with the default capacity and load factor.
TByteIntHashMap(int, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Creates a new TByteIntHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TByteIntHashMap(int, float, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Creates a new TByteIntHashMap instance with a prime value at or near the specified capacity and load factor.
TByteIntHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TByteIntHashMap conform to the java.util.Map API.
TByteIntHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TByteIntHashMapDecorator(TByteIntHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TByteIntIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type byte and int.
TByteIntIterator(TByteIntHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TByteIntIterator
Creates an iterator over the specified map
TByteIntProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type byte and int.
TByteIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for byte collections.
TByteIterator(TByteHash) - Constructor for class org.elasticsearch.util.gnu.trove.TByteIterator
Creates a TByteIterator for the elements in the specified collection.
TByteLongHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for byte keys and long values.
TByteLongHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Creates a new TByteLongHashMap instance with the default capacity and load factor.
TByteLongHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Creates a new TByteLongHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TByteLongHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Creates a new TByteLongHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TByteLongHashMap(TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Creates a new TByteLongHashMap instance with the default capacity and load factor.
TByteLongHashMap(int, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Creates a new TByteLongHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TByteLongHashMap(int, float, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Creates a new TByteLongHashMap instance with a prime value at or near the specified capacity and load factor.
TByteLongHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TByteLongHashMap conform to the java.util.Map API.
TByteLongHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TByteLongHashMapDecorator(TByteLongHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TByteLongIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type byte and long.
TByteLongIterator(TByteLongHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TByteLongIterator
Creates an iterator over the specified map
TByteLongProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type byte and long.
TByteObjectHashMap<V> - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for byte keys and Object values.
TByteObjectHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Creates a new TByteObjectHashMap instance with the default capacity and load factor.
TByteObjectHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Creates a new TByteObjectHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TByteObjectHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Creates a new TByteObjectHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TByteObjectHashMap(TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Creates a new TByteObjectHashMap instance with the default capacity and load factor.
TByteObjectHashMap(int, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Creates a new TByteObjectHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TByteObjectHashMap(int, float, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Creates a new TByteObjectHashMap instance with a prime value at or near the specified capacity and load factor.
TByteObjectHashMapDecorator<V> - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TByteObjectHashMap conform to the java.util.Map API.
TByteObjectHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TByteObjectHashMapDecorator(TByteObjectHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TByteObjectIterator<V> - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type byte and Object.
TByteObjectIterator(TByteObjectHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.TByteObjectIterator
Creates an iterator over the specified map
TByteObjectProcedure<T> - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type byte and Object.
TByteProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures with one byte parameter.
TByteShortHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for byte keys and short values.
TByteShortHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Creates a new TByteShortHashMap instance with the default capacity and load factor.
TByteShortHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Creates a new TByteShortHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TByteShortHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Creates a new TByteShortHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TByteShortHashMap(TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Creates a new TByteShortHashMap instance with the default capacity and load factor.
TByteShortHashMap(int, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Creates a new TByteShortHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TByteShortHashMap(int, float, TByteHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Creates a new TByteShortHashMap instance with a prime value at or near the specified capacity and load factor.
TByteShortHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TByteShortHashMap conform to the java.util.Map API.
TByteShortHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TByteShortHashMapDecorator(TByteShortHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TByteShortIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type byte and short.
TByteShortIterator(TByteShortHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TByteShortIterator
Creates an iterator over the specified map
TByteShortProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type byte and short.
TByteStack - Class in org.elasticsearch.util.gnu.trove
A stack of byte primitives, backed by a TByteArrayList.
TByteStack() - Constructor for class org.elasticsearch.util.gnu.trove.TByteStack
Creates a new TByteStack instance with the default capacity.
TByteStack(int) - Constructor for class org.elasticsearch.util.gnu.trove.TByteStack
Creates a new TByteStack instance with the specified capacity.
tcp() - Method in class org.elasticsearch.monitor.network.NetworkStats
 
TCP_KEEP_ALIVE - Static variable in class org.elasticsearch.util.network.NetworkService.TcpSettings
 
TCP_NO_DELAY - Static variable in class org.elasticsearch.util.network.NetworkService.TcpSettings
 
TCP_RECEIVE_BUFFER_SIZE - Static variable in class org.elasticsearch.util.network.NetworkService.TcpSettings
 
TCP_REUSE_ADDRESS - Static variable in class org.elasticsearch.util.network.NetworkService.TcpSettings
 
TCP_SEND_BUFFER_SIZE - Static variable in class org.elasticsearch.util.network.NetworkService.TcpSettings
 
TDoubleArrayList - Class in org.elasticsearch.util.gnu.trove
A resizable, array-backed list of double primitives.
TDoubleArrayList() - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Creates a new TDoubleArrayList instance with the default capacity.
TDoubleArrayList(int) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Creates a new TDoubleArrayList instance with the specified capacity.
TDoubleArrayList(double[]) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Creates a new TDoubleArrayList instance whose capacity is the greater of the length of values and DEFAULT_CAPACITY and whose initial contents are the specified values.
TDoubleByteHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for double keys and byte values.
TDoubleByteHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Creates a new TDoubleByteHashMap instance with the default capacity and load factor.
TDoubleByteHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Creates a new TDoubleByteHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TDoubleByteHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Creates a new TDoubleByteHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TDoubleByteHashMap(TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Creates a new TDoubleByteHashMap instance with the default capacity and load factor.
TDoubleByteHashMap(int, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Creates a new TDoubleByteHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TDoubleByteHashMap(int, float, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Creates a new TDoubleByteHashMap instance with a prime value at or near the specified capacity and load factor.
TDoubleByteHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TDoubleByteHashMap conform to the java.util.Map API.
TDoubleByteHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TDoubleByteHashMapDecorator(TDoubleByteHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TDoubleByteIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type double and byte.
TDoubleByteIterator(TDoubleByteHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleByteIterator
Creates an iterator over the specified map
TDoubleByteProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type double and byte.
TDoubleDoubleHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for double keys and double values.
TDoubleDoubleHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Creates a new TDoubleDoubleHashMap instance with the default capacity and load factor.
TDoubleDoubleHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Creates a new TDoubleDoubleHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TDoubleDoubleHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Creates a new TDoubleDoubleHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TDoubleDoubleHashMap(TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Creates a new TDoubleDoubleHashMap instance with the default capacity and load factor.
TDoubleDoubleHashMap(int, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Creates a new TDoubleDoubleHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TDoubleDoubleHashMap(int, float, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Creates a new TDoubleDoubleHashMap instance with a prime value at or near the specified capacity and load factor.
TDoubleDoubleHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TDoubleDoubleHashMap conform to the java.util.Map API.
TDoubleDoubleHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TDoubleDoubleHashMapDecorator(TDoubleDoubleHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TDoubleDoubleIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type double and double.
TDoubleDoubleIterator(TDoubleDoubleHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleDoubleIterator
Creates an iterator over the specified map
TDoubleDoubleProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type double and double.
TDoubleFloatHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for double keys and float values.
TDoubleFloatHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Creates a new TDoubleFloatHashMap instance with the default capacity and load factor.
TDoubleFloatHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Creates a new TDoubleFloatHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TDoubleFloatHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Creates a new TDoubleFloatHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TDoubleFloatHashMap(TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Creates a new TDoubleFloatHashMap instance with the default capacity and load factor.
TDoubleFloatHashMap(int, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Creates a new TDoubleFloatHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TDoubleFloatHashMap(int, float, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Creates a new TDoubleFloatHashMap instance with a prime value at or near the specified capacity and load factor.
TDoubleFloatHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TDoubleFloatHashMap conform to the java.util.Map API.
TDoubleFloatHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TDoubleFloatHashMapDecorator(TDoubleFloatHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TDoubleFloatIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type double and float.
TDoubleFloatIterator(TDoubleFloatHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleFloatIterator
Creates an iterator over the specified map
TDoubleFloatProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type double and float.
TDoubleFunction - Interface in org.elasticsearch.util.gnu.trove
Interface for functions that accept and return one double primitive.
TDoubleHash - Class in org.elasticsearch.util.gnu.trove
An open addressed hashing implementation for double primitives.
TDoubleHash() - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleHash
Creates a new TDoubleHash instance with the default capacity and load factor.
TDoubleHash(int) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleHash
Creates a new TDoubleHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TDoubleHash(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleHash
Creates a new TDoubleHash instance with a prime value at or near the specified capacity and load factor.
TDoubleHash(TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleHash
Creates a new TDoubleHash instance with the default capacity and load factor.
TDoubleHash(int, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleHash
Creates a new TDoubleHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TDoubleHash(int, float, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleHash
Creates a new TDoubleHash instance with a prime value at or near the specified capacity and load factor.
TDoubleHashingStrategy - Interface in org.elasticsearch.util.gnu.trove
Interface to support pluggable hashing strategies in maps and sets.
TDoubleHashSet - Class in org.elasticsearch.util.gnu.trove
An open addressed set implementation for double primitives.
TDoubleHashSet() - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Creates a new TDoubleHashSet instance with the default capacity and load factor.
TDoubleHashSet(int) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Creates a new TDoubleHashSet instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TDoubleHashSet(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Creates a new TDoubleHashSet instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TDoubleHashSet(double[]) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Creates a new TDoubleHashSet instance containing the elements of array.
TDoubleHashSet(TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Creates a new TDoubleHash instance with the default capacity and load factor.
TDoubleHashSet(int, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Creates a new TDoubleHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TDoubleHashSet(int, float, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Creates a new TDoubleHash instance with a prime value at or near the specified capacity and load factor.
TDoubleHashSet(double[], TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Creates a new TDoubleHashSet instance containing the elements of array.
TDoubleHashSetDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TDoubleHashSet conform to the java.util.Set API.
TDoubleHashSetDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TDoubleHashSetDecorator
FOR EXTERNALIZATION ONLY!!
TDoubleHashSetDecorator(TDoubleHashSet) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TDoubleHashSetDecorator
Creates a wrapper that decorates the specified primitive set.
TDoubleIntHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for double keys and int values.
TDoubleIntHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Creates a new TDoubleIntHashMap instance with the default capacity and load factor.
TDoubleIntHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Creates a new TDoubleIntHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TDoubleIntHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Creates a new TDoubleIntHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TDoubleIntHashMap(TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Creates a new TDoubleIntHashMap instance with the default capacity and load factor.
TDoubleIntHashMap(int, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Creates a new TDoubleIntHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TDoubleIntHashMap(int, float, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Creates a new TDoubleIntHashMap instance with a prime value at or near the specified capacity and load factor.
TDoubleIntHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TDoubleIntHashMap conform to the java.util.Map API.
TDoubleIntHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TDoubleIntHashMapDecorator(TDoubleIntHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TDoubleIntIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type double and int.
TDoubleIntIterator(TDoubleIntHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleIntIterator
Creates an iterator over the specified map
TDoubleIntProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type double and int.
TDoubleIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for double collections.
TDoubleIterator(TDoubleHash) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleIterator
Creates a TDoubleIterator for the elements in the specified collection.
TDoubleLongHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for double keys and long values.
TDoubleLongHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Creates a new TDoubleLongHashMap instance with the default capacity and load factor.
TDoubleLongHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Creates a new TDoubleLongHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TDoubleLongHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Creates a new TDoubleLongHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TDoubleLongHashMap(TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Creates a new TDoubleLongHashMap instance with the default capacity and load factor.
TDoubleLongHashMap(int, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Creates a new TDoubleLongHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TDoubleLongHashMap(int, float, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Creates a new TDoubleLongHashMap instance with a prime value at or near the specified capacity and load factor.
TDoubleLongHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TDoubleLongHashMap conform to the java.util.Map API.
TDoubleLongHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TDoubleLongHashMapDecorator(TDoubleLongHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TDoubleLongIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type double and long.
TDoubleLongIterator(TDoubleLongHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleLongIterator
Creates an iterator over the specified map
TDoubleLongProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type double and long.
TDoubleObjectHashMap<V> - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for double keys and Object values.
TDoubleObjectHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Creates a new TDoubleObjectHashMap instance with the default capacity and load factor.
TDoubleObjectHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Creates a new TDoubleObjectHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TDoubleObjectHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Creates a new TDoubleObjectHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TDoubleObjectHashMap(TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Creates a new TDoubleObjectHashMap instance with the default capacity and load factor.
TDoubleObjectHashMap(int, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Creates a new TDoubleObjectHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TDoubleObjectHashMap(int, float, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Creates a new TDoubleObjectHashMap instance with a prime value at or near the specified capacity and load factor.
TDoubleObjectHashMapDecorator<V> - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TDoubleObjectHashMap conform to the java.util.Map API.
TDoubleObjectHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TDoubleObjectHashMapDecorator(TDoubleObjectHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TDoubleObjectIterator<V> - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type double and Object.
TDoubleObjectIterator(TDoubleObjectHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleObjectIterator
Creates an iterator over the specified map
TDoubleObjectProcedure<T> - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type double and Object.
TDoubleProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures with one double parameter.
TDoubleShortHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for double keys and short values.
TDoubleShortHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Creates a new TDoubleShortHashMap instance with the default capacity and load factor.
TDoubleShortHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Creates a new TDoubleShortHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TDoubleShortHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Creates a new TDoubleShortHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TDoubleShortHashMap(TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Creates a new TDoubleShortHashMap instance with the default capacity and load factor.
TDoubleShortHashMap(int, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Creates a new TDoubleShortHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TDoubleShortHashMap(int, float, TDoubleHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Creates a new TDoubleShortHashMap instance with a prime value at or near the specified capacity and load factor.
TDoubleShortHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TDoubleShortHashMap conform to the java.util.Map API.
TDoubleShortHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TDoubleShortHashMapDecorator(TDoubleShortHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TDoubleShortIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type double and short.
TDoubleShortIterator(TDoubleShortHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleShortIterator
Creates an iterator over the specified map
TDoubleShortProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type double and short.
TDoubleStack - Class in org.elasticsearch.util.gnu.trove
A stack of double primitives, backed by a TDoubleArrayList.
TDoubleStack() - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleStack
Creates a new TDoubleStack instance with the default capacity.
TDoubleStack(int) - Constructor for class org.elasticsearch.util.gnu.trove.TDoubleStack
Creates a new TDoubleStack instance with the specified capacity.
tempDisableAutoCompaction() - Method in class org.elasticsearch.util.gnu.trove.THash
Temporarily disables auto-compaction.
term() - Method in class org.elasticsearch.action.terms.TermFreq
The term.
term(String) - Method in interface org.elasticsearch.index.mapper.TypeFieldMapper
 
term(String, String) - Method in interface org.elasticsearch.index.mapper.UidFieldMapper
 
term(String) - Method in interface org.elasticsearch.index.mapper.UidFieldMapper
 
term(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper
 
term(String, String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper
 
term(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper
 
TERM_VECTOR - Static variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Defaults
 
termAsString() - Method in class org.elasticsearch.action.terms.TermFreq
 
termComparator() - Static method in class org.elasticsearch.action.terms.TermFreq
Lexical based comparator.
termDocs() - Method in class org.elasticsearch.util.lucene.versioned.VersionedIndexReader
 
termDocs(Term) - Method in class org.elasticsearch.util.lucene.versioned.VersionedIndexReader
 
termFilter(String, String) - Static method in class org.elasticsearch.index.query.xcontent.FilterBuilders
A filter for a field based on a term.
termFilter(String, int) - Static method in class org.elasticsearch.index.query.xcontent.FilterBuilders
A filter for a field based on a term.
termFilter(String, long) - Static method in class org.elasticsearch.index.query.xcontent.FilterBuilders
A filter for a field based on a term.
termFilter(String, float) - Static method in class org.elasticsearch.index.query.xcontent.FilterBuilders
A filter for a field based on a term.
termFilter(String, double) - Static method in class org.elasticsearch.index.query.xcontent.FilterBuilders
A filter for a field based on a term.
termFilter(String, Object) - Static method in class org.elasticsearch.index.query.xcontent.FilterBuilders
A filter for a field based on a term.
TermFilter - Class in org.elasticsearch.util.lucene.search
A simple filter for a specific term.
TermFilter(Term) - Constructor for class org.elasticsearch.util.lucene.search.TermFilter
 
TermFilterBuilder - Class in org.elasticsearch.index.query.xcontent
A filter for a field based on a term.
TermFilterBuilder(String, String) - Constructor for class org.elasticsearch.index.query.xcontent.TermFilterBuilder
A filter for a field based on a term.
TermFilterBuilder(String, int) - Constructor for class org.elasticsearch.index.query.xcontent.TermFilterBuilder
A filter for a field based on a term.
TermFilterBuilder(String, long) - Constructor for class org.elasticsearch.index.query.xcontent.TermFilterBuilder
A filter for a field based on a term.
TermFilterBuilder(String, float) - Constructor for class org.elasticsearch.index.query.xcontent.TermFilterBuilder
A filter for a field based on a term.
TermFilterBuilder(String, double) - Constructor for class org.elasticsearch.index.query.xcontent.TermFilterBuilder
A filter for a field based on a term.
TermFilterBuilder(String, Object) - Constructor for class org.elasticsearch.index.query.xcontent.TermFilterBuilder
A filter for a field based on a term.
TermFilterParser - Class in org.elasticsearch.index.query.xcontent
 
TermFilterParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.TermFilterParser
 
TermFreq - Class in org.elasticsearch.action.terms
A tuple of term and its document frequency (in how many documents this term exists).
termPositions() - Method in class org.elasticsearch.util.lucene.versioned.VersionedIndexReader
 
termPositions(Term) - Method in class org.elasticsearch.util.lucene.versioned.VersionedIndexReader
 
termQuery(String, String) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A Query that matches documents containing a term.
termQuery(String, int) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A Query that matches documents containing a term.
termQuery(String, long) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A Query that matches documents containing a term.
termQuery(String, float) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A Query that matches documents containing a term.
termQuery(String, double) - Static method in class org.elasticsearch.index.query.xcontent.QueryBuilders
A Query that matches documents containing a term.
TermQueryBuilder - Class in org.elasticsearch.index.query.xcontent
A Query that matches documents containing a term.
TermQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.xcontent.TermQueryBuilder
Constructs a new term query.
TermQueryBuilder(String, int) - Constructor for class org.elasticsearch.index.query.xcontent.TermQueryBuilder
Constructs a new term query.
TermQueryBuilder(String, long) - Constructor for class org.elasticsearch.index.query.xcontent.TermQueryBuilder
Constructs a new term query.
TermQueryBuilder(String, float) - Constructor for class org.elasticsearch.index.query.xcontent.TermQueryBuilder
Constructs a new term query.
TermQueryBuilder(String, double) - Constructor for class org.elasticsearch.index.query.xcontent.TermQueryBuilder
Constructs a new term query.
TermQueryParser - Class in org.elasticsearch.index.query.xcontent
 
TermQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.TermQueryParser
 
TERMS - Static variable in class org.elasticsearch.action.TransportActions
 
terms(TermsRequest) - Method in interface org.elasticsearch.client.Client
A terms request to get terms in one or more indices of specific fields and their document frequencies (in how many document each term exists).
terms(TermsRequest, ActionListener<TermsResponse>) - Method in interface org.elasticsearch.client.Client
A terms request to get terms in one or more indices of specific fields and their document frequencies (in how many document each term exists).
terms(TermsRequest) - Method in class org.elasticsearch.client.node.NodeClient
 
terms(TermsRequest, ActionListener<TermsResponse>) - Method in class org.elasticsearch.client.node.NodeClient
 
terms(TermsRequest) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
terms(TermsRequest, ActionListener<TermsResponse>) - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
terms(TermsRequest) - Method in class org.elasticsearch.client.transport.TransportClient
 
terms(TermsRequest, ActionListener<TermsResponse>) - Method in class org.elasticsearch.client.transport.TransportClient
 
terms() - Method in class org.elasticsearch.search.dfs.DfsSearchResult
 
termsAndFreqs(Term[], int[]) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
 
termsFilter(String, String...) - Static method in class org.elasticsearch.index.query.xcontent.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.xcontent.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.xcontent.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.xcontent.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.xcontent.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.xcontent.FilterBuilders
A filer for a field based on several terms matching on any of them.
TermsFilterBuilder - Class in org.elasticsearch.index.query.xcontent
A filer for a field based on several terms matching on any of them.
TermsFilterBuilder(String, String...) - Constructor for class org.elasticsearch.index.query.xcontent.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.xcontent.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.xcontent.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.xcontent.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.xcontent.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.xcontent.TermsFilterBuilder
A filer for a field based on several terms matching on any of them.
TermsFilterParser - Class in org.elasticsearch.index.query.xcontent
 
TermsFilterParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.TermsFilterParser
 
termsFreqs() - Method in class org.elasticsearch.action.terms.FieldTermsFreq
The term frequencies of the field.
TermsRequest - Class in org.elasticsearch.action.terms
Terms request represent a request to get terms in one or more indices of specific fields and their document frequencies (in how many document each term exists).
TermsRequest(String...) - Constructor for class org.elasticsearch.action.terms.TermsRequest
Constructs a new terms requests with the provided indices.
termsRequest(String...) - Static method in class org.elasticsearch.client.Requests
Terms request represent a request to get terms in one or more indices of specific fields and their document frequencies (in how many document each term exists).
TermsRequest.SortType - Enum in org.elasticsearch.action.terms
The type of sorting for terms.
TermsResponse - Class in org.elasticsearch.action.terms
The response of terms request.
termVector() - Method in interface org.elasticsearch.index.mapper.FieldMapper
 
termVector(Field.TermVector) - Method in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper.Builder
 
termVector(Field.TermVector) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper.Builder
 
termVector - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
termVector(Field.TermVector) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
termVector(Field.TermVector) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.OpenBuilder
 
termVector - Variable in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
termVector() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
test(String) - Static method in class org.elasticsearch.util.jline.ANSI.Renderer
 
text() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
text() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
text() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
textCharacters() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
textCharacters() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
textCharacters() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
textLength() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
textLength() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
textLength() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
textOffset() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentParser
 
textOffset() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
textOffset() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 
textOrNull() - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentParser
 
textOrNull() - Method in interface org.elasticsearch.util.xcontent.XContentParser
 
TextXContentBuilder - Class in org.elasticsearch.util.xcontent.builder
 
TextXContentBuilder(XContent) - Constructor for class org.elasticsearch.util.xcontent.builder.TextXContentBuilder
 
TFloatArrayList - Class in org.elasticsearch.util.gnu.trove
A resizable, array-backed list of float primitives.
TFloatArrayList() - Constructor for class org.elasticsearch.util.gnu.trove.TFloatArrayList
Creates a new TFloatArrayList instance with the default capacity.
TFloatArrayList(int) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatArrayList
Creates a new TFloatArrayList instance with the specified capacity.
TFloatArrayList(float[]) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatArrayList
Creates a new TFloatArrayList instance whose capacity is the greater of the length of values and DEFAULT_CAPACITY and whose initial contents are the specified values.
TFloatByteHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for float keys and byte values.
TFloatByteHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Creates a new TFloatByteHashMap instance with the default capacity and load factor.
TFloatByteHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Creates a new TFloatByteHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TFloatByteHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Creates a new TFloatByteHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TFloatByteHashMap(TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Creates a new TFloatByteHashMap instance with the default capacity and load factor.
TFloatByteHashMap(int, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Creates a new TFloatByteHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TFloatByteHashMap(int, float, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Creates a new TFloatByteHashMap instance with a prime value at or near the specified capacity and load factor.
TFloatByteHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TFloatByteHashMap conform to the java.util.Map API.
TFloatByteHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TFloatByteHashMapDecorator(TFloatByteHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TFloatByteIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type float and byte.
TFloatByteIterator(TFloatByteHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatByteIterator
Creates an iterator over the specified map
TFloatByteProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type float and byte.
TFloatDoubleHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for float keys and double values.
TFloatDoubleHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Creates a new TFloatDoubleHashMap instance with the default capacity and load factor.
TFloatDoubleHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Creates a new TFloatDoubleHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TFloatDoubleHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Creates a new TFloatDoubleHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TFloatDoubleHashMap(TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Creates a new TFloatDoubleHashMap instance with the default capacity and load factor.
TFloatDoubleHashMap(int, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Creates a new TFloatDoubleHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TFloatDoubleHashMap(int, float, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Creates a new TFloatDoubleHashMap instance with a prime value at or near the specified capacity and load factor.
TFloatDoubleHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TFloatDoubleHashMap conform to the java.util.Map API.
TFloatDoubleHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TFloatDoubleHashMapDecorator(TFloatDoubleHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TFloatDoubleIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type float and double.
TFloatDoubleIterator(TFloatDoubleHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatDoubleIterator
Creates an iterator over the specified map
TFloatDoubleProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type float and double.
TFloatFloatHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for float keys and float values.
TFloatFloatHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Creates a new TFloatFloatHashMap instance with the default capacity and load factor.
TFloatFloatHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Creates a new TFloatFloatHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TFloatFloatHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Creates a new TFloatFloatHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TFloatFloatHashMap(TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Creates a new TFloatFloatHashMap instance with the default capacity and load factor.
TFloatFloatHashMap(int, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Creates a new TFloatFloatHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TFloatFloatHashMap(int, float, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Creates a new TFloatFloatHashMap instance with a prime value at or near the specified capacity and load factor.
TFloatFloatHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TFloatFloatHashMap conform to the java.util.Map API.
TFloatFloatHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TFloatFloatHashMapDecorator(TFloatFloatHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TFloatFloatIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type float and float.
TFloatFloatIterator(TFloatFloatHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatFloatIterator
Creates an iterator over the specified map
TFloatFloatProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type float and float.
TFloatFunction - Interface in org.elasticsearch.util.gnu.trove
Interface for functions that accept and return one float primitive.
TFloatHash - Class in org.elasticsearch.util.gnu.trove
An open addressed hashing implementation for float primitives.
TFloatHash() - Constructor for class org.elasticsearch.util.gnu.trove.TFloatHash
Creates a new TFloatHash instance with the default capacity and load factor.
TFloatHash(int) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatHash
Creates a new TFloatHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TFloatHash(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatHash
Creates a new TFloatHash instance with a prime value at or near the specified capacity and load factor.
TFloatHash(TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatHash
Creates a new TFloatHash instance with the default capacity and load factor.
TFloatHash(int, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatHash
Creates a new TFloatHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TFloatHash(int, float, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatHash
Creates a new TFloatHash instance with a prime value at or near the specified capacity and load factor.
TFloatHashingStrategy - Interface in org.elasticsearch.util.gnu.trove
Interface to support pluggable hashing strategies in maps and sets.
TFloatHashSet - Class in org.elasticsearch.util.gnu.trove
An open addressed set implementation for float primitives.
TFloatHashSet() - Constructor for class org.elasticsearch.util.gnu.trove.TFloatHashSet
Creates a new TFloatHashSet instance with the default capacity and load factor.
TFloatHashSet(int) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatHashSet
Creates a new TFloatHashSet instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TFloatHashSet(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatHashSet
Creates a new TFloatHashSet instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TFloatHashSet(float[]) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatHashSet
Creates a new TFloatHashSet instance containing the elements of array.
TFloatHashSet(TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatHashSet
Creates a new TFloatHash instance with the default capacity and load factor.
TFloatHashSet(int, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatHashSet
Creates a new TFloatHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TFloatHashSet(int, float, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatHashSet
Creates a new TFloatHash instance with a prime value at or near the specified capacity and load factor.
TFloatHashSet(float[], TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatHashSet
Creates a new TFloatHashSet instance containing the elements of array.
TFloatHashSetDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TFloatHashSet conform to the java.util.Set API.
TFloatHashSetDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TFloatHashSetDecorator
FOR EXTERNALIZATION ONLY!!
TFloatHashSetDecorator(TFloatHashSet) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TFloatHashSetDecorator
Creates a wrapper that decorates the specified primitive set.
TFloatIntHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for float keys and int values.
TFloatIntHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Creates a new TFloatIntHashMap instance with the default capacity and load factor.
TFloatIntHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Creates a new TFloatIntHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TFloatIntHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Creates a new TFloatIntHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TFloatIntHashMap(TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Creates a new TFloatIntHashMap instance with the default capacity and load factor.
TFloatIntHashMap(int, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Creates a new TFloatIntHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TFloatIntHashMap(int, float, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Creates a new TFloatIntHashMap instance with a prime value at or near the specified capacity and load factor.
TFloatIntHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TFloatIntHashMap conform to the java.util.Map API.
TFloatIntHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TFloatIntHashMapDecorator(TFloatIntHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TFloatIntIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type float and int.
TFloatIntIterator(TFloatIntHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatIntIterator
Creates an iterator over the specified map
TFloatIntProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type float and int.
TFloatIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for float collections.
TFloatIterator(TFloatHash) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatIterator
Creates a TFloatIterator for the elements in the specified collection.
TFloatLongHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for float keys and long values.
TFloatLongHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Creates a new TFloatLongHashMap instance with the default capacity and load factor.
TFloatLongHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Creates a new TFloatLongHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TFloatLongHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Creates a new TFloatLongHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TFloatLongHashMap(TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Creates a new TFloatLongHashMap instance with the default capacity and load factor.
TFloatLongHashMap(int, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Creates a new TFloatLongHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TFloatLongHashMap(int, float, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Creates a new TFloatLongHashMap instance with a prime value at or near the specified capacity and load factor.
TFloatLongHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TFloatLongHashMap conform to the java.util.Map API.
TFloatLongHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TFloatLongHashMapDecorator(TFloatLongHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TFloatLongIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type float and long.
TFloatLongIterator(TFloatLongHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatLongIterator
Creates an iterator over the specified map
TFloatLongProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type float and long.
TFloatObjectHashMap<V> - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for float keys and Object values.
TFloatObjectHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Creates a new TFloatObjectHashMap instance with the default capacity and load factor.
TFloatObjectHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Creates a new TFloatObjectHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TFloatObjectHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Creates a new TFloatObjectHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TFloatObjectHashMap(TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Creates a new TFloatObjectHashMap instance with the default capacity and load factor.
TFloatObjectHashMap(int, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Creates a new TFloatObjectHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TFloatObjectHashMap(int, float, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Creates a new TFloatObjectHashMap instance with a prime value at or near the specified capacity and load factor.
TFloatObjectHashMapDecorator<V> - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TFloatObjectHashMap conform to the java.util.Map API.
TFloatObjectHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TFloatObjectHashMapDecorator(TFloatObjectHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TFloatObjectIterator<V> - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type float and Object.
TFloatObjectIterator(TFloatObjectHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatObjectIterator
Creates an iterator over the specified map
TFloatObjectProcedure<T> - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type float and Object.
TFloatProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures with one float parameter.
TFloatShortHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for float keys and short values.
TFloatShortHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Creates a new TFloatShortHashMap instance with the default capacity and load factor.
TFloatShortHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Creates a new TFloatShortHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TFloatShortHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Creates a new TFloatShortHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TFloatShortHashMap(TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Creates a new TFloatShortHashMap instance with the default capacity and load factor.
TFloatShortHashMap(int, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Creates a new TFloatShortHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TFloatShortHashMap(int, float, TFloatHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Creates a new TFloatShortHashMap instance with a prime value at or near the specified capacity and load factor.
TFloatShortHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TFloatShortHashMap conform to the java.util.Map API.
TFloatShortHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TFloatShortHashMapDecorator(TFloatShortHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TFloatShortIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type float and short.
TFloatShortIterator(TFloatShortHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatShortIterator
Creates an iterator over the specified map
TFloatShortProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type float and short.
TFloatStack - Class in org.elasticsearch.util.gnu.trove
A stack of float primitives, backed by a TFloatArrayList.
TFloatStack() - Constructor for class org.elasticsearch.util.gnu.trove.TFloatStack
Creates a new TFloatStack instance with the default capacity.
TFloatStack(int) - Constructor for class org.elasticsearch.util.gnu.trove.TFloatStack
Creates a new TFloatStack instance with the specified capacity.
ThaiAnalyzerProvider - Class in org.elasticsearch.index.analysis
 
ThaiAnalyzerProvider(Index, Settings, String, Settings) - Constructor for class org.elasticsearch.index.analysis.ThaiAnalyzerProvider
 
THash - Class in org.elasticsearch.util.gnu.trove
Base class for hashtables that use open addressing to resolve collisions.
THash() - Constructor for class org.elasticsearch.util.gnu.trove.THash
Creates a new THash instance with the default capacity and load factor.
THash(int) - Constructor for class org.elasticsearch.util.gnu.trove.THash
Creates a new THash instance with a prime capacity at or near the specified capacity and with the default load factor.
THash(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.THash
Creates a new THash instance with a prime capacity at or near the minimum needed to hold initialCapacity elements with load factor loadFactor without triggering a rehash.
THashMap<K,V> - Class in org.elasticsearch.util.gnu.trove
An implementation of the Map interface which uses an open addressed hash table to store its contents.
THashMap() - Constructor for class org.elasticsearch.util.gnu.trove.THashMap
Creates a new THashMap instance with the default capacity and load factor.
THashMap(TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.THashMap
Creates a new THashMap instance with the default capacity and load factor.
THashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.THashMap
Creates a new THashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
THashMap(int, TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.THashMap
Creates a new THashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
THashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.THashMap
Creates a new THashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
THashMap(int, float, TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.THashMap
Creates a new THashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
THashMap(Map<K, V>) - Constructor for class org.elasticsearch.util.gnu.trove.THashMap
Creates a new THashMap instance which contains the key/value pairs in map.
THashMap(Map<K, V>, TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.THashMap
Creates a new THashMap instance which contains the key/value pairs in map.
THashMap.EntryView - Class in org.elasticsearch.util.gnu.trove
a view onto the entries of the map.
THashMap.EntryView() - Constructor for class org.elasticsearch.util.gnu.trove.THashMap.EntryView
 
THashMap.KeyView - Class in org.elasticsearch.util.gnu.trove
a view onto the keys of the map.
THashMap.KeyView() - Constructor for class org.elasticsearch.util.gnu.trove.THashMap.KeyView
 
THashMap.ValueView - Class in org.elasticsearch.util.gnu.trove
a view onto the values of the map.
THashMap.ValueView() - Constructor for class org.elasticsearch.util.gnu.trove.THashMap.ValueView
 
THashSet<E> - Class in org.elasticsearch.util.gnu.trove
An implementation of the Set interface that uses an open-addressed hash table to store its contents.
THashSet() - Constructor for class org.elasticsearch.util.gnu.trove.THashSet
Creates a new THashSet instance with the default capacity and load factor.
THashSet(TObjectHashingStrategy<E>) - Constructor for class org.elasticsearch.util.gnu.trove.THashSet
Creates a new THashSet instance with the default capacity and load factor.
THashSet(int) - Constructor for class org.elasticsearch.util.gnu.trove.THashSet
Creates a new THashSet instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
THashSet(int, TObjectHashingStrategy<E>) - Constructor for class org.elasticsearch.util.gnu.trove.THashSet
Creates a new THashSet instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
THashSet(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.THashSet
Creates a new THashSet instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
THashSet(int, float, TObjectHashingStrategy<E>) - Constructor for class org.elasticsearch.util.gnu.trove.THashSet
Creates a new THashSet instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
THashSet(Collection<? extends E>) - Constructor for class org.elasticsearch.util.gnu.trove.THashSet
Creates a new THashSet instance containing the elements of collection.
THashSet(Collection<? extends E>, TObjectHashingStrategy<E>) - Constructor for class org.elasticsearch.util.gnu.trove.THashSet
Creates a new THashSet instance containing the elements of collection.
THREAD_DUMP - Static variable in class org.elasticsearch.monitor.dump.thread.ThreadDumpContributor
 
ThreadBarrier - Class in org.elasticsearch.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.util.concurrent.ThreadBarrier
ThreadBarrier(int, Runnable) - Constructor for class org.elasticsearch.util.concurrent.ThreadBarrier
ThreadBarrier.BarrierTimer - Class in org.elasticsearch.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.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).
ThreadingModel - Enum in org.elasticsearch.action
 
ThreadLocalRandom - Class in org.elasticsearch.util.concurrent.jsr166y
A random number generator isolated to the current thread.
ThreadLocals - Class in org.elasticsearch.util
 
ThreadLocals() - Constructor for class org.elasticsearch.util.ThreadLocals
 
ThreadLocals.CleanableValue<T> - Class in org.elasticsearch.util
 
ThreadLocals.CleanableValue(T) - Constructor for class org.elasticsearch.util.ThreadLocals.CleanableValue
 
ThreadNameDeterminer - Interface in org.elasticsearch.util
Overrides the thread name proposed by ThreadRenamingRunnable.
threadPool() - Method in class org.elasticsearch.action.admin.cluster.node.info.NodeInfo
Thread Pool level information.
threadPool() - Method in class org.elasticsearch.action.admin.cluster.node.stats.NodeStats
Thread Pool level stats.
threadPool - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction
 
threadPool - Variable in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
threadPool - Variable in class org.elasticsearch.action.support.master.TransportMasterNodeOperationAction
 
threadPool - Variable in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
threadPool - Variable in class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
threadPool - Variable in class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
threadPool - Variable in class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction
 
threadPool - Variable in class org.elasticsearch.action.support.single.TransportSingleOperationAction
 
threadPool() - Method in interface org.elasticsearch.client.internal.InternalClient
 
threadPool() - Method in class org.elasticsearch.client.node.NodeClient
 
threadPool() - Method in class org.elasticsearch.client.transport.support.InternalTransportClient
 
threadPool() - Method in class org.elasticsearch.client.transport.TransportClient
 
ThreadPool - Interface in org.elasticsearch.threadpool
 
ThreadPoolInfo - Class in org.elasticsearch.threadpool
Thread Pool Info.
ThreadPoolInfo(String, int, int, int) - 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
Thread Pool level stats.
ThreadPoolStats(int, int, int, int) - Constructor for class org.elasticsearch.threadpool.ThreadPoolStats
 
ThreadRenamingRunnable - Class in org.elasticsearch.util
A Runnable that changes the current thread name and reverts it back when its execution ends.
ThreadRenamingRunnable(Runnable, String) - Constructor for class org.elasticsearch.util.ThreadRenamingRunnable
Creates a new instance which wraps the specified runnable and changes the thread name to the specified thread name when the specified runnable is running.
threads() - Method in class org.elasticsearch.monitor.jvm.JvmStats
 
ThreadSafe - Annotation Type in org.elasticsearch.util.concurrent
ThreadSafe

The class to which this annotation is applied is thread-safe.

throttleInterval() - Method in class org.elasticsearch.indices.recovery.throttler.RecoveryThrottler
 
throttlingWaitTime() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.RecoveryStatus.Index
 
throwableFromBytes(byte[]) - Static method in class org.elasticsearch.util.io.Serializers
 
ThrowableObjectInputStream - Class in org.elasticsearch.util.io
 
ThrowableObjectInputStream(InputStream) - Constructor for class org.elasticsearch.util.io.ThrowableObjectInputStream
 
ThrowableObjectInputStream(InputStream, ClassLoader) - Constructor for class org.elasticsearch.util.io.ThrowableObjectInputStream
 
ThrowableObjectOutputStream - Class in org.elasticsearch.util.io
 
ThrowableObjectOutputStream(OutputStream) - Constructor for class org.elasticsearch.util.io.ThrowableObjectOutputStream
 
throwableToBytes(Throwable) - Static method in class org.elasticsearch.util.io.Serializers
 
throwConfigurationExceptionIfErrorsExist() - Method in class org.elasticsearch.util.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.util.inject.internal.Errors
 
throwIfNewErrors(int) - Method in class org.elasticsearch.util.inject.internal.Errors
 
throwObjectContractViolation(Object, Object) - Method in class org.elasticsearch.util.gnu.trove.TObjectHash
Convenience methods for subclasses to use in throwing exceptions about badly behaved user objects employed as keys.
throwProvisionExceptionIfErrorsExist() - Method in class org.elasticsearch.util.inject.internal.Errors
 
tieBreaker(float) - Method in class org.elasticsearch.index.query.xcontent.DisMaxQueryBuilder
The score of each non-maximum disjunct for a document is multiplied by this weight and added into the final score.
tieBreaker(float) - Method in class org.elasticsearch.index.query.xcontent.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.
time() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.SnapshotStatus.Index
 
time() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.SnapshotStatus.Translog
 
timedOut() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse
true if the waitForXXX has timeout out and did not match.
timeout() - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
timeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.health.ClusterHealthRequest
 
timeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.IndexReplicationPingRequest
 
timeout(TimeValue) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.ReplicationPingRequest
 
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(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(TimeValue) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.GatewaySnapshotRequest
 
timeout(TimeValue) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.IndexGatewaySnapshotRequest
 
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(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(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() - Method in class org.elasticsearch.action.search.SearchRequest
An optional timeout to control how long search is allowed to take.
timeout(TimeValue) - Method in class org.elasticsearch.action.search.SearchRequest
An optional timeout to control how long search is allowed to take.
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() - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
timeout(TimeValue) - Method in class org.elasticsearch.search.internal.InternalSearchRequest
 
timeout() - Method in class org.elasticsearch.search.internal.SearchContext
 
Timeout - Interface in org.elasticsearch.util.timer
A handle associated with a TimerTask that is returned by a Timer.
TimeoutClusterStateListener - Interface in org.elasticsearch.cluster
 
Timer - Interface in org.elasticsearch.util.timer
Schedules TimerTasks for one-time future execution in a background thread.
TimerModule - Class in org.elasticsearch.timer
 
TimerModule() - Constructor for class org.elasticsearch.timer.TimerModule
 
TimerService - Class in org.elasticsearch.timer
 
TimerService(ThreadPool) - Constructor for class org.elasticsearch.timer.TimerService
 
TimerService(Settings, ThreadPool) - Constructor for class org.elasticsearch.timer.TimerService
 
TimerTask - Interface in org.elasticsearch.util.timer
A task which is executed after the delay specified with Timer.newTimeout(TimerTask, long, java.util.concurrent.TimeUnit).
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.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
 
TimeValue - Class in org.elasticsearch.util
 
TimeValue(long) - Constructor for class org.elasticsearch.util.TimeValue
 
TimeValue(long, TimeUnit) - Constructor for class org.elasticsearch.util.TimeValue
 
timeValueHours(long) - Static method in class org.elasticsearch.util.TimeValue
 
timeValueMillis(long) - Static method in class org.elasticsearch.util.TimeValue
 
timeValueMinutes(long) - Static method in class org.elasticsearch.util.TimeValue
 
timeValueSeconds(long) - Static method in class org.elasticsearch.util.TimeValue
 
TIntArrayList - Class in org.elasticsearch.util.gnu.trove
A resizable, array-backed list of int primitives.
TIntArrayList() - Constructor for class org.elasticsearch.util.gnu.trove.TIntArrayList
Creates a new TIntArrayList instance with the default capacity.
TIntArrayList(int) - Constructor for class org.elasticsearch.util.gnu.trove.TIntArrayList
Creates a new TIntArrayList instance with the specified capacity.
TIntArrayList(int[]) - Constructor for class org.elasticsearch.util.gnu.trove.TIntArrayList
Creates a new TIntArrayList instance whose capacity is the greater of the length of values and DEFAULT_CAPACITY and whose initial contents are the specified values.
TIntByteHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for int keys and byte values.
TIntByteHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Creates a new TIntByteHashMap instance with the default capacity and load factor.
TIntByteHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Creates a new TIntByteHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TIntByteHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Creates a new TIntByteHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TIntByteHashMap(TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Creates a new TIntByteHashMap instance with the default capacity and load factor.
TIntByteHashMap(int, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Creates a new TIntByteHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TIntByteHashMap(int, float, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Creates a new TIntByteHashMap instance with a prime value at or near the specified capacity and load factor.
TIntByteHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TIntByteHashMap conform to the java.util.Map API.
TIntByteHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TIntByteHashMapDecorator(TIntByteHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TIntByteIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type int and byte.
TIntByteIterator(TIntByteHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TIntByteIterator
Creates an iterator over the specified map
TIntByteProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type int and byte.
TIntDoubleHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for int keys and double values.
TIntDoubleHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Creates a new TIntDoubleHashMap instance with the default capacity and load factor.
TIntDoubleHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Creates a new TIntDoubleHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TIntDoubleHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Creates a new TIntDoubleHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TIntDoubleHashMap(TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Creates a new TIntDoubleHashMap instance with the default capacity and load factor.
TIntDoubleHashMap(int, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Creates a new TIntDoubleHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TIntDoubleHashMap(int, float, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Creates a new TIntDoubleHashMap instance with a prime value at or near the specified capacity and load factor.
TIntDoubleHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TIntDoubleHashMap conform to the java.util.Map API.
TIntDoubleHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TIntDoubleHashMapDecorator(TIntDoubleHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TIntDoubleIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type int and double.
TIntDoubleIterator(TIntDoubleHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TIntDoubleIterator
Creates an iterator over the specified map
TIntDoubleProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type int and double.
TIntFloatHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for int keys and float values.
TIntFloatHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Creates a new TIntFloatHashMap instance with the default capacity and load factor.
TIntFloatHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Creates a new TIntFloatHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TIntFloatHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Creates a new TIntFloatHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TIntFloatHashMap(TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Creates a new TIntFloatHashMap instance with the default capacity and load factor.
TIntFloatHashMap(int, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Creates a new TIntFloatHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TIntFloatHashMap(int, float, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Creates a new TIntFloatHashMap instance with a prime value at or near the specified capacity and load factor.
TIntFloatHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TIntFloatHashMap conform to the java.util.Map API.
TIntFloatHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TIntFloatHashMapDecorator(TIntFloatHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TIntFloatIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type int and float.
TIntFloatIterator(TIntFloatHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TIntFloatIterator
Creates an iterator over the specified map
TIntFloatProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type int and float.
TIntFunction - Interface in org.elasticsearch.util.gnu.trove
Interface for functions that accept and return one int primitive.
TIntHash - Class in org.elasticsearch.util.gnu.trove
An open addressed hashing implementation for int primitives.
TIntHash() - Constructor for class org.elasticsearch.util.gnu.trove.TIntHash
Creates a new TIntHash instance with the default capacity and load factor.
TIntHash(int) - Constructor for class org.elasticsearch.util.gnu.trove.TIntHash
Creates a new TIntHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TIntHash(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TIntHash
Creates a new TIntHash instance with a prime value at or near the specified capacity and load factor.
TIntHash(TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntHash
Creates a new TIntHash instance with the default capacity and load factor.
TIntHash(int, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntHash
Creates a new TIntHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TIntHash(int, float, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntHash
Creates a new TIntHash instance with a prime value at or near the specified capacity and load factor.
TIntHashingStrategy - Interface in org.elasticsearch.util.gnu.trove
Interface to support pluggable hashing strategies in maps and sets.
TIntHashSet - Class in org.elasticsearch.util.gnu.trove
An open addressed set implementation for int primitives.
TIntHashSet() - Constructor for class org.elasticsearch.util.gnu.trove.TIntHashSet
Creates a new TIntHashSet instance with the default capacity and load factor.
TIntHashSet(int) - Constructor for class org.elasticsearch.util.gnu.trove.TIntHashSet
Creates a new TIntHashSet instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TIntHashSet(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TIntHashSet
Creates a new TIntHashSet instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TIntHashSet(int[]) - Constructor for class org.elasticsearch.util.gnu.trove.TIntHashSet
Creates a new TIntHashSet instance containing the elements of array.
TIntHashSet(TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntHashSet
Creates a new TIntHash instance with the default capacity and load factor.
TIntHashSet(int, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntHashSet
Creates a new TIntHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TIntHashSet(int, float, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntHashSet
Creates a new TIntHash instance with a prime value at or near the specified capacity and load factor.
TIntHashSet(int[], TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntHashSet
Creates a new TIntHashSet instance containing the elements of array.
TIntHashSetDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TIntHashSet conform to the java.util.Set API.
TIntHashSetDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TIntHashSetDecorator
FOR EXTERNALIZATION ONLY!!
TIntHashSetDecorator(TIntHashSet) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TIntHashSetDecorator
Creates a wrapper that decorates the specified primitive set.
TIntIntHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for int keys and int values.
TIntIntHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Creates a new TIntIntHashMap instance with the default capacity and load factor.
TIntIntHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Creates a new TIntIntHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TIntIntHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Creates a new TIntIntHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TIntIntHashMap(TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Creates a new TIntIntHashMap instance with the default capacity and load factor.
TIntIntHashMap(int, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Creates a new TIntIntHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TIntIntHashMap(int, float, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Creates a new TIntIntHashMap instance with a prime value at or near the specified capacity and load factor.
TIntIntHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TIntIntHashMap conform to the java.util.Map API.
TIntIntHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TIntIntHashMapDecorator(TIntIntHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TIntIntIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type int and int.
TIntIntIterator(TIntIntHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TIntIntIterator
Creates an iterator over the specified map
TIntIntProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type int and int.
TIntIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for int collections.
TIntIterator(TIntHash) - Constructor for class org.elasticsearch.util.gnu.trove.TIntIterator
Creates a TIntIterator for the elements in the specified collection.
TIntLongHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for int keys and long values.
TIntLongHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Creates a new TIntLongHashMap instance with the default capacity and load factor.
TIntLongHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Creates a new TIntLongHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TIntLongHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Creates a new TIntLongHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TIntLongHashMap(TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Creates a new TIntLongHashMap instance with the default capacity and load factor.
TIntLongHashMap(int, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Creates a new TIntLongHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TIntLongHashMap(int, float, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Creates a new TIntLongHashMap instance with a prime value at or near the specified capacity and load factor.
TIntLongHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TIntLongHashMap conform to the java.util.Map API.
TIntLongHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TIntLongHashMapDecorator(TIntLongHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TIntLongIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type int and long.
TIntLongIterator(TIntLongHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TIntLongIterator
Creates an iterator over the specified map
TIntLongProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type int and long.
TIntObjectHashMap<V> - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for int keys and Object values.
TIntObjectHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Creates a new TIntObjectHashMap instance with the default capacity and load factor.
TIntObjectHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Creates a new TIntObjectHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TIntObjectHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Creates a new TIntObjectHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TIntObjectHashMap(TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Creates a new TIntObjectHashMap instance with the default capacity and load factor.
TIntObjectHashMap(int, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Creates a new TIntObjectHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TIntObjectHashMap(int, float, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Creates a new TIntObjectHashMap instance with a prime value at or near the specified capacity and load factor.
TIntObjectHashMapDecorator<V> - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TIntObjectHashMap conform to the java.util.Map API.
TIntObjectHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TIntObjectHashMapDecorator(TIntObjectHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TIntObjectIterator<V> - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type int and Object.
TIntObjectIterator(TIntObjectHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.TIntObjectIterator
Creates an iterator over the specified map
TIntObjectProcedure<T> - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type int and Object.
TIntProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures with one int parameter.
TIntShortHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for int keys and short values.
TIntShortHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Creates a new TIntShortHashMap instance with the default capacity and load factor.
TIntShortHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Creates a new TIntShortHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TIntShortHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Creates a new TIntShortHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TIntShortHashMap(TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Creates a new TIntShortHashMap instance with the default capacity and load factor.
TIntShortHashMap(int, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Creates a new TIntShortHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TIntShortHashMap(int, float, TIntHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Creates a new TIntShortHashMap instance with a prime value at or near the specified capacity and load factor.
TIntShortHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TIntShortHashMap conform to the java.util.Map API.
TIntShortHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TIntShortHashMapDecorator(TIntShortHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TIntShortIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type int and short.
TIntShortIterator(TIntShortHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TIntShortIterator
Creates an iterator over the specified map
TIntShortProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type int and short.
TIntStack - Class in org.elasticsearch.util.gnu.trove
A stack of int primitives, backed by a TIntArrayList.
TIntStack() - Constructor for class org.elasticsearch.util.gnu.trove.TIntStack
Creates a new TIntStack instance with the default capacity.
TIntStack(int) - Constructor for class org.elasticsearch.util.gnu.trove.TIntStack
Creates a new TIntStack instance with the specified capacity.
TLinkable - Interface in org.elasticsearch.util.gnu.trove
Interface for Objects which can be inserted into a TLinkedList.
TLinkableAdapter - Class in org.elasticsearch.util.gnu.trove
Adapter for TLinkable interface which implements the interface and can therefore be extended trivially to create TLinkable objects without having to implement the obvious.
TLinkableAdapter() - Constructor for class org.elasticsearch.util.gnu.trove.TLinkableAdapter
 
TLinkedList<T extends TLinkable> - Class in org.elasticsearch.util.gnu.trove
A LinkedList implementation which holds instances of type TLinkable.
TLinkedList() - Constructor for class org.elasticsearch.util.gnu.trove.TLinkedList
Creates a new TLinkedList instance.
TLinkedList.IteratorImpl - Class in org.elasticsearch.util.gnu.trove
A ListIterator that supports additions and deletions.
TLongArrayList - Class in org.elasticsearch.util.gnu.trove
A resizable, array-backed list of long primitives.
TLongArrayList() - Constructor for class org.elasticsearch.util.gnu.trove.TLongArrayList
Creates a new TLongArrayList instance with the default capacity.
TLongArrayList(int) - Constructor for class org.elasticsearch.util.gnu.trove.TLongArrayList
Creates a new TLongArrayList instance with the specified capacity.
TLongArrayList(long[]) - Constructor for class org.elasticsearch.util.gnu.trove.TLongArrayList
Creates a new TLongArrayList instance whose capacity is the greater of the length of values and DEFAULT_CAPACITY and whose initial contents are the specified values.
TLongByteHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for long keys and byte values.
TLongByteHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Creates a new TLongByteHashMap instance with the default capacity and load factor.
TLongByteHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Creates a new TLongByteHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TLongByteHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Creates a new TLongByteHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TLongByteHashMap(TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Creates a new TLongByteHashMap instance with the default capacity and load factor.
TLongByteHashMap(int, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Creates a new TLongByteHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TLongByteHashMap(int, float, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Creates a new TLongByteHashMap instance with a prime value at or near the specified capacity and load factor.
TLongByteHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TLongByteHashMap conform to the java.util.Map API.
TLongByteHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TLongByteHashMapDecorator(TLongByteHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TLongByteIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type long and byte.
TLongByteIterator(TLongByteHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TLongByteIterator
Creates an iterator over the specified map
TLongByteProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type long and byte.
TLongDoubleHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for long keys and double values.
TLongDoubleHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Creates a new TLongDoubleHashMap instance with the default capacity and load factor.
TLongDoubleHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Creates a new TLongDoubleHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TLongDoubleHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Creates a new TLongDoubleHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TLongDoubleHashMap(TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Creates a new TLongDoubleHashMap instance with the default capacity and load factor.
TLongDoubleHashMap(int, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Creates a new TLongDoubleHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TLongDoubleHashMap(int, float, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Creates a new TLongDoubleHashMap instance with a prime value at or near the specified capacity and load factor.
TLongDoubleHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TLongDoubleHashMap conform to the java.util.Map API.
TLongDoubleHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TLongDoubleHashMapDecorator(TLongDoubleHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TLongDoubleIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type long and double.
TLongDoubleIterator(TLongDoubleHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TLongDoubleIterator
Creates an iterator over the specified map
TLongDoubleProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type long and double.
TLongFloatHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for long keys and float values.
TLongFloatHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Creates a new TLongFloatHashMap instance with the default capacity and load factor.
TLongFloatHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Creates a new TLongFloatHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TLongFloatHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Creates a new TLongFloatHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TLongFloatHashMap(TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Creates a new TLongFloatHashMap instance with the default capacity and load factor.
TLongFloatHashMap(int, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Creates a new TLongFloatHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TLongFloatHashMap(int, float, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Creates a new TLongFloatHashMap instance with a prime value at or near the specified capacity and load factor.
TLongFloatHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TLongFloatHashMap conform to the java.util.Map API.
TLongFloatHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TLongFloatHashMapDecorator(TLongFloatHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TLongFloatIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type long and float.
TLongFloatIterator(TLongFloatHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TLongFloatIterator
Creates an iterator over the specified map
TLongFloatProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type long and float.
TLongFunction - Interface in org.elasticsearch.util.gnu.trove
Interface for functions that accept and return one long primitive.
TLongHash - Class in org.elasticsearch.util.gnu.trove
An open addressed hashing implementation for long primitives.
TLongHash() - Constructor for class org.elasticsearch.util.gnu.trove.TLongHash
Creates a new TLongHash instance with the default capacity and load factor.
TLongHash(int) - Constructor for class org.elasticsearch.util.gnu.trove.TLongHash
Creates a new TLongHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TLongHash(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TLongHash
Creates a new TLongHash instance with a prime value at or near the specified capacity and load factor.
TLongHash(TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongHash
Creates a new TLongHash instance with the default capacity and load factor.
TLongHash(int, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongHash
Creates a new TLongHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TLongHash(int, float, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongHash
Creates a new TLongHash instance with a prime value at or near the specified capacity and load factor.
TLongHashingStrategy - Interface in org.elasticsearch.util.gnu.trove
Interface to support pluggable hashing strategies in maps and sets.
TLongHashSet - Class in org.elasticsearch.util.gnu.trove
An open addressed set implementation for long primitives.
TLongHashSet() - Constructor for class org.elasticsearch.util.gnu.trove.TLongHashSet
Creates a new TLongHashSet instance with the default capacity and load factor.
TLongHashSet(int) - Constructor for class org.elasticsearch.util.gnu.trove.TLongHashSet
Creates a new TLongHashSet instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TLongHashSet(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TLongHashSet
Creates a new TLongHashSet instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TLongHashSet(long[]) - Constructor for class org.elasticsearch.util.gnu.trove.TLongHashSet
Creates a new TLongHashSet instance containing the elements of array.
TLongHashSet(TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongHashSet
Creates a new TLongHash instance with the default capacity and load factor.
TLongHashSet(int, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongHashSet
Creates a new TLongHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TLongHashSet(int, float, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongHashSet
Creates a new TLongHash instance with a prime value at or near the specified capacity and load factor.
TLongHashSet(long[], TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongHashSet
Creates a new TLongHashSet instance containing the elements of array.
TLongHashSetDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TLongHashSet conform to the java.util.Set API.
TLongHashSetDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TLongHashSetDecorator
FOR EXTERNALIZATION ONLY!!
TLongHashSetDecorator(TLongHashSet) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TLongHashSetDecorator
Creates a wrapper that decorates the specified primitive set.
TLongIntHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for long keys and int values.
TLongIntHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Creates a new TLongIntHashMap instance with the default capacity and load factor.
TLongIntHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Creates a new TLongIntHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TLongIntHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Creates a new TLongIntHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TLongIntHashMap(TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Creates a new TLongIntHashMap instance with the default capacity and load factor.
TLongIntHashMap(int, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Creates a new TLongIntHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TLongIntHashMap(int, float, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Creates a new TLongIntHashMap instance with a prime value at or near the specified capacity and load factor.
TLongIntHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TLongIntHashMap conform to the java.util.Map API.
TLongIntHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TLongIntHashMapDecorator(TLongIntHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TLongIntIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type long and int.
TLongIntIterator(TLongIntHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TLongIntIterator
Creates an iterator over the specified map
TLongIntProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type long and int.
TLongIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for long collections.
TLongIterator(TLongHash) - Constructor for class org.elasticsearch.util.gnu.trove.TLongIterator
Creates a TLongIterator for the elements in the specified collection.
TLongLongHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for long keys and long values.
TLongLongHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Creates a new TLongLongHashMap instance with the default capacity and load factor.
TLongLongHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Creates a new TLongLongHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TLongLongHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Creates a new TLongLongHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TLongLongHashMap(TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Creates a new TLongLongHashMap instance with the default capacity and load factor.
TLongLongHashMap(int, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Creates a new TLongLongHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TLongLongHashMap(int, float, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Creates a new TLongLongHashMap instance with a prime value at or near the specified capacity and load factor.
TLongLongHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TLongLongHashMap conform to the java.util.Map API.
TLongLongHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TLongLongHashMapDecorator(TLongLongHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TLongLongIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type long and long.
TLongLongIterator(TLongLongHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TLongLongIterator
Creates an iterator over the specified map
TLongLongProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type long and long.
TLongObjectHashMap<V> - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for long keys and Object values.
TLongObjectHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Creates a new TLongObjectHashMap instance with the default capacity and load factor.
TLongObjectHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Creates a new TLongObjectHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TLongObjectHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Creates a new TLongObjectHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TLongObjectHashMap(TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Creates a new TLongObjectHashMap instance with the default capacity and load factor.
TLongObjectHashMap(int, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Creates a new TLongObjectHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TLongObjectHashMap(int, float, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Creates a new TLongObjectHashMap instance with a prime value at or near the specified capacity and load factor.
TLongObjectHashMapDecorator<V> - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TLongObjectHashMap conform to the java.util.Map API.
TLongObjectHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TLongObjectHashMapDecorator(TLongObjectHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TLongObjectIterator<V> - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type long and Object.
TLongObjectIterator(TLongObjectHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.TLongObjectIterator
Creates an iterator over the specified map
TLongObjectProcedure<T> - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type long and Object.
TLongProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures with one long parameter.
TLongShortHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for long keys and short values.
TLongShortHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Creates a new TLongShortHashMap instance with the default capacity and load factor.
TLongShortHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Creates a new TLongShortHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TLongShortHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Creates a new TLongShortHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TLongShortHashMap(TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Creates a new TLongShortHashMap instance with the default capacity and load factor.
TLongShortHashMap(int, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Creates a new TLongShortHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TLongShortHashMap(int, float, TLongHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Creates a new TLongShortHashMap instance with a prime value at or near the specified capacity and load factor.
TLongShortHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TLongShortHashMap conform to the java.util.Map API.
TLongShortHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TLongShortHashMapDecorator(TLongShortHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TLongShortIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type long and short.
TLongShortIterator(TLongShortHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TLongShortIterator
Creates an iterator over the specified map
TLongShortProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type long and short.
TLongStack - Class in org.elasticsearch.util.gnu.trove
A stack of long primitives, backed by a TLongArrayList.
TLongStack() - Constructor for class org.elasticsearch.util.gnu.trove.TLongStack
Creates a new TLongStack instance with the default capacity.
TLongStack(int) - Constructor for class org.elasticsearch.util.gnu.trove.TLongStack
Creates a new TLongStack instance with the specified capacity.
to() - Method in class org.elasticsearch.action.terms.TermsRequest
The upper bound term to which the iteration will end.
to(Object) - Method in class org.elasticsearch.action.terms.TermsRequest
The upper bound term to which the iteration will end.
to(String) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The to part of the filter query.
to(int) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The to part of the filter query.
to(long) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The to part of the filter query.
to(float) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The to part of the filter query.
to(double) - Method in class org.elasticsearch.index.query.xcontent.RangeFilterBuilder
The to part of the filter query.
to(Object) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
to(String) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
to(int) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
to(long) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
to(float) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
to(double) - Method in class org.elasticsearch.index.query.xcontent.RangeQueryBuilder
The to part of the range query.
to(String) - Method in interface org.elasticsearch.util.inject.binder.ConstantBindingBuilder
Binds constant to the given value.
to(int) - Method in interface org.elasticsearch.util.inject.binder.ConstantBindingBuilder
Binds constant to the given value.
to(long) - Method in interface org.elasticsearch.util.inject.binder.ConstantBindingBuilder
Binds constant to the given value.
to(boolean) - Method in interface org.elasticsearch.util.inject.binder.ConstantBindingBuilder
Binds constant to the given value.
to(double) - Method in interface org.elasticsearch.util.inject.binder.ConstantBindingBuilder
Binds constant to the given value.
to(float) - Method in interface org.elasticsearch.util.inject.binder.ConstantBindingBuilder
Binds constant to the given value.
to(short) - Method in interface org.elasticsearch.util.inject.binder.ConstantBindingBuilder
Binds constant to the given value.
to(char) - Method in interface org.elasticsearch.util.inject.binder.ConstantBindingBuilder
Binds constant to the given value.
to(Class<?>) - Method in interface org.elasticsearch.util.inject.binder.ConstantBindingBuilder
Binds constant to the given value.
to(E) - Method in interface org.elasticsearch.util.inject.binder.ConstantBindingBuilder
Binds constant to the given value.
to(Class<? extends T>) - Method in interface org.elasticsearch.util.inject.binder.LinkedBindingBuilder
See the EDSL examples at Binder.
to(TypeLiteral<? extends T>) - Method in interface org.elasticsearch.util.inject.binder.LinkedBindingBuilder
See the EDSL examples at Binder.
to(Key<? extends T>) - Method in interface org.elasticsearch.util.inject.binder.LinkedBindingBuilder
See the EDSL examples at Binder.
to(Class<? extends T>) - Method in class org.elasticsearch.util.inject.internal.BindingBuilder
 
to(TypeLiteral<? extends T>) - Method in class org.elasticsearch.util.inject.internal.BindingBuilder
 
to(Key<? extends T>) - Method in class org.elasticsearch.util.inject.internal.BindingBuilder
 
to(String) - Method in class org.elasticsearch.util.inject.internal.ConstantBindingBuilderImpl
 
to(int) - Method in class org.elasticsearch.util.inject.internal.ConstantBindingBuilderImpl
 
to(long) - Method in class org.elasticsearch.util.inject.internal.ConstantBindingBuilderImpl
 
to(boolean) - Method in class org.elasticsearch.util.inject.internal.ConstantBindingBuilderImpl
 
to(double) - Method in class org.elasticsearch.util.inject.internal.ConstantBindingBuilderImpl
 
to(float) - Method in class org.elasticsearch.util.inject.internal.ConstantBindingBuilderImpl
 
to(short) - Method in class org.elasticsearch.util.inject.internal.ConstantBindingBuilderImpl
 
to(char) - Method in class org.elasticsearch.util.inject.internal.ConstantBindingBuilderImpl
 
to(Class<?>) - Method in class org.elasticsearch.util.inject.internal.ConstantBindingBuilderImpl
 
to(E) - Method in class org.elasticsearch.util.inject.internal.ConstantBindingBuilderImpl
 
toArray() - Method in class org.elasticsearch.util.collect.ConcurrentHashMultiset
 
toArray(T[]) - Method in class org.elasticsearch.util.collect.ConcurrentHashMultiset
 
toArray() - Method in class org.elasticsearch.util.collect.ForwardingCollection
 
toArray(T[]) - Method in class org.elasticsearch.util.collect.ForwardingCollection
 
toArray() - Method in class org.elasticsearch.util.collect.ImmutableCollection
 
toArray(T[]) - Method in class org.elasticsearch.util.collect.ImmutableCollection
 
toArray(Iterable<? extends T>, Class<T>) - Static method in class org.elasticsearch.util.collect.Iterables
Copies an iterable's elements into an array.
toArray(Iterator<? extends T>, Class<T>) - Static method in class org.elasticsearch.util.collect.Iterators
Copies an iterator's elements into an array.
toArray() - Method in class org.elasticsearch.util.gnu.trove.TByteHashSet
Returns a new array containing the values in the set.
toArray() - Method in class org.elasticsearch.util.gnu.trove.TDoubleHashSet
Returns a new array containing the values in the set.
toArray() - Method in class org.elasticsearch.util.gnu.trove.TFloatHashSet
Returns a new array containing the values in the set.
toArray() - Method in class org.elasticsearch.util.gnu.trove.THashSet
Returns a new array containing the objects in the set.
toArray(T[]) - Method in class org.elasticsearch.util.gnu.trove.THashSet
Returns a typed array of the objects in the set.
toArray() - Method in class org.elasticsearch.util.gnu.trove.TIntHashSet
Returns a new array containing the values in the set.
toArray() - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Copies the list's contents into a native array.
toArray() - Method in class org.elasticsearch.util.gnu.trove.TLongHashSet
Returns a new array containing the values in the set.
toArray() - Method in class org.elasticsearch.util.gnu.trove.TShortHashSet
Returns a new array containing the values in the set.
TObjectByteHashMap<K> - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for Object keys and byte values.
TObjectByteHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Creates a new TObjectByteHashMap instance with the default capacity and load factor.
TObjectByteHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Creates a new TObjectByteHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TObjectByteHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Creates a new TObjectByteHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TObjectByteHashMap(TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Creates a new TObjectByteHashMap instance with the default capacity and load factor.
TObjectByteHashMap(int, TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Creates a new TObjectByteHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TObjectByteHashMap(int, float, TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Creates a new TObjectByteHashMap instance with a prime value at or near the specified capacity and load factor.
TObjectByteHashMapDecorator<V> - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TObjectByteHashMap conform to the java.util.Map API.
TObjectByteHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TObjectByteHashMapDecorator(TObjectByteHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TObjectByteIterator<K> - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type Object and byte.
TObjectByteIterator(TObjectByteHashMap<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectByteIterator
 
TObjectByteProcedure<K> - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type Object and byte.
TObjectDoubleHashMap<K> - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for Object keys and double values.
TObjectDoubleHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Creates a new TObjectDoubleHashMap instance with the default capacity and load factor.
TObjectDoubleHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Creates a new TObjectDoubleHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TObjectDoubleHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Creates a new TObjectDoubleHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TObjectDoubleHashMap(TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Creates a new TObjectDoubleHashMap instance with the default capacity and load factor.
TObjectDoubleHashMap(int, TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Creates a new TObjectDoubleHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TObjectDoubleHashMap(int, float, TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Creates a new TObjectDoubleHashMap instance with a prime value at or near the specified capacity and load factor.
TObjectDoubleHashMapDecorator<V> - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TObjectDoubleHashMap conform to the java.util.Map API.
TObjectDoubleHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TObjectDoubleHashMapDecorator(TObjectDoubleHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TObjectDoubleIterator<K> - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type Object and double.
TObjectDoubleIterator(TObjectDoubleHashMap<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectDoubleIterator
 
TObjectDoubleProcedure<K> - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type Object and double.
TObjectFloatHashMap<K> - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for Object keys and float values.
TObjectFloatHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Creates a new TObjectFloatHashMap instance with the default capacity and load factor.
TObjectFloatHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Creates a new TObjectFloatHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TObjectFloatHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Creates a new TObjectFloatHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TObjectFloatHashMap(TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Creates a new TObjectFloatHashMap instance with the default capacity and load factor.
TObjectFloatHashMap(int, TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Creates a new TObjectFloatHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TObjectFloatHashMap(int, float, TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Creates a new TObjectFloatHashMap instance with a prime value at or near the specified capacity and load factor.
TObjectFloatHashMapDecorator<V> - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TObjectFloatHashMap conform to the java.util.Map API.
TObjectFloatHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TObjectFloatHashMapDecorator(TObjectFloatHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TObjectFloatIterator<K> - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type Object and float.
TObjectFloatIterator(TObjectFloatHashMap<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectFloatIterator
 
TObjectFloatProcedure<K> - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type Object and float.
TObjectFunction<T,R> - Interface in org.elasticsearch.util.gnu.trove
Interface for functions that accept and return one Object reference.
TObjectHash<T> - Class in org.elasticsearch.util.gnu.trove
An open addressed hashing implementation for Object types.
TObjectHash() - Constructor for class org.elasticsearch.util.gnu.trove.TObjectHash
Creates a new TObjectHash instance with the default capacity and load factor.
TObjectHash(TObjectHashingStrategy<T>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectHash
Creates a new TObjectHash instance with the default capacity and load factor and a custom hashing strategy.
TObjectHash(int) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectHash
Creates a new TObjectHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TObjectHash(int, TObjectHashingStrategy<T>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectHash
Creates a new TObjectHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TObjectHash(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectHash
Creates a new TObjectHash instance with a prime value at or near the specified capacity and load factor.
TObjectHash(int, float, TObjectHashingStrategy<T>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectHash
Creates a new TObjectHash instance with a prime value at or near the specified capacity and load factor.
TObjectHashingStrategy<T> - Interface in org.elasticsearch.util.gnu.trove
Interface to support pluggable hashing strategies in maps and sets.
TObjectIdentityHashingStrategy<T> - Class in org.elasticsearch.util.gnu.trove
This object hashing strategy uses the System.identityHashCode method to provide identity hash codes.
TObjectIdentityHashingStrategy() - Constructor for class org.elasticsearch.util.gnu.trove.TObjectIdentityHashingStrategy
 
TObjectIntHashMap<K> - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for Object keys and int values.
TObjectIntHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Creates a new TObjectIntHashMap instance with the default capacity and load factor.
TObjectIntHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Creates a new TObjectIntHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TObjectIntHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Creates a new TObjectIntHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TObjectIntHashMap(TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Creates a new TObjectIntHashMap instance with the default capacity and load factor.
TObjectIntHashMap(int, TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Creates a new TObjectIntHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TObjectIntHashMap(int, float, TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Creates a new TObjectIntHashMap instance with a prime value at or near the specified capacity and load factor.
TObjectIntHashMapDecorator<V> - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TObjectIntHashMap conform to the java.util.Map API.
TObjectIntHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TObjectIntHashMapDecorator(TObjectIntHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TObjectIntIterator<K> - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type Object and int.
TObjectIntIterator(TObjectIntHashMap<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectIntIterator
 
TObjectIntProcedure<K> - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type Object and int.
TObjectLongHashMap<K> - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for Object keys and long values.
TObjectLongHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Creates a new TObjectLongHashMap instance with the default capacity and load factor.
TObjectLongHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Creates a new TObjectLongHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TObjectLongHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Creates a new TObjectLongHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TObjectLongHashMap(TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Creates a new TObjectLongHashMap instance with the default capacity and load factor.
TObjectLongHashMap(int, TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Creates a new TObjectLongHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TObjectLongHashMap(int, float, TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Creates a new TObjectLongHashMap instance with a prime value at or near the specified capacity and load factor.
TObjectLongHashMapDecorator<V> - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TObjectLongHashMap conform to the java.util.Map API.
TObjectLongHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TObjectLongHashMapDecorator(TObjectLongHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TObjectLongIterator<K> - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type Object and long.
TObjectLongIterator(TObjectLongHashMap<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectLongIterator
 
TObjectLongProcedure<K> - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type Object and long.
TObjectObjectProcedure<K,V> - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two Object parameters.
TObjectProcedure<T> - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures with one Object parameter.
TObjectShortHashMap<K> - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for Object keys and short values.
TObjectShortHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Creates a new TObjectShortHashMap instance with the default capacity and load factor.
TObjectShortHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Creates a new TObjectShortHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TObjectShortHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Creates a new TObjectShortHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TObjectShortHashMap(TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Creates a new TObjectShortHashMap instance with the default capacity and load factor.
TObjectShortHashMap(int, TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Creates a new TObjectShortHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TObjectShortHashMap(int, float, TObjectHashingStrategy<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Creates a new TObjectShortHashMap instance with a prime value at or near the specified capacity and load factor.
TObjectShortHashMapDecorator<V> - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TObjectShortHashMap conform to the java.util.Map API.
TObjectShortHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TObjectShortHashMapDecorator(TObjectShortHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TObjectShortIterator<K> - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type Object and short.
TObjectShortIterator(TObjectShortHashMap<K>) - Constructor for class org.elasticsearch.util.gnu.trove.TObjectShortIterator
 
TObjectShortProcedure<K> - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type Object and short.
toBytes(ClusterState) - Static method in class org.elasticsearch.cluster.ClusterState.Builder
 
toBytes(long) - Method in enum org.elasticsearch.util.SizeUnit
 
toCamelCase(String) - Static method in class org.elasticsearch.util.Strings
 
toCamelCase(String, StringBuilder) - Static method in class org.elasticsearch.util.Strings
 
toCharArray() - Method in class org.elasticsearch.util.io.FastCharArrayWriter
Returns a copy of the input data.
toException() - Method in class org.elasticsearch.util.inject.internal.Errors
 
toGB(long) - Method in enum org.elasticsearch.util.SizeUnit
 
toInclusive() - Method in class org.elasticsearch.action.terms.TermsRequest
Should the last to (if set using TermsRequest.to(Object) be inclusive or not.
toInclusive(boolean) - Method in class org.elasticsearch.action.terms.TermsRequest
Should the last to (if set using TermsRequest.to(Object) be inclusive or not.
toInstance(T) - Method in interface org.elasticsearch.util.inject.binder.LinkedBindingBuilder
See the EDSL examples at Binder.
toInstance(T) - Method in class org.elasticsearch.util.inject.internal.BindingBuilder
 
toKB(long) - Method in enum org.elasticsearch.util.SizeUnit
 
tokenFilter(String) - Method in class org.elasticsearch.index.analysis.AnalysisService
 
TokenFilterFactory - Interface in org.elasticsearch.index.analysis
 
TokenFilterFactoryFactory - Interface in org.elasticsearch.index.analysis
 
tokenFilters() - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
 
tokenizer(String) - Method in class org.elasticsearch.index.analysis.AnalysisService
 
tokenizerFactory() - Method in class org.elasticsearch.index.analysis.CustomAnalyzer
 
TokenizerFactory - Interface in org.elasticsearch.index.analysis
 
TokenizerFactoryFactory - Interface in org.elasticsearch.index.analysis
 
tokenizeToStringArray(String, String) - Static method in class org.elasticsearch.util.Strings
Tokenize the given String into a String array via a StringTokenizer.
tokenizeToStringArray(String, String, boolean, boolean) - Static method in class org.elasticsearch.util.Strings
Tokenize the given String into a String array via a StringTokenizer.
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
 
tokenStream(String, Reader) - Method in class org.elasticsearch.util.lucene.all.AllAnalyzer
 
toLanguageTag(Locale) - Static method in class org.elasticsearch.util.Strings
Determine the RFC 3066 compliant language tag, as used for the HTTP "Accept-Language" header.
toMB(long) - Method in enum org.elasticsearch.util.SizeUnit
 
toNativeArray() - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Copies the contents of the list into a native array.
toNativeArray(int, int) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Copies a slice of the list into a native array.
toNativeArray(byte[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Copies a slice of the list into a native array.
toNativeArray() - Method in class org.elasticsearch.util.gnu.trove.TByteStack
Copies the contents of the stack into a native array.
toNativeArray(byte[]) - Method in class org.elasticsearch.util.gnu.trove.TByteStack
Copies a slice of the list into a native array.
toNativeArray() - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Copies the contents of the list into a native array.
toNativeArray(int, int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Copies a slice of the list into a native array.
toNativeArray(double[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Copies a slice of the list into a native array.
toNativeArray() - Method in class org.elasticsearch.util.gnu.trove.TDoubleStack
Copies the contents of the stack into a native array.
toNativeArray(double[]) - Method in class org.elasticsearch.util.gnu.trove.TDoubleStack
Copies a slice of the list into a native array.
toNativeArray() - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Copies the contents of the list into a native array.
toNativeArray(int, int) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Copies a slice of the list into a native array.
toNativeArray(float[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Copies a slice of the list into a native array.
toNativeArray() - Method in class org.elasticsearch.util.gnu.trove.TFloatStack
Copies the contents of the stack into a native array.
toNativeArray(float[]) - Method in class org.elasticsearch.util.gnu.trove.TFloatStack
Copies a slice of the list into a native array.
toNativeArray() - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Copies the contents of the list into a native array.
toNativeArray(int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Copies a slice of the list into a native array.
toNativeArray(int[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Copies a slice of the list into a native array.
toNativeArray() - Method in class org.elasticsearch.util.gnu.trove.TIntStack
Copies the contents of the stack into a native array.
toNativeArray(int[]) - Method in class org.elasticsearch.util.gnu.trove.TIntStack
Copies a slice of the list into a native array.
toNativeArray() - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Copies the contents of the list into a native array.
toNativeArray(int, int) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Copies a slice of the list into a native array.
toNativeArray(long[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Copies a slice of the list into a native array.
toNativeArray() - Method in class org.elasticsearch.util.gnu.trove.TLongStack
Copies the contents of the stack into a native array.
toNativeArray(long[]) - Method in class org.elasticsearch.util.gnu.trove.TLongStack
Copies a slice of the list into a native array.
toNativeArray() - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Copies the contents of the list into a native array.
toNativeArray(int, int) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Copies a slice of the list into a native array.
toNativeArray(short[], int, int) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Copies a slice of the list into a native array.
toNativeArray() - Method in class org.elasticsearch.util.gnu.trove.TShortStack
Copies the contents of the stack into a native array.
toNativeArray(short[]) - Method in class org.elasticsearch.util.gnu.trove.TShortStack
Copies a slice of the list into a native array.
tooManyConstructors(Class<?>) - Method in class org.elasticsearch.util.inject.internal.Errors
 
topDocs() - Method in class org.elasticsearch.search.query.QuerySearchResult
 
topDocs(TopDocs) - Method in class org.elasticsearch.search.query.QuerySearchResult
 
toProvider(Provider<? extends T>) - Method in interface org.elasticsearch.util.inject.binder.LinkedBindingBuilder
See the EDSL examples at Binder.
toProvider(Class<? extends Provider<? extends T>>) - Method in interface org.elasticsearch.util.inject.binder.LinkedBindingBuilder
See the EDSL examples at Binder.
toProvider(Key<? extends Provider<? extends T>>) - Method in interface org.elasticsearch.util.inject.binder.LinkedBindingBuilder
See the EDSL examples at Binder.
toProvider(Provider<? extends T>) - Method in class org.elasticsearch.util.inject.internal.BindingBuilder
 
toProvider(Class<? extends Provider<? extends T>>) - Method in class org.elasticsearch.util.inject.internal.BindingBuilder
 
toProvider(Key<? extends Provider<? extends T>>) - Method in class org.elasticsearch.util.inject.internal.BindingBuilder
 
toString() - Method in class org.elasticsearch.action.admin.cluster.ping.replication.ShardReplicationPingRequest
 
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.ShardSearchFailure
 
toString() - Method in class org.elasticsearch.cluster.ClusterName
 
toString() - Method in class org.elasticsearch.cluster.node.DiscoveryNode
 
toString() - Method in class org.elasticsearch.cluster.routing.ImmutableShardRouting
 
toString() - Method in class org.elasticsearch.cluster.routing.RoutingTableValidation
 
toString() - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
 
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.fs.FsIndexShardGateway
 
toString() - Method in class org.elasticsearch.index.gateway.none.NoneIndexGateway
 
toString() - Method in class org.elasticsearch.index.Index
 
toString() - Method in class org.elasticsearch.index.mapper.ParsedDocument
 
toString() - Method in class org.elasticsearch.index.shard.ShardId
 
toString() - Method in class org.elasticsearch.indices.IndicesMemoryCleaner.MemoryCleanResult
 
toString() - Method in class org.elasticsearch.indices.IndicesMemoryCleaner.TranslogCleanResult
 
toString() - Method in class org.elasticsearch.monitor.jvm.DeadlockAnalyzer.Deadlock
 
toString() - Method in class org.elasticsearch.search.highlight.HighlightField
 
toString() - Method in class org.elasticsearch.search.SearchShardTarget
 
toString() - Method in class org.elasticsearch.util.collect.ForwardingObject
Returns the string representation generated by the delegate's toString method.
toString() - Method in class org.elasticsearch.util.collect.ImmutableBiMap
 
toString() - Method in class org.elasticsearch.util.collect.ImmutableCollection
 
toString() - Method in class org.elasticsearch.util.collect.ImmutableMap
 
toString() - Method in class org.elasticsearch.util.collect.ImmutableMultimap
 
toString() - Method in class org.elasticsearch.util.collect.ImmutableMultiset
 
toString(Iterable<?>) - Static method in class org.elasticsearch.util.collect.Iterables
Returns a string representation of iterable, with the format [e1, e2, ..., en].
toString(Iterator<?>) - Static method in class org.elasticsearch.util.collect.Iterators
Returns a string representation of iterator, with the format [e1, e2, ..., en].
toString() - Method in class org.elasticsearch.util.collect.LinkedListMultimap
Returns a string representation of the multimap, generated by calling toString on the map returned by Multimap.asMap().
toString() - Method in interface org.elasticsearch.util.collect.Multiset.Entry
Returns the canonical string representation of this entry, defined as follows.
toString() - Method in interface org.elasticsearch.util.collect.Multiset
toString() - Method in class org.elasticsearch.util.component.Lifecycle
 
toString() - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
toString() - Method in class org.elasticsearch.util.concurrent.highscalelib.ConcurrentAutoTable
Return the counter's long value converted to a string.
toString() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Returns a string representation of this map.
toString() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Returns a string representation of this map.
toString() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Returns a string representation of this map.
toString() - Method in class org.elasticsearch.util.concurrent.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 org.elasticsearch.util.concurrent.jsr166y.Phaser
Returns a string identifying this phaser, as well as its state.
toString() - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Returns a String representation of the list, front to back.
toString() - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Returns a String representation of the list, front to back.
toString() - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Returns a String representation of the list, front to back.
toString() - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.THashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.THashSet
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Returns a String representation of the list, front to back.
toString() - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Returns a String representation of the list, front to back.
toString() - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Returns a String representation of the list, front to back.
toString() - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
 
toString() - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
 
toString() - Method in class org.elasticsearch.util.inject.internal.BindingBuilder
 
toString() - Method in class org.elasticsearch.util.inject.internal.BindingImpl
 
toString() - Method in class org.elasticsearch.util.inject.internal.ConstantBindingBuilderImpl
 
toString() - Method in class org.elasticsearch.util.inject.internal.ExposedBindingImpl
 
toString() - Method in class org.elasticsearch.util.inject.internal.ExposureBuilder
 
toString() - Method in class org.elasticsearch.util.inject.internal.InstanceBindingImpl
 
toString() - Method in class org.elasticsearch.util.inject.internal.LinkedBindingImpl
 
toString() - Method in class org.elasticsearch.util.inject.internal.LinkedProviderBindingImpl
 
toString() - Method in class org.elasticsearch.util.inject.internal.MatcherAndConverter
 
toString() - Method in class org.elasticsearch.util.inject.internal.MoreTypes.GenericArrayTypeImpl
 
toString() - Method in class org.elasticsearch.util.inject.internal.MoreTypes.MemberImpl
 
toString() - Method in class org.elasticsearch.util.inject.internal.MoreTypes.ParameterizedTypeImpl
 
toString(Type) - Static method in class org.elasticsearch.util.inject.internal.MoreTypes
 
toString(Member) - Static method in class org.elasticsearch.util.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.util.inject.internal.MoreTypes.WildcardTypeImpl
 
toString() - Method in class org.elasticsearch.util.inject.internal.PrivateElementsImpl
 
toString() - Method in class org.elasticsearch.util.inject.internal.ProviderInstanceBindingImpl
 
toString() - Method in class org.elasticsearch.util.inject.internal.ToStringBuilder
 
toString() - Method in class org.elasticsearch.util.inject.internal.UntargettedBindingImpl
 
toString() - Method in class org.elasticsearch.util.inject.Key
 
toString() - Method in interface org.elasticsearch.util.inject.Scope
A short but useful description of this scope.
toString() - Method in class org.elasticsearch.util.inject.spi.Dependency
 
toString() - Method in class org.elasticsearch.util.inject.spi.InjectionPoint
 
toString() - Method in class org.elasticsearch.util.inject.spi.Message
 
toString() - Method in class org.elasticsearch.util.inject.TypeLiteral
 
toString() - Method in class org.elasticsearch.util.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.util.io.FastByteArrayOutputStream
Converts the buffer's contents into a string by decoding the bytes using the specified charsetName.
toString() - Method in class org.elasticsearch.util.io.FastCharArrayWriter
Converts input data to a string.
toString() - Method in class org.elasticsearch.util.io.FastStringReader
 
toString() - Method in class org.elasticsearch.util.io.StringBuilderWriter
Returns StringBuilder.toString().
toString() - Method in class org.elasticsearch.util.jline.ANSI.Buffer
 
toString() - Method in class org.elasticsearch.util.lucene.all.AllEntries
 
toString() - Method in class org.elasticsearch.util.lucene.all.AllTokenFilter
 
toString(String) - Method in class org.elasticsearch.util.lucene.search.CustomBoostFactorQuery
 
toString(String) - Method in class org.elasticsearch.util.lucene.search.MoreLikeThisQuery
 
toString() - Method in class org.elasticsearch.util.Percent
 
toString() - Method in class org.elasticsearch.util.SizeValue
 
toString() - Method in class org.elasticsearch.util.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.util.TimeValue
 
toString() - Method in class org.elasticsearch.util.transport.BoundTransportAddress
 
toString() - Method in class org.elasticsearch.util.transport.InetSocketTransportAddress
 
toString() - Method in class org.elasticsearch.util.transport.LocalTransportAddress
 
toString() - Method in class org.elasticsearch.util.UUID
Returns a String object representing this UUID.
toStringArray(Collection<String>) - Static method in class org.elasticsearch.util.Strings
Copy the given Collection into a String array.
toStringArray(Enumeration<String>) - Static method in class org.elasticsearch.util.Strings
Copy the given Enumeration into a String array.
ToStringBuilder - Class in org.elasticsearch.util.inject.internal
Helps with toString() methods.
ToStringBuilder(String) - Constructor for class org.elasticsearch.util.inject.internal.ToStringBuilder
 
ToStringBuilder(Class) - Constructor for class org.elasticsearch.util.inject.internal.ToStringBuilder
 
toStringFunction() - Static method in class org.elasticsearch.util.base.Functions
Returns a function that calls toString() on its argument.
toStringTrim() - Method in class org.elasticsearch.util.io.FastCharArrayWriter
Converts the input data to a string with trimmed whitespaces.
total() - Method in class org.elasticsearch.monitor.os.OsInfo.Mem
 
total() - Method in class org.elasticsearch.monitor.os.OsInfo.Swap
 
total() - Method in class org.elasticsearch.monitor.process.ProcessStats.Cpu
Get the Process cpu time (sum of User and Sys).
total() - Method in class org.elasticsearch.monitor.process.ProcessStats.Fd
Get the Total number of open file descriptors.
totalCores() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
totalFilesSize() - Method in exception org.elasticsearch.index.shard.recovery.RecoverFilesRecoveryException
 
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.
totalNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.IndexMetaData
 
totalNumberOfShards() - Method in class org.elasticsearch.cluster.metadata.MetaData
 
totalOps - Variable in class org.elasticsearch.action.search.type.TransportSearchTypeAction.BaseAsyncAction
 
totalShards() - Method in class org.elasticsearch.action.admin.cluster.ping.replication.IndexReplicationPingResponse
 
totalShards() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.IndexGatewaySnapshotResponse
The number of total shards the gateway snapshot operation was performed 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.
totalShards() - Method in class org.elasticsearch.indices.IndicesMemoryCleaner.MemoryCleanResult
 
totalShards() - Method in class org.elasticsearch.indices.IndicesMemoryCleaner.TranslogCleanResult
 
totalSize() - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
 
totalSize() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.RecoveryStatus.Index
 
totalSize() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.RecoveryStatus.Translog
 
totalSize() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.SnapshotStatus.Index
 
totalSizeActive() - Method in class org.elasticsearch.cluster.routing.GroupShardsIterator
 
totalSockets() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
totalTime() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.SnapshotStatus
 
totalTime() - Method in class org.elasticsearch.util.StopWatch
Return the total time for all tasks.
totalVirtual() - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
touchFile(String) - Method in class org.elasticsearch.index.store.memory.ByteBufferDirectory
 
touchFile(String) - Method in class org.elasticsearch.index.store.memory.HeapDirectory
 
touchFile(String) - Method in class org.elasticsearch.util.lucene.store.SwitchDirectory
 
toUnderscoreCase(String) - Static method in class org.elasticsearch.util.Strings
 
toUnderscoreCase(String, StringBuilder) - Static method in class org.elasticsearch.util.Strings
 
toUnlinkedArray() - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
Copies the list to a native array, destroying the next/previous links as the copy is made.
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.action.search.SearchResponse
 
toXContent(IndexMetaData, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
toXContent(MetaData) - Static method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
toXContent(MetaData, XContentBuilder, ToXContent.Params) - Static method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBinaryFieldMapper
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper
 
toXContent(XContentBuilder, ToXContent.Params, XContentMapper...) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.BaseFilterBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.index.query.xcontent.BaseQueryBuilder
 
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.builder.SearchSourceFacetsBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.builder.SearchSourceHighlightBuilder
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facets.CountFacet
 
toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.search.facets.Facets
 
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.threadpool.ThreadPoolInfo
 
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 - Interface in org.elasticsearch.util.xcontent
An interface allowing to transfer an object to "XContent" using an XContentBuilder.
toXContent(XContentBuilder, ToXContent.Params) - Method in interface org.elasticsearch.util.xcontent.ToXContent
 
ToXContent.MapParams - Class in org.elasticsearch.util.xcontent
 
ToXContent.MapParams(Map<String, String>) - Constructor for class org.elasticsearch.util.xcontent.ToXContent.MapParams
 
ToXContent.Params - Interface in org.elasticsearch.util.xcontent
 
TPrimitiveHash - Class in org.elasticsearch.util.gnu.trove
The base class for hashtables of primitive values.
TPrimitiveHash() - Constructor for class org.elasticsearch.util.gnu.trove.TPrimitiveHash
Creates a new THash instance with the default capacity and load factor.
TPrimitiveHash(int) - Constructor for class org.elasticsearch.util.gnu.trove.TPrimitiveHash
Creates a new TPrimitiveHash instance with a prime capacity at or near the specified capacity and with the default load factor.
TPrimitiveHash(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TPrimitiveHash
Creates a new TPrimitiveHash instance with a prime capacity at or near the minimum needed to hold initialCapacity elements with load factor loadFactor without triggering a rehash.
trace(String, Object...) - Method in interface org.elasticsearch.util.logging.ESLogger
Logs a DEBUG level message.
trace(String, Throwable, Object...) - Method in interface org.elasticsearch.util.logging.ESLogger
Logs a DEBUG level message.
trace(String, Object...) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
trace(String, Throwable, Object...) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
transfer(E) - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
Transfers the element to a consumer, waiting if necessary to do so.
transfer(E) - Method in interface org.elasticsearch.util.concurrent.jsr166y.TransferQueue
Transfers the element to a consumer, waiting if necessary to do so.
TransferQueue<E> - Interface in org.elasticsearch.util.concurrent.jsr166y
A BlockingQueue in which producers may wait for consumers to receive elements.
transform(Collection<F>, Function<? super F, T>) - Static method in class org.elasticsearch.util.collect.Collections2
Returns a collection that applies function to each element of fromCollection.
transform(Iterable<F>, Function<? super F, ? extends T>) - Static method in class org.elasticsearch.util.collect.Iterables
Returns an iterable that applies function to each element of fromIterable.
transform(Iterator<F>, Function<? super F, ? extends T>) - Static method in class org.elasticsearch.util.collect.Iterators
Returns an iterator that applies function to each element of fromIterator.
transform(List<F>, Function<? super F, ? extends T>) - Static method in class org.elasticsearch.util.collect.Lists
Returns a list that applies function to each element of fromList.
transformValues(Map<K, V1>, Function<? super V1, V2>) - Static method in class org.elasticsearch.util.collect.Maps
Returns a view of a map where each value is transformed by a function.
transformValues(TByteFunction) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Transform each value in the list using the specified function.
transformValues(TByteFunction) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
Transform the values in this map using function.
transformValues(TDoubleFunction) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
Transform the values in this map using function.
transformValues(TFloatFunction) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
Transform the values in this map using function.
transformValues(TIntFunction) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
Transform the values in this map using function.
transformValues(TLongFunction) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
Transform the values in this map using function.
transformValues(TObjectFunction<V, V>) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
Transform the values in this map using function.
transformValues(TShortFunction) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
Transform the values in this map using function.
transformValues(TDoubleFunction) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Transform each value in the list using the specified function.
transformValues(TByteFunction) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
Transform the values in this map using function.
transformValues(TDoubleFunction) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
Transform the values in this map using function.
transformValues(TFloatFunction) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
Transform the values in this map using function.
transformValues(TIntFunction) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
Transform the values in this map using function.
transformValues(TLongFunction) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
Transform the values in this map using function.
transformValues(TObjectFunction<V, V>) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
Transform the values in this map using function.
transformValues(TShortFunction) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
Transform the values in this map using function.
transformValues(TFloatFunction) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Transform each value in the list using the specified function.
transformValues(TByteFunction) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
Transform the values in this map using function.
transformValues(TDoubleFunction) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
Transform the values in this map using function.
transformValues(TFloatFunction) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
Transform the values in this map using function.
transformValues(TIntFunction) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
Transform the values in this map using function.
transformValues(TLongFunction) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
Transform the values in this map using function.
transformValues(TObjectFunction<V, V>) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
Transform the values in this map using function.
transformValues(TShortFunction) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
Transform the values in this map using function.
transformValues(TObjectFunction<V, V>) - Method in class org.elasticsearch.util.gnu.trove.THashMap
Transform the values in this map using function.
transformValues(TIntFunction) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Transform each value in the list using the specified function.
transformValues(TByteFunction) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
Transform the values in this map using function.
transformValues(TDoubleFunction) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
Transform the values in this map using function.
transformValues(TFloatFunction) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
Transform the values in this map using function.
transformValues(TIntFunction) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
Transform the values in this map using function.
transformValues(TLongFunction) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
Transform the values in this map using function.
transformValues(TObjectFunction<V, V>) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
Transform the values in this map using function.
transformValues(TShortFunction) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
Transform the values in this map using function.
transformValues(TLongFunction) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Transform each value in the list using the specified function.
transformValues(TByteFunction) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
Transform the values in this map using function.
transformValues(TDoubleFunction) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
Transform the values in this map using function.
transformValues(TFloatFunction) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
Transform the values in this map using function.
transformValues(TIntFunction) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
Transform the values in this map using function.
transformValues(TLongFunction) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
Transform the values in this map using function.
transformValues(TObjectFunction<V, V>) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
Transform the values in this map using function.
transformValues(TShortFunction) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
Transform the values in this map using function.
transformValues(TByteFunction) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
Transform the values in this map using function.
transformValues(TDoubleFunction) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
Transform the values in this map using function.
transformValues(TFloatFunction) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
Transform the values in this map using function.
transformValues(TIntFunction) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
Transform the values in this map using function.
transformValues(TLongFunction) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
Transform the values in this map using function.
transformValues(TShortFunction) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
Transform the values in this map using function.
transformValues(TShortFunction) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Transform each value in the list using the specified function.
transformValues(TByteFunction) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Transform the values in this map using function.
transformValues(TDoubleFunction) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Transform the values in this map using function.
transformValues(TFloatFunction) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Transform the values in this map using function.
transformValues(TIntFunction) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Transform the values in this map using function.
transformValues(TLongFunction) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Transform the values in this map using function.
transformValues(TObjectFunction<V, V>) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Transform the values in this map using function.
transformValues(TShortFunction) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Transform the values in this map using function.
translog() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.RecoveryStatus
 
translog() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.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(byte[], 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.Operation - Interface in org.elasticsearch.index.translog
A generic interface representing an operation perfomed 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.
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
 
translogId() - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
translogId() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.RecoveryStatus.Translog
The translog id recovered, -1 indicating no translog.
translogId() - Method in class org.elasticsearch.index.translog.memory.MemorySnapshot
 
translogId() - Method in interface org.elasticsearch.index.translog.Translog.Snapshot
The id of the translog the snapshot was taken with.
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
 
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.stats.NodeStats
 
Transport - Interface in org.elasticsearch.transport
 
Transport.Helper - Class in org.elasticsearch.transport
 
Transport.Helper() - Constructor for class org.elasticsearch.transport.Transport.Helper
 
TRANSPORT_TYPE - Static variable in class org.elasticsearch.transport.Transport.Helper
 
transportAction() - Method in class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
 
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.ping.broadcast.TransportBroadcastPingAction
 
transportAction() - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportIndexReplicationPingAction
 
transportAction() - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportReplicationPingAction
 
transportAction() - Method in class org.elasticsearch.action.admin.cluster.ping.replication.TransportShardReplicationPingAction
 
transportAction() - Method in class org.elasticsearch.action.admin.cluster.ping.single.TransportSinglePingAction
 
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.cache.clear.TransportClearIndicesCacheAction
 
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.flush.TransportFlushAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportGatewaySnapshotAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportIndexGatewaySnapshotAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportShardGatewaySnapshotAction
 
transportAction() - Method in class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
 
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.status.TransportIndicesStatusAction
 
transportAction() - Method in class org.elasticsearch.action.count.TransportCountAction
 
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.get.TransportGetAction
 
transportAction() - Method in class org.elasticsearch.action.index.TransportIndexAction
 
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.TransportSingleOperationAction
 
transportAction() - Method in class org.elasticsearch.action.terms.TransportTermsAction
 
transportAction() - Method in class org.elasticsearch.cluster.action.index.MappingUpdatedAction
 
TransportActionModule - Class in org.elasticsearch.action
 
TransportActionModule() - Constructor for class org.elasticsearch.action.TransportActionModule
 
TransportActions - Class in org.elasticsearch.action
 
TransportActions() - Constructor for class org.elasticsearch.action.TransportActions
 
TransportActions.Admin - Class in org.elasticsearch.action
 
TransportActions.Admin() - Constructor for class org.elasticsearch.action.TransportActions.Admin
 
TransportActions.Admin.Cluster - Class in org.elasticsearch.action
 
TransportActions.Admin.Cluster() - Constructor for class org.elasticsearch.action.TransportActions.Admin.Cluster
 
TransportActions.Admin.Cluster.Node - Class in org.elasticsearch.action
 
TransportActions.Admin.Cluster.Node() - Constructor for class org.elasticsearch.action.TransportActions.Admin.Cluster.Node
 
TransportActions.Admin.Cluster.Ping - Class in org.elasticsearch.action
 
TransportActions.Admin.Cluster.Ping() - Constructor for class org.elasticsearch.action.TransportActions.Admin.Cluster.Ping
 
TransportActions.Admin.Indices - Class in org.elasticsearch.action
 
TransportActions.Admin.Indices() - Constructor for class org.elasticsearch.action.TransportActions.Admin.Indices
 
TransportActions.Admin.Indices.Cache - Class in org.elasticsearch.action
 
TransportActions.Admin.Indices.Cache() - Constructor for class org.elasticsearch.action.TransportActions.Admin.Indices.Cache
 
TransportActions.Admin.Indices.Gateway - Class in org.elasticsearch.action
 
TransportActions.Admin.Indices.Gateway() - Constructor for class org.elasticsearch.action.TransportActions.Admin.Indices.Gateway
 
TransportActions.Admin.Indices.Mapping - Class in org.elasticsearch.action
 
TransportActions.Admin.Indices.Mapping() - Constructor for class org.elasticsearch.action.TransportActions.Admin.Indices.Mapping
 
TransportAddress - Interface in org.elasticsearch.util.transport
 
transportAddresses() - Method in class org.elasticsearch.client.transport.TransportClient
Returns the current registered transport addresses to use (added using TransportClient.addTransportAddress(org.elasticsearch.util.transport.TransportAddress).
transportAddresses() - Method in class org.elasticsearch.client.transport.TransportClientNodesService
 
TransportAddressSerializers - Class in org.elasticsearch.util.transport
A global registry of all different types of TransportAddress allowing to perform serialization of them.
TransportAddressSerializers() - Constructor for class org.elasticsearch.util.transport.TransportAddressSerializers
 
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, IndicesService) - Constructor for class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
TransportBroadcastPingAction - Class in org.elasticsearch.action.admin.cluster.ping.broadcast
 
TransportBroadcastPingAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService) - Constructor for class org.elasticsearch.action.admin.cluster.ping.broadcast.TransportBroadcastPingAction
 
TransportChannel - Interface in org.elasticsearch.transport
 
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.util.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, 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/).
TransportClientClusterModule - Class in org.elasticsearch.client.transport
 
TransportClientClusterModule(Settings) - Constructor for class org.elasticsearch.client.transport.TransportClientClusterModule
 
TransportClientClusterService - Class in org.elasticsearch.client.transport
 
TransportClientClusterService(Settings, ClusterService, TransportClientNodesService, DiscoveryService) - Constructor for class org.elasticsearch.client.transport.TransportClientClusterService
 
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
 
TransportClusterHealthAction - Class in org.elasticsearch.action.admin.cluster.health
 
TransportClusterHealthAction(Settings, TransportService, ClusterService, ThreadPool, TimerService, ClusterName) - Constructor for class org.elasticsearch.action.admin.cluster.health.TransportClusterHealthAction
 
TransportClusterStateAction - Class in org.elasticsearch.action.admin.cluster.state
 
TransportClusterStateAction(Settings, TransportService, ClusterService, ThreadPool) - Constructor for class org.elasticsearch.action.admin.cluster.state.TransportClusterStateAction
 
TransportConnectionListener - Interface in org.elasticsearch.transport
 
TransportCountAction - Class in org.elasticsearch.action.count
 
TransportCountAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService) - 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, MetaDataService) - 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) - 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, MetaDataService) - Constructor for class org.elasticsearch.action.admin.indices.delete.TransportDeleteIndexAction
 
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
 
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, TransportService, ClusterService, ThreadPool, TransportIndexGatewaySnapshotAction) - 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
 
TransportIndexDeleteByQueryAction - Class in org.elasticsearch.action.deletebyquery
 
TransportIndexDeleteByQueryAction(Settings, ClusterService, TransportService, IndicesService, ThreadPool, TransportShardDeleteByQueryAction) - Constructor for class org.elasticsearch.action.deletebyquery.TransportIndexDeleteByQueryAction
 
TransportIndexGatewaySnapshotAction - Class in org.elasticsearch.action.admin.indices.gateway.snapshot
 
TransportIndexGatewaySnapshotAction(Settings, ClusterService, TransportService, ThreadPool, TransportShardGatewaySnapshotAction) - Constructor for class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportIndexGatewaySnapshotAction
 
TransportIndexReplicationOperationAction<Request extends IndexReplicationOperationRequest,Response extends ActionResponse,ShardRequest extends ShardReplicationOperationRequest,ShardResponse extends ActionResponse> - Class in org.elasticsearch.action.support.replication
 
TransportIndexReplicationOperationAction(Settings, TransportService, ThreadPool, TransportShardReplicationOperationAction<ShardRequest, ShardResponse>) - Constructor for class org.elasticsearch.action.support.replication.TransportIndexReplicationOperationAction
 
TransportIndexReplicationPingAction - Class in org.elasticsearch.action.admin.cluster.ping.replication
 
TransportIndexReplicationPingAction(Settings, ClusterService, TransportService, ThreadPool, TransportShardReplicationPingAction) - Constructor for class org.elasticsearch.action.admin.cluster.ping.replication.TransportIndexReplicationPingAction
 
TransportIndicesAliasesAction - Class in org.elasticsearch.action.admin.indices.alias
 
TransportIndicesAliasesAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataService) - Constructor for class org.elasticsearch.action.admin.indices.alias.TransportIndicesAliasesAction
 
TransportIndicesReplicationOperationAction<Request extends IndicesReplicationOperationRequest,Response extends ActionResponse,IndexRequest extends IndexReplicationOperationRequest,IndexResponse extends ActionResponse,ShardRequest extends ShardReplicationOperationRequest,ShardResponse extends ActionResponse> - Class in org.elasticsearch.action.support.replication
 
TransportIndicesReplicationOperationAction(Settings, TransportService, ClusterService, ThreadPool, TransportIndexReplicationOperationAction<IndexRequest, IndexResponse, ShardRequest, ShardResponse>) - Constructor for class org.elasticsearch.action.support.replication.TransportIndicesReplicationOperationAction
 
TransportIndicesStatusAction - Class in org.elasticsearch.action.admin.indices.status
 
TransportIndicesStatusAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService) - 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
 
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, TransportSearchAction, TransportGetAction, ClusterService, IndicesService, TransportService) - Constructor for class org.elasticsearch.action.mlt.TransportMoreLikeThisAction
 
transportNodeAction() - Method in class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
 
transportNodeAction() - Method in class org.elasticsearch.action.admin.cluster.node.restart.TransportNodesRestartAction
 
transportNodeAction() - Method in class org.elasticsearch.action.admin.cluster.node.shutdown.TransportNodesShutdownAction
 
transportNodeAction() - Method in class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
 
transportNodeAction() - Method in class org.elasticsearch.action.support.nodes.TransportNodesOperationAction
 
TransportNodesInfoAction - Class in org.elasticsearch.action.admin.cluster.node.info
 
TransportNodesInfoAction(Settings, ClusterName, ThreadPool, ClusterService, TransportService, MonitorService) - Constructor for class org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction
 
TransportNodesInfoAction.NodeInfoRequest - Class in org.elasticsearch.action.admin.cluster.node.info
 
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, ClusterName, ThreadPool, ClusterService, TransportService, Node) - Constructor for class org.elasticsearch.action.admin.cluster.node.shutdown.TransportNodesShutdownAction
 
TransportNodesShutdownAction.NodeShutdownRequest - Class in org.elasticsearch.action.admin.cluster.node.shutdown
 
TransportNodesStatsAction - Class in org.elasticsearch.action.admin.cluster.node.stats
 
TransportNodesStatsAction(Settings, ClusterName, ThreadPool, ClusterService, TransportService, MonitorService) - Constructor for class org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction
 
TransportNodesStatsAction.NodeStatsRequest - Class in org.elasticsearch.action.admin.cluster.node.stats
 
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
 
TransportPutMappingAction - Class in org.elasticsearch.action.admin.indices.mapping.put
Put mapping action.
TransportPutMappingAction(Settings, TransportService, ClusterService, ThreadPool, MetaDataService) - Constructor for class org.elasticsearch.action.admin.indices.mapping.put.TransportPutMappingAction
 
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
 
TransportReplicationPingAction - Class in org.elasticsearch.action.admin.cluster.ping.replication
 
TransportReplicationPingAction(Settings, TransportService, ClusterService, ThreadPool, TransportIndexReplicationPingAction) - Constructor for class org.elasticsearch.action.admin.cluster.ping.replication.TransportReplicationPingAction
 
TransportRequestHandler<T extends Streamable> - Interface in org.elasticsearch.transport
 
TransportResponseHandler<T extends Streamable> - Interface in org.elasticsearch.transport
 
TransportSearchAction - Class in org.elasticsearch.action.search
 
TransportSearchAction(Settings, TransportService, TransportSearchDfsQueryThenFetchAction, TransportSearchQueryThenFetchAction, TransportSearchDfsQueryAndFetchAction, TransportSearchQueryAndFetchAction) - 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
 
TransportSearchDfsQueryAndFetchAction - Class in org.elasticsearch.action.search.type
 
TransportSearchDfsQueryAndFetchAction(Settings, ThreadPool, ClusterService, IndicesService, TransportSearchCache, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchDfsQueryAndFetchAction
 
TransportSearchDfsQueryThenFetchAction - Class in org.elasticsearch.action.search.type
 
TransportSearchDfsQueryThenFetchAction(Settings, ThreadPool, ClusterService, IndicesService, TransportSearchCache, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchDfsQueryThenFetchAction
 
TransportSearchHelper - Class in org.elasticsearch.action.search.type
 
TransportSearchQueryAndFetchAction - Class in org.elasticsearch.action.search.type
 
TransportSearchQueryAndFetchAction(Settings, ThreadPool, ClusterService, IndicesService, TransportSearchCache, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchQueryAndFetchAction
 
TransportSearchQueryThenFetchAction - Class in org.elasticsearch.action.search.type
 
TransportSearchQueryThenFetchAction(Settings, ThreadPool, ClusterService, IndicesService, TransportSearchCache, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchQueryThenFetchAction
 
TransportSearchScrollAction - Class in org.elasticsearch.action.search
 
TransportSearchScrollAction(Settings, TransportService, TransportSearchScrollQueryThenFetchAction, TransportSearchScrollQueryAndFetchAction) - 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
 
TransportSearchTypeAction - Class in org.elasticsearch.action.search.type
 
TransportSearchTypeAction(Settings, ThreadPool, ClusterService, IndicesService, TransportSearchCache, SearchServiceTransportAction, SearchPhaseController) - Constructor for class org.elasticsearch.action.search.type.TransportSearchTypeAction
 
TransportSearchTypeAction.BaseAsyncAction<FirstResult> - 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.TransportSingleOperationAction
 
transportService - Variable in class org.elasticsearch.client.transport.action.support.BaseClientTransportAction
 
TransportService - Class in org.elasticsearch.transport
 
TransportService(Transport, ThreadPool, TimerService) - Constructor for class org.elasticsearch.transport.TransportService
 
TransportService(Settings, Transport, ThreadPool, TimerService) - 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
 
transportShardAction() - Method in class org.elasticsearch.action.admin.cluster.ping.broadcast.TransportBroadcastPingAction
 
transportShardAction() - Method in class org.elasticsearch.action.admin.cluster.ping.single.TransportSinglePingAction
 
transportShardAction() - Method in class org.elasticsearch.action.admin.indices.cache.clear.TransportClearIndicesCacheAction
 
transportShardAction() - Method in class org.elasticsearch.action.admin.indices.flush.TransportFlushAction
 
transportShardAction() - Method in class org.elasticsearch.action.admin.indices.optimize.TransportOptimizeAction
 
transportShardAction() - Method in class org.elasticsearch.action.admin.indices.refresh.TransportRefreshAction
 
transportShardAction() - Method in class org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction
 
transportShardAction() - Method in class org.elasticsearch.action.count.TransportCountAction
 
transportShardAction() - Method in class org.elasticsearch.action.get.TransportGetAction
 
transportShardAction() - Method in class org.elasticsearch.action.support.broadcast.TransportBroadcastOperationAction
 
transportShardAction() - Method in class org.elasticsearch.action.support.single.TransportSingleOperationAction
 
transportShardAction() - Method in class org.elasticsearch.action.terms.TransportTermsAction
 
TransportShardDeleteByQueryAction - Class in org.elasticsearch.action.deletebyquery
 
TransportShardDeleteByQueryAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction) - Constructor for class org.elasticsearch.action.deletebyquery.TransportShardDeleteByQueryAction
 
TransportShardGatewaySnapshotAction - Class in org.elasticsearch.action.admin.indices.gateway.snapshot
 
TransportShardGatewaySnapshotAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction) - Constructor for class org.elasticsearch.action.admin.indices.gateway.snapshot.TransportShardGatewaySnapshotAction
 
TransportShardReplicationOperationAction<Request extends ShardReplicationOperationRequest,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.ShardOperationRequest - Class in org.elasticsearch.action.support.replication
 
TransportShardReplicationOperationAction.ShardOperationRequest() - Constructor for class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.ShardOperationRequest
 
TransportShardReplicationOperationAction.ShardOperationRequest(int, Request) - Constructor for class org.elasticsearch.action.support.replication.TransportShardReplicationOperationAction.ShardOperationRequest
 
TransportShardReplicationPingAction - Class in org.elasticsearch.action.admin.cluster.ping.replication
 
TransportShardReplicationPingAction(Settings, TransportService, ClusterService, IndicesService, ThreadPool, ShardStateAction) - Constructor for class org.elasticsearch.action.admin.cluster.ping.replication.TransportShardReplicationPingAction
 
TransportSingleOperationAction<Request extends SingleOperationRequest,Response extends ActionResponse> - Class in org.elasticsearch.action.support.single
 
TransportSingleOperationAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService) - Constructor for class org.elasticsearch.action.support.single.TransportSingleOperationAction
 
TransportSingleOperationAction.ShardSingleOperationRequest - Class in org.elasticsearch.action.support.single
 
TransportSingleOperationAction.ShardSingleOperationRequest(Request, int) - Constructor for class org.elasticsearch.action.support.single.TransportSingleOperationAction.ShardSingleOperationRequest
 
TransportSinglePingAction - Class in org.elasticsearch.action.admin.cluster.ping.single
 
TransportSinglePingAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService) - Constructor for class org.elasticsearch.action.admin.cluster.ping.single.TransportSinglePingAction
 
TransportStats - Class in org.elasticsearch.transport
 
TransportStats(long, long, long, long) - Constructor for class org.elasticsearch.transport.TransportStats
 
TransportTermsAction - Class in org.elasticsearch.action.terms
 
TransportTermsAction(Settings, ThreadPool, ClusterService, TransportService, IndicesService) - Constructor for class org.elasticsearch.action.terms.TransportTermsAction
 
traverse(FieldMapperListener) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
traverse(FieldMapperListener) - Method in interface org.elasticsearch.index.mapper.xcontent.XContentMapper
 
traverse(FieldMapperListener) - Method in class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper
 
traverse(FieldMapperListener) - Method in class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper
 
TreeMultimap<K,V> - Class in org.elasticsearch.util.collect
Implementation of Multimap whose keys and values are ordered by their natural ordering or by supplied comparators.
TreeMultiset<E> - Class in org.elasticsearch.util.collect
A multiset which maintains the ordering of its elements, according to either their natural order or an explicit Comparator.
trimAllWhitespace(String) - Static method in class org.elasticsearch.util.Strings
Trim all whitespace from the given String: leading, trailing, and inbetween characters.
trimArrayElements(String[]) - Static method in class org.elasticsearch.util.Strings
Trim the elements of the given String array, calling String.trim() on each of them.
trimLeadingCharacter(String, char) - Static method in class org.elasticsearch.util.Strings
Trim all occurences of the supplied leading character from the given String.
trimLeadingWhitespace(String) - Static method in class org.elasticsearch.util.Strings
Trim leading whitespace from the given String.
trimToSize() - Method in class org.elasticsearch.util.collect.ArrayListMultimap
Reduces the memory used by this ArrayListMultimap, if feasible.
trimToSize() - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
Sheds any excess capacity above and beyond the current size of the list.
trimToSize() - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
Sheds any excess capacity above and beyond the current size of the list.
trimToSize() - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
Sheds any excess capacity above and beyond the current size of the list.
trimToSize() - Method in class org.elasticsearch.util.gnu.trove.THash
This simply calls compact.
trimToSize() - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
Sheds any excess capacity above and beyond the current size of the list.
trimToSize() - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
Sheds any excess capacity above and beyond the current size of the list.
trimToSize() - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
Sheds any excess capacity above and beyond the current size of the list.
trimTrailingCharacter(String, char) - Static method in class org.elasticsearch.util.Strings
Trim all occurences of the supplied trailing character from the given String.
trimTrailingWhitespace(String) - Static method in class org.elasticsearch.util.Strings
Trim trailing whitespace from the given String.
trimWhitespace(String) - Static method in class org.elasticsearch.util.Strings
Trim leading and trailing whitespace from the given String.
tryRecovery(ShardId, String) - Method in class org.elasticsearch.indices.recovery.throttler.RecoveryThrottler
 
tryStream(ShardId, String) - Method in class org.elasticsearch.indices.recovery.throttler.RecoveryThrottler
 
tryTransfer(E) - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
Transfers the element to a waiting consumer immediately, if possible.
tryTransfer(E, long, TimeUnit) - Method in class org.elasticsearch.util.concurrent.jsr166y.LinkedTransferQueue
Transfers the element to a consumer if it is possible to do so before the timeout elapses.
tryTransfer(E) - Method in interface org.elasticsearch.util.concurrent.jsr166y.TransferQueue
Transfers the element to a waiting consumer immediately, if possible.
tryTransfer(E, long, TimeUnit) - Method in interface org.elasticsearch.util.concurrent.jsr166y.TransferQueue
Transfers the element to a consumer if it is possible to do so before the timeout elapses.
tryUnfork() - Method in class org.elasticsearch.util.concurrent.jsr166y.ForkJoinTask
Tries to unschedule this task for execution.
TShortArrayList - Class in org.elasticsearch.util.gnu.trove
A resizable, array-backed list of short primitives.
TShortArrayList() - Constructor for class org.elasticsearch.util.gnu.trove.TShortArrayList
Creates a new TShortArrayList instance with the default capacity.
TShortArrayList(int) - Constructor for class org.elasticsearch.util.gnu.trove.TShortArrayList
Creates a new TShortArrayList instance with the specified capacity.
TShortArrayList(short[]) - Constructor for class org.elasticsearch.util.gnu.trove.TShortArrayList
Creates a new TShortArrayList instance whose capacity is the greater of the length of values and DEFAULT_CAPACITY and whose initial contents are the specified values.
TShortByteHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for short keys and byte values.
TShortByteHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Creates a new TShortByteHashMap instance with the default capacity and load factor.
TShortByteHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Creates a new TShortByteHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TShortByteHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Creates a new TShortByteHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TShortByteHashMap(TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Creates a new TShortByteHashMap instance with the default capacity and load factor.
TShortByteHashMap(int, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Creates a new TShortByteHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TShortByteHashMap(int, float, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortByteHashMap
Creates a new TShortByteHashMap instance with a prime value at or near the specified capacity and load factor.
TShortByteHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TShortByteHashMap conform to the java.util.Map API.
TShortByteHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TShortByteHashMapDecorator(TShortByteHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TShortByteIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type short and byte.
TShortByteIterator(TShortByteHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TShortByteIterator
Creates an iterator over the specified map
TShortByteProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type short and byte.
TShortDoubleHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for short keys and double values.
TShortDoubleHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Creates a new TShortDoubleHashMap instance with the default capacity and load factor.
TShortDoubleHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Creates a new TShortDoubleHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TShortDoubleHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Creates a new TShortDoubleHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TShortDoubleHashMap(TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Creates a new TShortDoubleHashMap instance with the default capacity and load factor.
TShortDoubleHashMap(int, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Creates a new TShortDoubleHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TShortDoubleHashMap(int, float, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
Creates a new TShortDoubleHashMap instance with a prime value at or near the specified capacity and load factor.
TShortDoubleHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TShortDoubleHashMap conform to the java.util.Map API.
TShortDoubleHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TShortDoubleHashMapDecorator(TShortDoubleHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TShortDoubleIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type short and double.
TShortDoubleIterator(TShortDoubleHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TShortDoubleIterator
Creates an iterator over the specified map
TShortDoubleProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type short and double.
TShortFloatHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for short keys and float values.
TShortFloatHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Creates a new TShortFloatHashMap instance with the default capacity and load factor.
TShortFloatHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Creates a new TShortFloatHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TShortFloatHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Creates a new TShortFloatHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TShortFloatHashMap(TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Creates a new TShortFloatHashMap instance with the default capacity and load factor.
TShortFloatHashMap(int, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Creates a new TShortFloatHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TShortFloatHashMap(int, float, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
Creates a new TShortFloatHashMap instance with a prime value at or near the specified capacity and load factor.
TShortFloatHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TShortFloatHashMap conform to the java.util.Map API.
TShortFloatHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TShortFloatHashMapDecorator(TShortFloatHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TShortFloatIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type short and float.
TShortFloatIterator(TShortFloatHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TShortFloatIterator
Creates an iterator over the specified map
TShortFloatProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type short and float.
TShortFunction - Interface in org.elasticsearch.util.gnu.trove
Interface for functions that accept and return one short primitive.
TShortHash - Class in org.elasticsearch.util.gnu.trove
An open addressed hashing implementation for short primitives.
TShortHash() - Constructor for class org.elasticsearch.util.gnu.trove.TShortHash
Creates a new TShortHash instance with the default capacity and load factor.
TShortHash(int) - Constructor for class org.elasticsearch.util.gnu.trove.TShortHash
Creates a new TShortHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TShortHash(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TShortHash
Creates a new TShortHash instance with a prime value at or near the specified capacity and load factor.
TShortHash(TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortHash
Creates a new TShortHash instance with the default capacity and load factor.
TShortHash(int, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortHash
Creates a new TShortHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TShortHash(int, float, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortHash
Creates a new TShortHash instance with a prime value at or near the specified capacity and load factor.
TShortHashingStrategy - Interface in org.elasticsearch.util.gnu.trove
Interface to support pluggable hashing strategies in maps and sets.
TShortHashSet - Class in org.elasticsearch.util.gnu.trove
An open addressed set implementation for short primitives.
TShortHashSet() - Constructor for class org.elasticsearch.util.gnu.trove.TShortHashSet
Creates a new TShortHashSet instance with the default capacity and load factor.
TShortHashSet(int) - Constructor for class org.elasticsearch.util.gnu.trove.TShortHashSet
Creates a new TShortHashSet instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TShortHashSet(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TShortHashSet
Creates a new TShortHashSet instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TShortHashSet(short[]) - Constructor for class org.elasticsearch.util.gnu.trove.TShortHashSet
Creates a new TShortHashSet instance containing the elements of array.
TShortHashSet(TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortHashSet
Creates a new TShortHash instance with the default capacity and load factor.
TShortHashSet(int, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortHashSet
Creates a new TShortHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TShortHashSet(int, float, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortHashSet
Creates a new TShortHash instance with a prime value at or near the specified capacity and load factor.
TShortHashSet(short[], TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortHashSet
Creates a new TShortHashSet instance containing the elements of array.
TShortHashSetDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TShortHashSet conform to the java.util.Set API.
TShortHashSetDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TShortHashSetDecorator
FOR EXTERNALIZATION ONLY!!
TShortHashSetDecorator(TShortHashSet) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TShortHashSetDecorator
Creates a wrapper that decorates the specified primitive set.
TShortIntHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for short keys and int values.
TShortIntHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Creates a new TShortIntHashMap instance with the default capacity and load factor.
TShortIntHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Creates a new TShortIntHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TShortIntHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Creates a new TShortIntHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TShortIntHashMap(TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Creates a new TShortIntHashMap instance with the default capacity and load factor.
TShortIntHashMap(int, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Creates a new TShortIntHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TShortIntHashMap(int, float, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortIntHashMap
Creates a new TShortIntHashMap instance with a prime value at or near the specified capacity and load factor.
TShortIntHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TShortIntHashMap conform to the java.util.Map API.
TShortIntHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TShortIntHashMapDecorator(TShortIntHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TShortIntIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type short and int.
TShortIntIterator(TShortIntHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TShortIntIterator
Creates an iterator over the specified map
TShortIntProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type short and int.
TShortIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for short collections.
TShortIterator(TShortHash) - Constructor for class org.elasticsearch.util.gnu.trove.TShortIterator
Creates a TShortIterator for the elements in the specified collection.
TShortLongHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for short keys and long values.
TShortLongHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Creates a new TShortLongHashMap instance with the default capacity and load factor.
TShortLongHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Creates a new TShortLongHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TShortLongHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Creates a new TShortLongHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TShortLongHashMap(TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Creates a new TShortLongHashMap instance with the default capacity and load factor.
TShortLongHashMap(int, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Creates a new TShortLongHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TShortLongHashMap(int, float, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortLongHashMap
Creates a new TShortLongHashMap instance with a prime value at or near the specified capacity and load factor.
TShortLongHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TShortLongHashMap conform to the java.util.Map API.
TShortLongHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TShortLongHashMapDecorator(TShortLongHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TShortLongIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type short and long.
TShortLongIterator(TShortLongHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TShortLongIterator
Creates an iterator over the specified map
TShortLongProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type short and long.
TShortObjectHashMap<V> - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for short keys and Object values.
TShortObjectHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Creates a new TShortObjectHashMap instance with the default capacity and load factor.
TShortObjectHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Creates a new TShortObjectHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TShortObjectHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Creates a new TShortObjectHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TShortObjectHashMap(TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Creates a new TShortObjectHashMap instance with the default capacity and load factor.
TShortObjectHashMap(int, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Creates a new TShortObjectHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TShortObjectHashMap(int, float, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
Creates a new TShortObjectHashMap instance with a prime value at or near the specified capacity and load factor.
TShortObjectHashMapDecorator<V> - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TShortObjectHashMap conform to the java.util.Map API.
TShortObjectHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TShortObjectHashMapDecorator(TShortObjectHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TShortObjectIterator<V> - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type short and Object.
TShortObjectIterator(TShortObjectHashMap<V>) - Constructor for class org.elasticsearch.util.gnu.trove.TShortObjectIterator
Creates an iterator over the specified map
TShortObjectProcedure<T> - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type short and Object.
TShortProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures with one short parameter.
TShortShortHashMap - Class in org.elasticsearch.util.gnu.trove
An open addressed Map implementation for short keys and short values.
TShortShortHashMap() - Constructor for class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Creates a new TShortShortHashMap instance with the default capacity and load factor.
TShortShortHashMap(int) - Constructor for class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Creates a new TShortShortHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
TShortShortHashMap(int, float) - Constructor for class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Creates a new TShortShortHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
TShortShortHashMap(TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Creates a new TShortShortHashMap instance with the default capacity and load factor.
TShortShortHashMap(int, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Creates a new TShortShortHashMap instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
TShortShortHashMap(int, float, TShortHashingStrategy) - Constructor for class org.elasticsearch.util.gnu.trove.TShortShortHashMap
Creates a new TShortShortHashMap instance with a prime value at or near the specified capacity and load factor.
TShortShortHashMapDecorator - Class in org.elasticsearch.util.gnu.trove.decorator
Wrapper class to make a TShortShortHashMap conform to the java.util.Map API.
TShortShortHashMapDecorator() - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
FOR EXTERNALIZATION ONLY!!
TShortShortHashMapDecorator(TShortShortHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Creates a wrapper that decorates the specified primitive map.
TShortShortIterator - Class in org.elasticsearch.util.gnu.trove
Iterator for maps of type short and short.
TShortShortIterator(TShortShortHashMap) - Constructor for class org.elasticsearch.util.gnu.trove.TShortShortIterator
Creates an iterator over the specified map
TShortShortProcedure - Interface in org.elasticsearch.util.gnu.trove
Interface for procedures that take two parameters of type short and short.
TShortStack - Class in org.elasticsearch.util.gnu.trove
A stack of short primitives, backed by a TShortArrayList.
TShortStack() - Constructor for class org.elasticsearch.util.gnu.trove.TShortStack
Creates a new TShortStack instance with the default capacity.
TShortStack(int) - Constructor for class org.elasticsearch.util.gnu.trove.TShortStack
Creates a new TShortStack instance with the specified capacity.
Tuple<V1,V2> - Class in org.elasticsearch.util
 
Tuple(V1, V2) - Constructor for class org.elasticsearch.util.Tuple
 
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.ping.single.SinglePingRequest
 
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(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(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.GetResponse
The type of the 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 rutn with.
type() - Method in class org.elasticsearch.action.search.type.ParsedScrollId
 
type - Variable in class org.elasticsearch.action.support.single.SingleOperationRequest
 
type() - Method in class org.elasticsearch.action.support.single.SingleOperationRequest
 
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.index.cache.filter.FilterCache
 
type() - Method in class org.elasticsearch.index.cache.filter.none.NoneFilterCache
 
type() - Method in class org.elasticsearch.index.cache.filter.soft.SoftFilterCache
 
type() - Method in class org.elasticsearch.index.cache.filter.weak.WeakFilterCache
 
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.Index
 
type() - Method in exception org.elasticsearch.index.engine.IndexFailedEngineException
 
type() - Method in interface org.elasticsearch.index.mapper.DocumentMapper
 
type(String) - Method in class org.elasticsearch.index.mapper.MapperService
 
type() - Method in class org.elasticsearch.index.mapper.ParsedDocument
 
type() - Method in class org.elasticsearch.index.mapper.Uid
 
type() - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
 
type() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
type() - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
TYPE - Static variable in class org.elasticsearch.index.merge.scheduler.MergeSchedulerModule.MergeSchedulerSettings
 
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() - Method in class org.elasticsearch.search.facets.CountFacet
 
type() - Method in interface org.elasticsearch.search.facets.Facet
The type of the facet.
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.threadpool.ThreadPoolInfo
The type of the thread pool.
type() - Method in class org.elasticsearch.util.xcontent.json.JsonXContent
 
type() - Method in interface org.elasticsearch.util.xcontent.XContent
The type this content handles and produces.
type() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContent
 
TypeConverter - Interface in org.elasticsearch.util.inject.spi
Converts constant string values to a different type.
TypeConverterBinding - Class in org.elasticsearch.util.inject.spi
Registration of type converters for matching target types.
TypeEncounter<I> - Interface in org.elasticsearch.util.inject.spi
Context of an injectable type encounter.
typeField(XContentTypeFieldMapper.Builder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper.Builder
 
TypeFieldMapper - Interface in org.elasticsearch.index.mapper
A mapper that maps the type of the resource into the document.
typeFieldMappers() - Method in class org.elasticsearch.index.mapper.MapperService
 
TypeListener - Interface in org.elasticsearch.util.inject.spi
Listens for Guice to encounter injectable types.
TypeListenerBinding - Class in org.elasticsearch.util.inject.spi
Binds types (picked using a Matcher) to an type listener.
TypeLiteral<T> - Class in org.elasticsearch.util.inject
Represents a generic type T.
TypeLiteral() - Constructor for class org.elasticsearch.util.inject.TypeLiteral
Constructs a new type literal.
typeMapper() - Method in interface org.elasticsearch.index.mapper.DocumentMapper
 
typeMapper() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
TypeMissingException - Exception in org.elasticsearch.indices
 
TypeMissingException(Index, String) - Constructor for exception org.elasticsearch.indices.TypeMissingException
 
typeParser(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentTypeParser.ParserContext
 
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.index.engine.Engine.DeleteByQuery
 
types() - Method in class org.elasticsearch.index.translog.Translog.DeleteByQuery
 
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 - Class in org.elasticsearch.util.inject.util
Static methods for working with types.
typesPattern - Static variable in class org.elasticsearch.rest.action.support.RestActions
 

U

uid() - Method in class org.elasticsearch.index.engine.Engine.Delete
 
uid() - Method in class org.elasticsearch.index.engine.Engine.Index
 
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.mapper.xcontent.ParseContext
 
uid(String) - Method in class org.elasticsearch.index.mapper.xcontent.ParseContext
Really, just the uid mapper should set this.
uid() - Static method in class org.elasticsearch.index.mapper.xcontent.XContentMapperBuilders
 
uid() - Method in class org.elasticsearch.index.translog.Translog.Delete
 
UidAndSourceFieldSelector - Class in org.elasticsearch.index.mapper
An optimized field selector that loads just the uid and the source.
UidAndSourceFieldSelector() - Constructor for class org.elasticsearch.index.mapper.UidAndSourceFieldSelector
 
uidField(XContentUidFieldMapper.Builder) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper.Builder
 
UidFieldMapper - Interface in org.elasticsearch.index.mapper
 
uidFieldMappers() - Method in class org.elasticsearch.index.mapper.MapperService
 
UidFieldSelector - Class in org.elasticsearch.index.mapper
An optimized field selector that loads just the uid.
UidFieldSelector() - Constructor for class org.elasticsearch.index.mapper.UidFieldSelector
 
uidMapper() - Method in interface org.elasticsearch.index.mapper.DocumentMapper
 
uidMapper() - Method in class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
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
 
uncapitalize(String) - Static method in class org.elasticsearch.util.Strings
Uncapitalize a String, changing the first letter to lower case as per Character.toLowerCase(char).
UncategorizedExecutionException - Exception in org.elasticsearch.util.concurrent
 
UncategorizedExecutionException(String) - Constructor for exception org.elasticsearch.util.concurrent.UncategorizedExecutionException
 
UncategorizedExecutionException(String, Throwable) - Constructor for exception org.elasticsearch.util.concurrent.UncategorizedExecutionException
 
UNDERSCORE - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
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) - Constructor for class org.elasticsearch.discovery.zen.ping.unicast.UnicastZenPing
 
Unicode - Class in org.elasticsearch.util
 
Unicode() - Constructor for class org.elasticsearch.util.Unicode
 
Unicode.UTF16Result - Class in org.elasticsearch.util
 
Unicode.UTF16Result() - Constructor for class org.elasticsearch.util.Unicode.UTF16Result
 
union(Set<? extends E>, Set<? extends E>) - Static method in class org.elasticsearch.util.collect.Sets
Returns an unmodifiable view of the union of two sets.
uniqueAddressTypeId() - Method in class org.elasticsearch.util.transport.DummyTransportAddress
 
uniqueAddressTypeId() - Method in class org.elasticsearch.util.transport.InetSocketTransportAddress
 
uniqueAddressTypeId() - Method in class org.elasticsearch.util.transport.LocalTransportAddress
 
uniqueAddressTypeId() - Method in interface org.elasticsearch.util.transport.TransportAddress
 
UniqueAnnotations - Class in org.elasticsearch.util.inject.internal
 
uniqueIndex(Iterable<V>, Function<? super V, K>) - Static method in class org.elasticsearch.util.collect.Maps
Returns an immutable map for which the Map.values() are the given elements in the given order, and each key is the product of invoking a supplied function on its corresponding value.
UNKNOWN - Static variable in class org.elasticsearch.action.admin.indices.status.IndexShardStatus.Docs
 
UNKNOWN - Static variable in class org.elasticsearch.action.admin.indices.status.IndexStatus.Docs
 
UNKNOWN - Static variable in class org.elasticsearch.action.admin.indices.status.ShardStatus.Docs
 
UNKNOWN_SOURCE - Static variable in class org.elasticsearch.util.inject.internal.SourceProvider
Indicates that the source is unknown.
unmodifiableBiMap(BiMap<? extends K, ? extends V>) - Static method in class org.elasticsearch.util.collect.Maps
Returns an unmodifiable view of the specified bimap.
unmodifiableIterable(Iterable<T>) - Static method in class org.elasticsearch.util.collect.Iterables
Returns an unmodifiable view of iterable.
unmodifiableIterator(Iterator<T>) - Static method in class org.elasticsearch.util.collect.Iterators
Returns an unmodifiable view of iterator.
UnmodifiableIterator<E> - Class in org.elasticsearch.util.collect
An iterator that does not support UnmodifiableIterator.remove().
UnmodifiableIterator() - Constructor for class org.elasticsearch.util.collect.UnmodifiableIterator
 
UnmodifiableIterator<E> - Class in org.elasticsearch.util.inject.internal
An iterator that does not support UnmodifiableIterator.remove().
UnmodifiableIterator() - Constructor for class org.elasticsearch.util.inject.internal.UnmodifiableIterator
 
unmodifiableListMultimap(ListMultimap<K, V>) - Static method in class org.elasticsearch.util.collect.Multimaps
Returns an unmodifiable view of the specified ListMultimap.
unmodifiableMultimap(Multimap<K, V>) - Static method in class org.elasticsearch.util.collect.Multimaps
Returns an unmodifiable view of the specified multimap.
unmodifiableMultiset(Multiset<? extends E>) - Static method in class org.elasticsearch.util.collect.Multisets
Returns an unmodifiable view of the specified multiset.
unmodifiableSetMultimap(SetMultimap<K, V>) - Static method in class org.elasticsearch.util.collect.Multimaps
Returns an unmodifiable view of the specified SetMultimap.
unmodifiableSortedSetMultimap(SortedSetMultimap<K, V>) - Static method in class org.elasticsearch.util.collect.Multimaps
Returns an unmodifiable view of the specified SortedSetMultimap.
unqualify(String) - Static method in class org.elasticsearch.util.Strings
Unqualify a string qualified by a '.' dot character.
unqualify(String, char) - Static method in class org.elasticsearch.util.Strings
Unqualify a string qualified by a separator character.
unregisterGroup(String) - Method in class org.elasticsearch.jmx.JmxService
 
unsafeArray() - Method in class org.elasticsearch.util.trove.ExtTIntArrayList
 
unsafeByteArray() - Method in class org.elasticsearch.util.io.ByteArrayDataOutputStream
 
unsafeByteArray() - Method in class org.elasticsearch.util.io.FastByteArrayOutputStream
Returns the underlying byte array.
unsafeByteArray() - Method in class org.elasticsearch.util.io.stream.BytesStreamOutput
Returns the underlying byte array.
unsafeBytes() - Method in class org.elasticsearch.util.xcontent.builder.BinaryXContentBuilder
 
unsafeBytes() - Method in class org.elasticsearch.util.xcontent.builder.TextXContentBuilder
 
unsafeBytes() - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
unsafeBytesLength() - Method in class org.elasticsearch.util.xcontent.builder.BinaryXContentBuilder
 
unsafeBytesLength() - Method in class org.elasticsearch.util.xcontent.builder.TextXContentBuilder
Call this AFTER TextXContentBuilder.unsafeBytes().
unsafeBytesLength() - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
unsafeCharArray() - Method in class org.elasticsearch.util.io.FastCharArrayWriter
Returns the underlying char array.
unsafeChars() - Method in class org.elasticsearch.util.xcontent.builder.TextXContentBuilder
 
unsafeFromBytesAsUtf16(byte[]) - Static method in class org.elasticsearch.util.Unicode
 
unsafeFromBytesAsUtf16(byte[], int, int) - Static method in class org.elasticsearch.util.Unicode
 
unsafeFromStringAsUtf8(String) - Static method in class org.elasticsearch.util.Unicode
 
unsafeStream() - Method in class org.elasticsearch.util.xcontent.builder.BinaryXContentBuilder
 
UNSCOPED - Static variable in class org.elasticsearch.util.inject.internal.Scoping
No scoping annotation has been applied.
UntargettedBinding<T> - Interface in org.elasticsearch.util.inject.spi
An untargetted binding.
UntargettedBindingImpl<T> - Class in org.elasticsearch.util.inject.internal
 
UntargettedBindingImpl(Injector, Key<T>, Object) - Constructor for class org.elasticsearch.util.inject.internal.UntargettedBindingImpl
 
UntargettedBindingImpl(Object, Key<T>, Scoping) - Constructor for class org.elasticsearch.util.inject.internal.UntargettedBindingImpl
 
unwrap(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteHashSetDecorator
Unwraps a value
unwrap(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleHashSetDecorator
Unwraps a value
unwrap(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatHashSetDecorator
Unwraps a value
unwrap(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntHashSetDecorator
Unwraps a value
unwrap(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongHashSetDecorator
Unwraps a value
unwrap(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortHashSetDecorator
Unwraps a value
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
 
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Unwraps a key
unwrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Unwraps a key
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Unwraps a value
unwrapValue(V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Unwraps a value
unwrapValue(V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Unwraps a value
unwrapValue(V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Unwraps a value
unwrapValue(V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Unwraps a value
unwrapValue(V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Unwraps a value
unwrapValue(V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Unwraps a value
unwrapValue(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Unwraps a value
updatedSettings() - Method in class org.elasticsearch.plugins.PluginsService
 
updateKeyWithNamedWildcard(String) - Method in class org.elasticsearch.util.path.PathTrie.TrieNode
 
updateMapping(String, String, String) - Method in class org.elasticsearch.cluster.metadata.MetaDataService
 
updateNodes(RoutingNodes) - Method in class org.elasticsearch.cluster.routing.RoutingTable.Builder
 
updateNodes(DiscoveryNodes) - Method in class org.elasticsearch.discovery.zen.fd.NodesFaultDetection
 
updateRewriteQuery(Query) - Method in class org.elasticsearch.search.internal.SearchContext
Rewrites the query and updates it.
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.util.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.os.OsStats.Mem
 
used() - Method in class org.elasticsearch.monitor.os.OsStats.Swap
 
useDisMax(boolean) - Method in class org.elasticsearch.index.query.xcontent.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 interface org.elasticsearch.index.mapper.FieldMapper
Should the field query FieldMapper.fieldQuery(String) be used when detecting this field in query string.
useFieldQueryWithQueryString() - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
useFieldQueryWithQueryString() - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
Use the field query created here when matching on numbers.
useForNull(String) - Method in class org.elasticsearch.util.base.Joiner.MapJoiner
Returns a map joiner with the same behavior as this one, except automatically substituting nullText for any provided null keys or values.
useForNull(String) - Method in class org.elasticsearch.util.base.Joiner
Returns a joiner with the same behavior as this one, except automatically substituting nullText for any provided null elements.
usePrettyPrint() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
usePrettyPrint() - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
usePrettyPrint() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
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.
usingToString() - Static method in class org.elasticsearch.util.collect.Ordering
Returns an ordering that compares objects by the natural ordering of their string representations as returned by toString().
utf8() - Method in class org.elasticsearch.util.xcontent.builder.TextXContentBuilder
Returns the byte[] that represents the utf8 of the json written up until now.
utf8copied() - Method in class org.elasticsearch.util.xcontent.builder.TextXContentBuilder
Returns a copied byte[] that represnts the utf8 o fthe json written up until now.
Utf8RestResponse - Class in org.elasticsearch.rest
An http response that is built on top of UnicodeUtil.UTF8Result.
Utf8RestResponse(RestResponse.Status) - Constructor for class org.elasticsearch.rest.Utf8RestResponse
 
Utf8RestResponse(RestResponse.Status, UnicodeUtil.UTF8Result) - Constructor for class org.elasticsearch.rest.Utf8RestResponse
 
Utf8RestResponse(RestResponse.Status, UnicodeUtil.UTF8Result, UnicodeUtil.UTF8Result, UnicodeUtil.UTF8Result) - Constructor for class org.elasticsearch.rest.Utf8RestResponse
 
UTF8toUTF16(byte[], int, int, Unicode.UTF16Result) - Static method in class org.elasticsearch.util.Unicode
Convert UTF8 bytes into UTF16 characters.
UUID - Class in org.elasticsearch.util
A UUID taken from java UUID that simply holds less data.
UUID(long, long) - Constructor for class org.elasticsearch.util.UUID
Constructs a new UUID using the specified data.

V

v1() - Method in class org.elasticsearch.util.Tuple
 
v2() - Method in class org.elasticsearch.util.Tuple
 
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.state.ClusterStateRequest
 
validate() - Method in class org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequest
 
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.mapping.put.PutMappingRequest
 
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.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.index.IndexRequest
 
validate() - Method in class org.elasticsearch.action.mlt.MoreLikeThisRequest
 
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.SingleOperationRequest
 
validate() - Method in class org.elasticsearch.action.terms.TermsRequest
 
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
 
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.util.Strings
 
value() - Method in enum org.elasticsearch.action.admin.cluster.health.ClusterHealthStatus
 
value() - Method in enum org.elasticsearch.action.terms.TermsRequest.SortType
The unique byte value of the sort type.
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(Fieldable) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Returns the actual value of the field.
value(Document) - Method in interface org.elasticsearch.index.mapper.IdFieldMapper
 
value(Document) - Method in interface org.elasticsearch.index.mapper.SourceFieldMapper
 
value(Document) - Method in interface org.elasticsearch.index.mapper.TypeFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBinaryFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper
 
value(Document) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper
 
value(Document) - Method in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper
 
value(Document) - Method in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper
 
value(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper
 
value() - Method in class org.elasticsearch.util.gnu.trove.TByteByteIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TByteFloatIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TByteIntIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TByteLongIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TByteObjectIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TByteShortIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TFloatByteIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TFloatIntIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TFloatLongIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TFloatShortIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TIntByteIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TIntFloatIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TIntIntIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TIntLongIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TIntObjectIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TIntShortIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TLongByteIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TLongFloatIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TLongIntIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TLongLongIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TLongObjectIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TLongShortIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TObjectByteIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TObjectIntIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TObjectLongIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TObjectShortIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TShortByteIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TShortFloatIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TShortIntIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TShortLongIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TShortObjectIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.gnu.trove.TShortShortIterator
Provides access to the value of the mapping at the iterator's position.
value() - Method in class org.elasticsearch.util.Percent
 
value(Boolean) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
value(boolean) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
value(ReadableInstant) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
value(ReadableInstant, DateTimeFormatter) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
value(Date) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
value(Date, DateTimeFormatter) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
value(Integer) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
value(int) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
value(Long) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
value(long) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
value(Float) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
value(float) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
value(Double) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
value(double) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
value(String) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
value(byte[]) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
value(Object) - Method in class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
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.xcontent.XContentAllFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBinaryFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper
 
valueAsString(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper
 
valueComparator() - Method in interface org.elasticsearch.util.collect.SortedSetMultimap
Returns the comparator that orders the multimap values, with a null indicating that natural ordering is used.
valueComparator() - Method in class org.elasticsearch.util.collect.TreeMultimap
 
valueForEntry(Map.Entry<K, V>) - Method in class org.elasticsearch.util.gnu.trove.THashMap.EntryView
 
valueForSearch(Fieldable) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Returns the value that will be used as a result for search.
valueForSearch(Object) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Returns the value that will be returned to the user (similar to FieldMapper.valueForSearch(org.apache.lucene.document.Fieldable)).
valueForSearch(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper
 
valueForSearch(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
Dates should return as a string, delegates to XContentDateFieldMapper.valueAsString(org.apache.lucene.document.Fieldable).
valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
 
valueForSearch(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
valueForSearch(Object) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
valueForSearch(Fieldable) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
Override the default behavior (to return the string, and return the actual Number instance).
valueFromString(String) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Parses a string that represents the field into its value.
valueFromString(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
 
valueFromString(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper
 
valueFromTerm(String) - Method in interface org.elasticsearch.index.mapper.FieldMapper
Parses the string back into the type of the field (should be comparable!) in a similar manner FieldMapper.valueForSearch(org.apache.lucene.document.Fieldable) does with fields.
valueFromTerm(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
valueFromTerm(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
 
valueFromTerm(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper
 
valueFromTerm(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
Simply returns the same string.
valueFromTerm(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper
 
valueFromTerm(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper
 
valueFromTerm(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper
 
valueFromTerm(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
 
valueFromTerm(String) - Method in class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper
 
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.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.terms.TermsRequest.SortType
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.cluster.metadata.AliasAction.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.cluster.routing.ShardRoutingState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.index.mapper.xcontent.ContentPath.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.index.mapper.xcontent.ParseContext.ParsedIdState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.index.query.xcontent.FieldQueryBuilder.Operator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.index.query.xcontent.QueryStringQueryBuilder.Operator
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.Translog.Operation.Type
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.RestResponse.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.search.builder.SearchSourceBuilder.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.search.facets.Facet.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.search.facets.SearchContextFacets.QueryExecutionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.util.component.Lifecycle.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.util.inject.internal.BytecodeGen.Visibility
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.util.inject.Stage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.util.network.NetworkUtils.StackType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.util.SizeUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.util.xcontent.builder.XContentBuilder.FieldCaseConversion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.util.xcontent.XContentParser.NumberType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.util.xcontent.XContentParser.Token
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.util.xcontent.XContentType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.elasticsearch.util.xcontent.xson.XsonType
Returns the enum constant of this type with the specified name.
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() - Method in class org.elasticsearch.action.get.GetField
 
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() - Method in class org.elasticsearch.action.search.type.ParsedScrollId
 
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.terms.TermsRequest.SortType
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.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.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.index.mapper.xcontent.ContentPath.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.index.mapper.xcontent.ParseContext.ParsedIdState
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.xcontent.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.xcontent.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.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.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.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.RestResponse.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.search.builder.SearchSourceBuilder.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.search.facets.Facet.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.search.facets.SearchContextFacets.QueryExecutionType
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() - Method in interface org.elasticsearch.search.SearchHitField
The field values.
values() - Method in interface org.elasticsearch.util.collect.BiMap
values() - Method in class org.elasticsearch.util.collect.ForwardingMap
 
values() - Method in class org.elasticsearch.util.collect.ForwardingMultimap
 
values() - Method in class org.elasticsearch.util.collect.ImmutableBiMap
Returns an immutable set of the values in this map.
values() - Method in class org.elasticsearch.util.collect.ImmutableMap
Returns an immutable collection of the values in this map.
values() - Method in class org.elasticsearch.util.collect.ImmutableMultimap
Returns an immutable collection of the values in this multimap.
values() - Method in class org.elasticsearch.util.collect.ImmutableSortedMap
Returns an immutable collection of the values in this map, sorted by the ordering of the corresponding keys.
values() - Method in class org.elasticsearch.util.collect.LinkedHashMultimap
Returns a collection of all values in the multimap.
values() - Method in class org.elasticsearch.util.collect.LinkedListMultimap
Returns a collection of all values in the multimap.
values() - Method in interface org.elasticsearch.util.collect.Multimap
Returns a collection of all values in the multimap.
values() - Static method in enum org.elasticsearch.util.component.Lifecycle.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.elasticsearch.util.concurrent.ConcurrentHashMapLong
 
values() - Method in class org.elasticsearch.util.concurrent.ConcurrentIdentityHashMap
Returns a Collection view of the values contained in this map.
values() - Method in class org.elasticsearch.util.concurrent.CopyOnWriteMap
 
values() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMap
Returns a Collection view of the values contained in this map.
values() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashMapLong
Returns a Collection view of the values contained in this map.
values() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingHashtable
Returns a Collection view of the values contained in this map.
values() - Method in class org.elasticsearch.util.concurrent.highscalelib.NonBlockingIdentityHashMap
Returns a Collection view of the values contained in this map.
values() - Method in class org.elasticsearch.util.gnu.trove.THashMap
Returns a view on the values of the map.
values() - Static method in enum org.elasticsearch.util.inject.internal.BytecodeGen.Visibility
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.util.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.util.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.util.SizeUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.elasticsearch.util.xcontent.builder.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.util.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.util.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.util.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.util.xcontent.xson.XsonType
Returns an array containing the constants of this enum type, in the order they are declared.
valueType() - Method in class org.elasticsearch.util.collect.EnumBiMap
Returns the associated value type.
vendor() - Method in class org.elasticsearch.monitor.os.OsInfo.Cpu
 
version() - Method in class org.elasticsearch.cluster.ClusterState
 
version() - Method in class org.elasticsearch.index.gateway.IndexShardGateway.RecoveryStatus.Index
 
version - Variable in class org.elasticsearch.util.lucene.versioned.VersionedIndexReader
 
Version - Class in org.elasticsearch
 
Version() - Constructor for class org.elasticsearch.Version
 
VersionedIndexReader - Class in org.elasticsearch.util.lucene.versioned
 
VersionedIndexReader(IndexReader, int, VersionedMap) - Constructor for class org.elasticsearch.util.lucene.versioned.VersionedIndexReader
 
versionedMap - Variable in class org.elasticsearch.util.lucene.versioned.VersionedIndexReader
 
VersionedMap - Interface in org.elasticsearch.util.lucene.versioned
A versioned map, allowing to put version numbers associated with specific keys.
VisibleForTesting - Annotation Type in org.elasticsearch.util.annotations
An annotation that indicates that the visibility of a type or member has been relaxed to make the code testable.
visit(InstanceBinding<? extends T>) - Method in interface org.elasticsearch.util.inject.spi.BindingTargetVisitor
Visit a instance binding.
visit(ProviderInstanceBinding<? extends T>) - Method in interface org.elasticsearch.util.inject.spi.BindingTargetVisitor
Visit a provider instance binding.
visit(ProviderKeyBinding<? extends T>) - Method in interface org.elasticsearch.util.inject.spi.BindingTargetVisitor
Visit a provider key binding.
visit(LinkedKeyBinding<? extends T>) - Method in interface org.elasticsearch.util.inject.spi.BindingTargetVisitor
Visit a linked key binding.
visit(ExposedBinding<? extends T>) - Method in interface org.elasticsearch.util.inject.spi.BindingTargetVisitor
Visit a binding to a key exposed from an enclosed private environment.
visit(UntargettedBinding<? extends T>) - Method in interface org.elasticsearch.util.inject.spi.BindingTargetVisitor
Visit an untargetted binding.
visit(ConstructorBinding<? extends T>) - Method in interface org.elasticsearch.util.inject.spi.BindingTargetVisitor
Visit a constructor binding.
visit(ConvertedConstantBinding<? extends T>) - Method in interface org.elasticsearch.util.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.util.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.util.inject.spi.DefaultBindingTargetVisitor
 
visit(ProviderInstanceBinding<? extends T>) - Method in class org.elasticsearch.util.inject.spi.DefaultBindingTargetVisitor
 
visit(ProviderKeyBinding<? extends T>) - Method in class org.elasticsearch.util.inject.spi.DefaultBindingTargetVisitor
 
visit(LinkedKeyBinding<? extends T>) - Method in class org.elasticsearch.util.inject.spi.DefaultBindingTargetVisitor
 
visit(ExposedBinding<? extends T>) - Method in class org.elasticsearch.util.inject.spi.DefaultBindingTargetVisitor
 
visit(UntargettedBinding<? extends T>) - Method in class org.elasticsearch.util.inject.spi.DefaultBindingTargetVisitor
 
visit(ConstructorBinding<? extends T>) - Method in class org.elasticsearch.util.inject.spi.DefaultBindingTargetVisitor
 
visit(ConvertedConstantBinding<? extends T>) - Method in class org.elasticsearch.util.inject.spi.DefaultBindingTargetVisitor
 
visit(ProviderBinding<? extends T>) - Method in class org.elasticsearch.util.inject.spi.DefaultBindingTargetVisitor
 
visit(Message) - Method in class org.elasticsearch.util.inject.spi.DefaultElementVisitor
 
visit(Binding<T>) - Method in class org.elasticsearch.util.inject.spi.DefaultElementVisitor
 
visit(ScopeBinding) - Method in class org.elasticsearch.util.inject.spi.DefaultElementVisitor
 
visit(TypeConverterBinding) - Method in class org.elasticsearch.util.inject.spi.DefaultElementVisitor
 
visit(ProviderLookup<T>) - Method in class org.elasticsearch.util.inject.spi.DefaultElementVisitor
 
visit(InjectionRequest) - Method in class org.elasticsearch.util.inject.spi.DefaultElementVisitor
 
visit(StaticInjectionRequest) - Method in class org.elasticsearch.util.inject.spi.DefaultElementVisitor
 
visit(PrivateElements) - Method in class org.elasticsearch.util.inject.spi.DefaultElementVisitor
 
visit(MembersInjectorLookup<T>) - Method in class org.elasticsearch.util.inject.spi.DefaultElementVisitor
 
visit(TypeListenerBinding) - Method in class org.elasticsearch.util.inject.spi.DefaultElementVisitor
 
visit(Binding<T>) - Method in interface org.elasticsearch.util.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.util.inject.spi.ElementVisitor
Visit a registration of a scope annotation with the scope that implements it.
visit(TypeConverterBinding) - Method in interface org.elasticsearch.util.inject.spi.ElementVisitor
Visit a registration of type converters for matching target types.
visit(InjectionRequest) - Method in interface org.elasticsearch.util.inject.spi.ElementVisitor
Visit a request to inject the instance fields and methods of an instance.
visit(StaticInjectionRequest) - Method in interface org.elasticsearch.util.inject.spi.ElementVisitor
Visit a request to inject the static fields and methods of type.
visit(ProviderLookup<T>) - Method in interface org.elasticsearch.util.inject.spi.ElementVisitor
Visit a lookup of the provider for a type.
visit(MembersInjectorLookup<T>) - Method in interface org.elasticsearch.util.inject.spi.ElementVisitor
Visit a lookup of the members injector.
visit(Message) - Method in interface org.elasticsearch.util.inject.spi.ElementVisitor
Visit an error message and the context in which it occured.
visit(PrivateElements) - Method in interface org.elasticsearch.util.inject.spi.ElementVisitor
Visit a collection of configuration elements for a private binder.
visit(TypeListenerBinding) - Method in interface org.elasticsearch.util.inject.spi.ElementVisitor
Visit an injectable type listener binding.
visitEagerSingleton() - Method in interface org.elasticsearch.util.inject.spi.BindingScopingVisitor
Visit an eager singleton or single instance.
visitEagerSingleton() - Method in class org.elasticsearch.util.inject.spi.DefaultBindingScopingVisitor
 
visitNoScoping() - Method in interface org.elasticsearch.util.inject.spi.BindingScopingVisitor
Visit an unspecified or unscoped strategy.
visitNoScoping() - Method in class org.elasticsearch.util.inject.spi.DefaultBindingScopingVisitor
 
visitOther() - Method in class org.elasticsearch.util.inject.spi.DefaultBindingScopingVisitor
Default visit implementation.
visitOther(Binding<? extends T>) - Method in class org.elasticsearch.util.inject.spi.DefaultBindingTargetVisitor
Default visit implementation.
visitOther(Element) - Method in class org.elasticsearch.util.inject.spi.DefaultElementVisitor
Default visit implementation.
visitScope(Scope) - Method in interface org.elasticsearch.util.inject.spi.BindingScopingVisitor
Visit a scope instance.
visitScope(Scope) - Method in class org.elasticsearch.util.inject.spi.DefaultBindingScopingVisitor
 
visitScopeAnnotation(Class<? extends Annotation>) - Method in interface org.elasticsearch.util.inject.spi.BindingScopingVisitor
Visit a scope annotation.
visitScopeAnnotation(Class<? extends Annotation>) - Method in class org.elasticsearch.util.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.util.inject.internal.Errors
 
VoidStreamable - Class in org.elasticsearch.util.io.stream
 
VoidStreamable() - Constructor for class org.elasticsearch.util.io.stream.VoidStreamable
 
VoidTransportResponseHandler - Class in org.elasticsearch.transport
 
VoidTransportResponseHandler() - Constructor for class org.elasticsearch.transport.VoidTransportResponseHandler
 
VoidTransportResponseHandler(boolean) - Constructor for class org.elasticsearch.transport.VoidTransportResponseHandler
 

W

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
 
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
 
warn(String) - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
 
warn(String, Throwable) - Method in class org.elasticsearch.transport.netty.NettyInternalESLogger
 
warn(String, Object...) - Method in interface org.elasticsearch.util.logging.ESLogger
Logs a WARN level message.
warn(String, Throwable, Object...) - Method in interface org.elasticsearch.util.logging.ESLogger
Logs a WARN level message.
warn(String, Object...) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
warn(String, Throwable, Object...) - Method in class org.elasticsearch.util.logging.support.AbstractESLogger
 
WeakFilterCache - Class in org.elasticsearch.index.cache.filter.weak
A weak reference based filter cache that has weak keys on the IndexReader.
WeakFilterCache(Index, Settings, ThreadPool) - Constructor for class org.elasticsearch.index.cache.filter.weak.WeakFilterCache
 
weakKeys() - Method in class org.elasticsearch.util.collect.MapMaker
Specifies that each key (not value) stored in the map should be wrapped in a WeakReference (by default, strong references are used).
weakValues() - Method in class org.elasticsearch.util.collect.MapMaker
Specifies that each value (not key) stored in the map should be wrapped in a WeakReference (by default, strong references are used).
WHITE - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 
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.xcontent.QueryBuilders
Implements the wildcard search query.
WildcardQueryBuilder - Class in org.elasticsearch.index.query.xcontent
Implements the wildcard search query.
WildcardQueryBuilder(String, String) - Constructor for class org.elasticsearch.index.query.xcontent.WildcardQueryBuilder
Implements the wildcard search query.
WildcardQueryParser - Class in org.elasticsearch.index.query.xcontent
 
WildcardQueryParser(Index, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.WildcardQueryParser
 
WINDOWS - Static variable in class org.elasticsearch.util.OsUtils
True iff running on Windows.
with(Module...) - Method in interface org.elasticsearch.util.inject.util.Modules.OverriddenModuleBuilder
See the EDSL example at override().
with(Iterable<? extends Module>) - Method in interface org.elasticsearch.util.inject.util.Modules.OverriddenModuleBuilder
See the EDSL example at override().
withKey(Key<T>) - Method in class org.elasticsearch.util.inject.internal.BindingImpl
 
withKey(Key<T>) - Method in class org.elasticsearch.util.inject.internal.ExposedBindingImpl
 
withKey(Key<T>) - Method in class org.elasticsearch.util.inject.internal.InstanceBindingImpl
 
withKey(Key<T>) - Method in class org.elasticsearch.util.inject.internal.LinkedBindingImpl
 
withKey(Key<T>) - Method in class org.elasticsearch.util.inject.internal.LinkedProviderBindingImpl
 
withKey(Key<T>) - Method in class org.elasticsearch.util.inject.internal.ProviderInstanceBindingImpl
 
withKey(Key<T>) - Method in class org.elasticsearch.util.inject.internal.UntargettedBindingImpl
 
withKeyValueSeparator(String) - Method in class org.elasticsearch.util.base.Joiner
Returns a MapJoiner using the given key-value separator, and the same configuration as this Joiner otherwise.
withPartialValue(Object) - Method in exception org.elasticsearch.util.inject.ConfigurationException
Returns a copy of this configuration exception with the specified partial value.
withScoping(Scoping) - Method in class org.elasticsearch.util.inject.internal.BindingImpl
 
withScoping(Scoping) - Method in class org.elasticsearch.util.inject.internal.ExposedBindingImpl
 
withScoping(Scoping) - Method in class org.elasticsearch.util.inject.internal.InstanceBindingImpl
 
withScoping(Scoping) - Method in class org.elasticsearch.util.inject.internal.LinkedBindingImpl
 
withScoping(Scoping) - Method in class org.elasticsearch.util.inject.internal.LinkedProviderBindingImpl
 
withScoping(Scoping) - Method in class org.elasticsearch.util.inject.internal.ProviderInstanceBindingImpl
 
withScoping(Scoping) - Method in class org.elasticsearch.util.inject.internal.UntargettedBindingImpl
 
withSource(Object) - Method in interface org.elasticsearch.util.inject.Binder
Returns a binder that uses source as the reference location for configuration errors.
withSource(Object) - Method in class org.elasticsearch.util.inject.internal.Errors
Returns an instance that uses source as a reference point for newly added errors.
withSource(Object) - Method in interface org.elasticsearch.util.inject.PrivateBinder
 
workFile() - Method in class org.elasticsearch.env.Environment
The work location.
workWithClusterFile() - Method in class org.elasticsearch.env.Environment
 
wrap(byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteHashSetDecorator
Wraps a value
wrap(double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleHashSetDecorator
Wraps a value
wrap(float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatHashSetDecorator
Wraps a value
wrap(int) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntHashSetDecorator
Wraps a value
wrap(long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongHashSetDecorator
Wraps a value
wrap(short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortHashSetDecorator
Wraps a value
wrap(TDoubleDoubleHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TDoubleFloatHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TDoubleIntHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TDoubleLongHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TDoubleByteHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TDoubleShortHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TFloatDoubleHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TFloatFloatHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TFloatIntHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TFloatLongHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TFloatByteHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TFloatShortHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TIntDoubleHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TIntFloatHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TIntIntHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TIntLongHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TIntByteHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TIntShortHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TLongDoubleHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TLongFloatHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TLongIntHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TLongLongHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TLongByteHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TLongShortHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TByteDoubleHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TByteFloatHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TByteIntHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TByteLongHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TByteByteHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TByteShortHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TShortDoubleHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TShortFloatHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TShortIntHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TShortLongHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TShortByteHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TShortShortHashMap) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TObjectDoubleHashMap<T>) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TObjectFloatHashMap<T>) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TObjectIntHashMap<T>) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TObjectLongHashMap<T>) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TObjectByteHashMap<T>) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TObjectShortHashMap<T>) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TDoubleObjectHashMap<T>) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TFloatObjectHashMap<T>) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TIntObjectHashMap<T>) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TLongObjectHashMap<T>) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TByteObjectHashMap<T>) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TShortObjectHashMap<T>) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given map in a decorator that uses the standard Map interface.
wrap(TDoubleHashSet) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given set in a decorator that uses the standard Set interface.
wrap(TFloatHashSet) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given set in a decorator that uses the standard Set interface.
wrap(TIntHashSet) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given set in a decorator that uses the standard Set interface.
wrap(TLongHashSet) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given set in a decorator that uses the standard Set interface.
wrap(TByteHashSet) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given set in a decorator that uses the standard Set interface.
wrap(TShortHashSet) - Static method in class org.elasticsearch.util.gnu.trove.Decorators
Wrap the given set in a decorator that uses the standard Set interface.
wrapKey(byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Wraps a key
wrapKey(byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Wraps a key
wrapKey(byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Wraps a key
wrapKey(byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Wraps a key
wrapKey(byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Wraps a key
wrapKey(byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Wraps a key
wrapKey(byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Wraps a key
wrapKey(double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Wraps a key
wrapKey(double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Wraps a key
wrapKey(double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Wraps a key
wrapKey(double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Wraps a key
wrapKey(double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Wraps a key
wrapKey(double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Wraps a key
wrapKey(double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Wraps a key
wrapKey(float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Wraps a key
wrapKey(float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Wraps a key
wrapKey(float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Wraps a key
wrapKey(float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Wraps a key
wrapKey(float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Wraps a key
wrapKey(float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Wraps a key
wrapKey(float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Wraps a key
wrapKey(int) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Wraps a key
wrapKey(int) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Wraps a key
wrapKey(int) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Wraps a key
wrapKey(int) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Wraps a key
wrapKey(int) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Wraps a key
wrapKey(int) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Wraps a key
wrapKey(int) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Wraps a key
wrapKey(long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Wraps a key
wrapKey(long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Wraps a key
wrapKey(long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Wraps a key
wrapKey(long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Wraps a key
wrapKey(long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Wraps a key
wrapKey(long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Wraps a key
wrapKey(long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Wraps a key
wrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Wraps a key
wrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Wraps a key
wrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Wraps a key
wrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Wraps a key
wrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Wraps a key
wrapKey(Object) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Wraps a key
wrapKey(short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Wraps a key
wrapKey(short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Wraps a key
wrapKey(short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Wraps a key
wrapKey(short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Wraps a key
wrapKey(short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Wraps a key
wrapKey(short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Wraps a key
wrapKey(short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Wraps a key
wrappedOut() - Method in class org.elasticsearch.util.io.stream.HandlesStreamOutput
 
wrapSmartNameFilter(Filter, MapperService.SmartNameFieldMappers, IndexCache) - Static method in class org.elasticsearch.index.query.support.QueryParsers
 
wrapSmartNameQuery(Query, MapperService.SmartNameFieldMappers, IndexCache) - Static method in class org.elasticsearch.index.query.support.QueryParsers
 
wrapValue(byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
Wraps a value
wrapValue(double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
Wraps a value
wrapValue(float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
Wraps a value
wrapValue(int) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
Wraps a value
wrapValue(long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
Wraps a value
wrapValue(V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
Wraps a value
wrapValue(short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
Wraps a value
wrapValue(byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
Wraps a value
wrapValue(double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
Wraps a value
wrapValue(float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
Wraps a value
wrapValue(int) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
Wraps a value
wrapValue(long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
Wraps a value
wrapValue(V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
Wraps a value
wrapValue(short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
Wraps a value
wrapValue(byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
Wraps a value
wrapValue(double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
Wraps a value
wrapValue(float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
Wraps a value
wrapValue(int) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
Wraps a value
wrapValue(long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
Wraps a value
wrapValue(V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
Wraps a value
wrapValue(short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
Wraps a value
wrapValue(byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
Wraps a value
wrapValue(double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
Wraps a value
wrapValue(float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
Wraps a value
wrapValue(int) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
Wraps a value
wrapValue(long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
Wraps a value
wrapValue(V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
Wraps a value
wrapValue(short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
Wraps a value
wrapValue(byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
Wraps a value
wrapValue(double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
Wraps a value
wrapValue(float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
Wraps a value
wrapValue(int) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
Wraps a value
wrapValue(long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
Wraps a value
wrapValue(V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
Wraps a value
wrapValue(short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
Wraps a value
wrapValue(byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
Wraps a value
wrapValue(double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
Wraps a value
wrapValue(float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
Wraps a value
wrapValue(int) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
Wraps a value
wrapValue(long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
Wraps a value
wrapValue(short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
Wraps a value
wrapValue(byte) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
Wraps a value
wrapValue(double) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
Wraps a value
wrapValue(float) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
Wraps a value
wrapValue(int) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
Wraps a value
wrapValue(long) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
Wraps a value
wrapValue(V) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
Wraps a value
wrapValue(short) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
Wraps a value
write(MetaData) - Method in class org.elasticsearch.gateway.fs.FsGateway
 
write(MetaData) - Method in interface org.elasticsearch.gateway.Gateway
 
write(MetaData) - Method in class org.elasticsearch.gateway.none.NoneGateway
 
write(int) - Method in class org.elasticsearch.util.Base64.OutputStream
Writes the byte to the output stream after converting to/from Base64 notation.
write(byte[], int, int) - Method in class org.elasticsearch.util.Base64.OutputStream
Calls Base64.OutputStream.write(int) repeatedly until len bytes are written.
write(int) - Method in class org.elasticsearch.util.io.FastByteArrayOutputStream
Writes the specified byte to this byte array output stream.
write(byte[], int, int) - Method in class org.elasticsearch.util.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.util.io.FastCharArrayWriter
Writes a character to the buffer.
write(char[], int, int) - Method in class org.elasticsearch.util.io.FastCharArrayWriter
Writes characters to the buffer.
write(String, int, int) - Method in class org.elasticsearch.util.io.FastCharArrayWriter
Write a portion of a string to the buffer.
write(int) - Method in class org.elasticsearch.util.io.FastDataOutputStream
Writes the specified byte (the low eight bits of the argument b) to the underlying output stream.
write(byte[], int, int) - Method in class org.elasticsearch.util.io.FastDataOutputStream
Writes len bytes from the specified byte array starting at offset off to the underlying output stream.
write(int) - Method in class org.elasticsearch.util.io.stream.StreamOutput
 
write(byte[], int, int) - Method in class org.elasticsearch.util.io.stream.StreamOutput
 
write(String) - Method in class org.elasticsearch.util.io.StringBuilderWriter
Write a String to the StringBuilder.
write(char[], int, int) - Method in class org.elasticsearch.util.io.StringBuilderWriter
Write a portion of a character array to the StringBuilder.
write(String) - Method in class org.elasticsearch.util.jline.ANSI.RenderWriter
 
writeAllowed() - Method in class org.elasticsearch.index.shard.service.InternalIndexShard
 
writeArrayFieldStart(String) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeArrayFieldStart(String) - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentGenerator
 
writeArrayFieldStart(String) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeBinary(byte[], int, int) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeBinary(byte[]) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeBinary(byte[], int, int) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeBinary(byte[]) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeBinary(byte[], int, int) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
writeBinary(byte[]) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
writeBinaryField(String, byte[]) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeBinaryField(String, byte[]) - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentGenerator
 
writeBinaryField(String, byte[]) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeBoolean(boolean) - Method in class org.elasticsearch.util.io.FastDataOutputStream
Writes a boolean to the underlying output stream as a 1-byte value.
writeBoolean(boolean) - Method in class org.elasticsearch.util.io.stream.StreamOutput
Writes a boolean.
writeBoolean(boolean) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeBoolean(boolean) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeBoolean(boolean) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
writeBooleanField(String, boolean) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeBooleanField(String, boolean) - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentGenerator
 
writeBooleanField(String, boolean) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeByte(byte) - Method in class org.elasticsearch.index.store.memory.ByteBufferIndexOutput
 
writeByte(byte) - Method in class org.elasticsearch.index.store.memory.HeapIndexOutput
 
writeByte(int) - Method in class org.elasticsearch.util.io.FastDataOutputStream
Writes out a byte to the underlying output stream as a 1-byte value.
writeByte(byte) - Method in class org.elasticsearch.util.io.stream.BytesStreamOutput
 
writeByte(byte) - Method in class org.elasticsearch.util.io.stream.DataOutputStreamOutput
 
writeByte(byte) - Method in class org.elasticsearch.util.io.stream.HandlesStreamOutput
 
writeByte(byte) - Method in class org.elasticsearch.util.io.stream.OutputStreamStreamOutput
 
writeByte(byte) - Method in class org.elasticsearch.util.io.stream.StreamOutput
Writes a single byte.
writeBytes(byte[], int, int) - Method in class org.elasticsearch.index.store.memory.ByteBufferIndexOutput
 
writeBytes(byte[], int, int) - Method in class org.elasticsearch.index.store.memory.HeapIndexOutput
 
writeBytes(String) - Method in class org.elasticsearch.util.io.FastDataOutputStream
Writes out the string to the underlying output stream as a sequence of bytes.
writeBytes(byte[], int, int) - Method in class org.elasticsearch.util.io.stream.BytesStreamOutput
 
writeBytes(byte[], int, int) - Method in class org.elasticsearch.util.io.stream.DataOutputStreamOutput
 
writeBytes(byte[], int, int) - Method in class org.elasticsearch.util.io.stream.HandlesStreamOutput
 
writeBytes(byte[], int, int) - Method in class org.elasticsearch.util.io.stream.OutputStreamStreamOutput
 
writeBytes(byte[]) - Method in class org.elasticsearch.util.io.stream.StreamOutput
Writes an array of bytes.
writeBytes(byte[], int) - Method in class org.elasticsearch.util.io.stream.StreamOutput
Writes an array of bytes.
writeBytes(byte[], int, int) - Method in class org.elasticsearch.util.io.stream.StreamOutput
Writes an array of bytes.
writeChar(int) - Method in class org.elasticsearch.util.io.FastDataOutputStream
Writes a char to the underlying output stream as a 2-byte value, high byte first.
writeChars(String) - Method in class org.elasticsearch.util.io.FastDataOutputStream
Writes a string to the underlying output stream as a sequence of characters.
writeClassDescriptor(ObjectStreamClass) - Method in class org.elasticsearch.util.io.ThrowableObjectOutputStream
 
writeComplete(ChannelHandlerContext, WriteCompletionEvent) - Method in class org.elasticsearch.transport.netty.MessageChannelHandler
 
writeDouble(double) - Method in class org.elasticsearch.util.io.FastDataOutputStream
Converts the double argument to a long using the doubleToLongBits method in class Double, and then writes that long value to the underlying output stream as an 8-byte quantity, high byte first.
writeDouble(double) - Method in class org.elasticsearch.util.io.stream.StreamOutput
 
writeEndArray() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeEndArray() - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeEndArray() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
writeEndObject() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeEndObject() - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeEndObject() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
writeExplanation(StreamOutput, Explanation) - Static method in class org.elasticsearch.util.lucene.Lucene
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteHashSetDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleHashSetDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatHashSetDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntHashSetDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongHashSetDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortHashSetDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TByteArrayList
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TByteHashSet
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleHashSet
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TFloatArrayList
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TFloatHashSet
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.THash
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.THashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.THashSet
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TIntArrayList
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TIntHashSet
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TLinkedList
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TLongArrayList
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TLongHashSet
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TObjectHash
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TShortArrayList
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TShortHashSet
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
 
writeExternal(ObjectOutput) - Method in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
 
writeFieldName(String) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeFieldName(String) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeFieldName(String) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
writeFieldValue(StreamOutput, Object) - Static method in class org.elasticsearch.util.lucene.Lucene
 
writeFloat(float) - Method in class org.elasticsearch.util.io.FastDataOutputStream
Converts the float argument to an int using the floatToIntBits method in class Float, and then writes that int value to the underlying output stream as a 4-byte quantity, high byte first.
writeFloat(float) - Method in class org.elasticsearch.util.io.stream.StreamOutput
 
writeInt(int) - Method in class org.elasticsearch.util.io.FastDataOutputStream
Writes an int to the underlying output stream as four bytes, high byte first.
writeInt(int) - Method in class org.elasticsearch.util.io.stream.StreamOutput
Writes an int as four bytes.
writeLong(long) - Method in class org.elasticsearch.util.io.FastDataOutputStream
Writes a long to the underlying output stream as eight bytes, high byte first.
writeLong(long) - Method in class org.elasticsearch.util.io.stream.StreamOutput
Writes a long as eight bytes.
writeMap(XContentGenerator, Map<String, Object>) - Static method in class org.elasticsearch.util.xcontent.support.XContentMapConverter
 
writeNull() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeNull() - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeNull() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
writeNullField(String) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeNullField(String) - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentGenerator
 
writeNullField(String) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeNumber(int) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeNumber(long) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeNumber(double) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeNumber(float) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeNumber(int) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeNumber(long) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeNumber(double) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeNumber(float) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeNumber(int) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
writeNumber(long) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
writeNumber(double) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
writeNumber(float) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
writeNumberField(String, int) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeNumberField(String, long) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeNumberField(String, double) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeNumberField(String, float) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeNumberField(String, int) - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentGenerator
 
writeNumberField(String, long) - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentGenerator
 
writeNumberField(String, double) - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentGenerator
 
writeNumberField(String, float) - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentGenerator
 
writeNumberField(String, int) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeNumberField(String, long) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeNumberField(String, double) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeNumberField(String, float) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeObjectFieldStart(String) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeObjectFieldStart(String) - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentGenerator
 
writeObjectFieldStart(String) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeRawFieldStart(String) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeRawFieldStart(String) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeRawFieldStart(String) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
writeSettingsToStream(Settings, StreamOutput) - Static method in class org.elasticsearch.util.settings.ImmutableSettings
 
writeShort(int) - Method in class org.elasticsearch.util.io.FastDataOutputStream
Writes a short to the underlying output stream as two bytes, high byte first.
writeShort(short) - Method in class org.elasticsearch.util.io.stream.StreamOutput
 
writeStartArray() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeStartArray() - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeStartArray() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
writeStartObject() - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeStartObject() - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeStartObject() - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
writeStreamHeader() - Method in class org.elasticsearch.util.io.ThrowableObjectOutputStream
 
writeString(String) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeString(char[], int, int) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeString(String) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeString(char[], int, int) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
writeString(String) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
writeString(char[], int, int) - Method in class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
writeStringField(String, String) - Method in class org.elasticsearch.util.xcontent.json.JsonXContentGenerator
 
writeStringField(String, String) - Method in class org.elasticsearch.util.xcontent.support.AbstractXContentGenerator
 
writeStringField(String, String) - Method in interface org.elasticsearch.util.xcontent.XContentGenerator
 
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.info.NodeInfo
 
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.shutdown.TransportNodesShutdownAction.NodeShutdownRequest
 
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.ping.broadcast.BroadcastPingRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.ping.broadcast.BroadcastPingResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.ping.broadcast.BroadcastShardPingRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.ping.broadcast.BroadcastShardPingResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.IndexReplicationPingRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.IndexReplicationPingResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.ReplicationPingResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.ShardReplicationPingRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.ping.replication.ShardReplicationPingResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.ping.single.SinglePingRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.cluster.ping.single.SinglePingResponse
 
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.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.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.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.gateway.snapshot.IndexGatewaySnapshotRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.gateway.snapshot.IndexGatewaySnapshotResponse
 
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.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.status.IndicesStatusResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.admin.indices.status.ShardStatus
 
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.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.get.GetField
 
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.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.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.ShardOperationRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.single.SingleOperationRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.support.single.TransportSingleOperationAction.ShardSingleOperationRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.terms.FieldTermsFreq
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.terms.TermFreq
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.terms.TermsRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.action.terms.TermsResponse
 
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.NodeMappingCreatedAction.NodeMappingCreatedResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.ClusterName
 
writeTo(ClusterState, StreamOutput) - Static method in class org.elasticsearch.cluster.ClusterState.Builder
 
writeTo(StreamOutput) - Method in class org.elasticsearch.cluster.metadata.AliasAction
 
writeTo(IndexMetaData, StreamOutput) - Static method in class org.elasticsearch.cluster.metadata.IndexMetaData.Builder
 
writeTo(MetaData, StreamOutput) - Static method in class org.elasticsearch.cluster.metadata.MetaData.Builder
 
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.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(StreamOutput) - Method in class org.elasticsearch.discovery.zen.ping.ZenPing.PingResponse
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.Index
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.shard.ShardId
 
writeTo(StreamOutput) - Method in class org.elasticsearch.index.translog.memory.MemorySnapshot
 
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.monitor.jvm.JvmInfo.Mem
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.jvm.JvmInfo
 
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.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.Fd
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.process.ProcessStats.Mem
 
writeTo(StreamOutput) - Method in class org.elasticsearch.monitor.process.ProcessStats
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.dfs.AggregatedDfs
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.dfs.DfsSearchResult
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facets.CountFacet
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.facets.Facets
 
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.highlight.HighlightField
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.InternalScrollSearchRequest
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.internal.InternalSearchHit
 
writeTo(StreamOutput, Map<SearchShardTarget, Integer>) - 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) - 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.Scroll
 
writeTo(StreamOutput) - Method in class org.elasticsearch.search.SearchShardTarget
 
writeTo(StreamOutput) - Method in class org.elasticsearch.threadpool.ThreadPoolInfo
 
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
 
writeTo(StreamOutput) - Method in class org.elasticsearch.util.io.BooleanStreamable
 
writeTo(StreamOutput) - Method in class org.elasticsearch.util.io.compression.CompressedString
 
writeTo(OutputStream) - Method in class org.elasticsearch.util.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.util.io.FastCharArrayWriter
Writes the contents of the buffer to another character stream.
writeTo(StreamOutput) - Method in class org.elasticsearch.util.io.stream.LongStreamable
 
writeTo(StreamOutput) - Method in interface org.elasticsearch.util.io.stream.Streamable
 
writeTo(StreamOutput) - Method in class org.elasticsearch.util.io.stream.StringStreamable
 
writeTo(StreamOutput) - Method in class org.elasticsearch.util.io.stream.VoidStreamable
 
writeTo(StreamOutput) - Method in class org.elasticsearch.util.Percent
 
writeTo(StreamOutput) - Method in class org.elasticsearch.util.SizeValue
 
writeTo(StreamOutput) - Method in class org.elasticsearch.util.TimeValue
 
writeTo(StreamOutput) - Method in class org.elasticsearch.util.transport.BoundTransportAddress
 
writeTo(StreamOutput) - Method in class org.elasticsearch.util.transport.DummyTransportAddress
 
writeTo(StreamOutput) - Method in class org.elasticsearch.util.transport.InetSocketTransportAddress
 
writeTo(StreamOutput) - Method in class org.elasticsearch.util.transport.LocalTransportAddress
 
writeTopDocs(StreamOutput, TopDocs, int) - Static method in class org.elasticsearch.util.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.util.io.FastDataOutputStream
Writes a string to the underlying output stream using modified UTF-8 encoding in a machine-independent manner.
writeUTF(String) - Method in class org.elasticsearch.util.io.stream.HandlesStreamOutput
 
writeUTF(String) - Method in class org.elasticsearch.util.io.stream.StreamOutput
Writes a string.
writeVInt(int) - Method in class org.elasticsearch.util.io.stream.StreamOutput
Writes an int in a variable-length format.
writeVLong(long) - Method in class org.elasticsearch.util.io.stream.StreamOutput
Writes an long in a variable-length format.
written - Variable in class org.elasticsearch.util.io.FastDataOutputStream
The number of bytes written to the data output stream so far.

X

XContent - Interface in org.elasticsearch.util.xcontent
A generic abstraction on top of handling content, inspired by JSON and pull parsing.
xContent(XContentType) - Static method in class org.elasticsearch.util.xcontent.XContentFactory
Returns the XContent for the provided content type.
xContent(CharSequence) - Static method in class org.elasticsearch.util.xcontent.XContentFactory
Guesses the content (type) based on the provided char sequence.
xContent(byte[]) - Static method in class org.elasticsearch.util.xcontent.XContentFactory
Guesses the content type based on the provided bytes.
xContent(byte[], int, int) - Static method in class org.elasticsearch.util.xcontent.XContentFactory
Guesses the content type based on the provided bytes.
XContentAllFieldMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentAllFieldMapper() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper
 
XContentAllFieldMapper(String, Field.Store, Field.TermVector, boolean, boolean, NamedAnalyzer, NamedAnalyzer, boolean) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper
 
XContentAllFieldMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentAllFieldMapper.Builder() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper.Builder
 
XContentAllFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentAllFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentAllFieldMapper.Defaults
 
XContentBinaryFieldMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentBinaryFieldMapper(FieldMapper.Names) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentBinaryFieldMapper
 
XContentBinaryFieldMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentBinaryFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentBinaryFieldMapper.Builder
 
XContentBinaryFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.xcontent
 
XContentBinaryFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentBinaryFieldMapper.TypeParser
 
XContentBooleanFieldMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentBooleanFieldMapper(FieldMapper.Names, Field.Index, Field.Store, Field.TermVector, float, boolean, boolean, Boolean) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper
 
XContentBooleanFieldMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentBooleanFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper.Builder
 
XContentBooleanFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentBooleanFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper.Defaults
 
XContentBooleanFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.xcontent
 
XContentBooleanFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentBooleanFieldMapper.TypeParser
 
XContentBoostFieldMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentBoostFieldMapper() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
XContentBoostFieldMapper(String, String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
XContentBoostFieldMapper(String, String, int, Field.Index, Field.Store, float, boolean, boolean, Float) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper
 
XContentBoostFieldMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentBoostFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper.Builder
 
XContentBoostFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentBoostFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentBoostFieldMapper.Defaults
 
XContentBuilder<T extends XContentBuilder> - Class in org.elasticsearch.util.xcontent.builder
 
XContentBuilder() - Constructor for class org.elasticsearch.util.xcontent.builder.XContentBuilder
 
XContentBuilder.FieldCaseConversion - Enum in org.elasticsearch.util.xcontent.builder
 
XContentDateFieldMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentDateFieldMapper(FieldMapper.Names, FormatDateTimeFormatter, int, Field.Index, Field.Store, float, boolean, boolean, String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper
 
XContentDateFieldMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentDateFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper.Builder
 
XContentDateFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentDateFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper.Defaults
 
XContentDateFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.xcontent
 
XContentDateFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentDateFieldMapper.TypeParser
 
XContentDocumentMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentDocumentMapper(XContentObjectMapper, XContentUidFieldMapper, XContentIdFieldMapper, XContentTypeFieldMapper, XContentSourceFieldMapper, XContentAllFieldMapper, Analyzer, Analyzer, XContentBoostFieldMapper, String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper
 
XContentDocumentMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentDocumentMapper.Builder(XContentObjectMapper.Builder) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapper.Builder
 
XContentDocumentMapperParser - Class in org.elasticsearch.index.mapper.xcontent
 
XContentDocumentMapperParser(AnalysisService) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentDocumentMapperParser
 
XContentDoubleFieldMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentDoubleFieldMapper(FieldMapper.Names, int, Field.Index, Field.Store, float, boolean, boolean, Double) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper
 
XContentDoubleFieldMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentDoubleFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper.Builder
 
XContentDoubleFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentDoubleFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper.Defaults
 
XContentDoubleFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.xcontent
 
XContentDoubleFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentDoubleFieldMapper.TypeParser
 
XContentFactory - Class in org.elasticsearch.util.xcontent
A one stop to use XContent and XContentBuilder.
XContentFactory() - Constructor for class org.elasticsearch.util.xcontent.XContentFactory
 
XContentFieldMapper<T> - Class in org.elasticsearch.index.mapper.xcontent
 
XContentFieldMapper(FieldMapper.Names, Field.Index, Field.Store, Field.TermVector, float, boolean, boolean, NamedAnalyzer, NamedAnalyzer) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper
 
XContentFieldMapper.Builder<T extends XContentFieldMapper.Builder,Y extends XContentFieldMapper> - Class in org.elasticsearch.index.mapper.xcontent
 
XContentFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Builder
 
XContentFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.Defaults
 
XContentFieldMapper.OpenBuilder<T extends XContentFieldMapper.Builder,Y extends XContentFieldMapper> - Class in org.elasticsearch.index.mapper.xcontent
 
XContentFieldMapper.OpenBuilder(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentFieldMapper.OpenBuilder
 
XContentFilterBuilder - Interface in org.elasticsearch.index.query.xcontent
 
XContentFilterParser - Interface in org.elasticsearch.index.query.xcontent
 
XContentFilterParserFactory - Interface in org.elasticsearch.index.query.xcontent
 
XContentFloatFieldMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentFloatFieldMapper(FieldMapper.Names, int, Field.Index, Field.Store, float, boolean, boolean, Float) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper
 
XContentFloatFieldMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentFloatFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper.Builder
 
XContentFloatFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentFloatFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper.Defaults
 
XContentFloatFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.xcontent
 
XContentFloatFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentFloatFieldMapper.TypeParser
 
XContentGenerator - Interface in org.elasticsearch.util.xcontent
 
XContentIdFieldMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentIdFieldMapper() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper
 
XContentIdFieldMapper(String, String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper
 
XContentIdFieldMapper(String, String, Field.Store, Field.TermVector, float, boolean, boolean) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper
 
XContentIdFieldMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentIdFieldMapper.Builder() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper.Builder
 
XContentIdFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentIdFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentIdFieldMapper.Defaults
 
XContentIncludeInAllMapper - Interface in org.elasticsearch.index.mapper.xcontent
 
XContentIndexQueryParser - Class in org.elasticsearch.index.query.xcontent
 
XContentIndexQueryParser(Index, Settings, MapperService, IndexCache, AnalysisService, SimilarityService, Map<String, XContentQueryParserFactory>, Map<String, XContentFilterParserFactory>, String, Settings) - Constructor for class org.elasticsearch.index.query.xcontent.XContentIndexQueryParser
 
XContentIndexQueryParser.Defaults - Class in org.elasticsearch.index.query.xcontent
 
XContentIndexQueryParser.Defaults() - Constructor for class org.elasticsearch.index.query.xcontent.XContentIndexQueryParser.Defaults
 
XContentIntegerFieldMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentIntegerFieldMapper(FieldMapper.Names, int, Field.Index, Field.Store, float, boolean, boolean, Integer) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper
 
XContentIntegerFieldMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentIntegerFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper.Builder
 
XContentIntegerFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentIntegerFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper.Defaults
 
XContentIntegerFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.xcontent
 
XContentIntegerFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentIntegerFieldMapper.TypeParser
 
XContentLongFieldMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentLongFieldMapper(FieldMapper.Names, int, Field.Index, Field.Store, float, boolean, boolean, Long) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper
 
XContentLongFieldMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentLongFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper.Builder
 
XContentLongFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentLongFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper.Defaults
 
XContentLongFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.xcontent
 
XContentLongFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentLongFieldMapper.TypeParser
 
XContentMapConverter - Class in org.elasticsearch.util.xcontent.support
 
XContentMapConverter() - Constructor for class org.elasticsearch.util.xcontent.support.XContentMapConverter
 
XContentMapper - Interface in org.elasticsearch.index.mapper.xcontent
 
XContentMapper.Builder<T extends XContentMapper.Builder,Y extends XContentMapper> - Class in org.elasticsearch.index.mapper.xcontent
 
XContentMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentMapper.Builder
 
XContentMapper.BuilderContext - Class in org.elasticsearch.index.mapper.xcontent
 
XContentMapper.BuilderContext(ContentPath) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentMapper.BuilderContext
 
XContentMapperBuilders - Class in org.elasticsearch.index.mapper.xcontent
 
XContentMapValues - Class in org.elasticsearch.util.xcontent.support
 
XContentMapValues() - Constructor for class org.elasticsearch.util.xcontent.support.XContentMapValues
 
XContentMultiFieldMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentMultiFieldMapper(String, ContentPath.Type, XContentMapper) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper
 
XContentMultiFieldMapper(String, ContentPath.Type, Map<String, XContentMapper>, XContentMapper) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper
 
XContentMultiFieldMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentMultiFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper.Builder
 
XContentMultiFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentMultiFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper.Defaults
 
XContentMultiFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.xcontent
 
XContentMultiFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentMultiFieldMapper.TypeParser
 
XContentNumberFieldMapper<T extends java.lang.Number> - Class in org.elasticsearch.index.mapper.xcontent
 
XContentNumberFieldMapper(FieldMapper.Names, int, Field.Index, Field.Store, float, boolean, boolean, NamedAnalyzer, NamedAnalyzer) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper
 
XContentNumberFieldMapper.Builder<T extends XContentNumberFieldMapper.Builder,Y extends XContentNumberFieldMapper> - Class in org.elasticsearch.index.mapper.xcontent
 
XContentNumberFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.Builder
 
XContentNumberFieldMapper.CachedNumericTokenStream - Class in org.elasticsearch.index.mapper.xcontent
A wrapper around a numeric stream allowing to reuse it by implementing the end method which returns this stream back to the thread local cache.
XContentNumberFieldMapper.CachedNumericTokenStream(NumericTokenStream, int) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.CachedNumericTokenStream
 
XContentNumberFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentNumberFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentNumberFieldMapper.Defaults
 
XContentObjectMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentObjectMapper(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper
 
XContentObjectMapper(String, boolean, boolean, ContentPath.Type) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper
 
XContentObjectMapper(String, boolean, boolean, ContentPath.Type, FormatDateTimeFormatter[]) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper
 
XContentObjectMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentObjectMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.Builder
 
XContentObjectMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentObjectMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.Defaults
 
XContentObjectMapper.TypeParser - Class in org.elasticsearch.index.mapper.xcontent
 
XContentObjectMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentObjectMapper.TypeParser
 
XContentParser - Interface in org.elasticsearch.util.xcontent
 
XContentParser.NumberType - Enum in org.elasticsearch.util.xcontent
 
XContentParser.Token - Enum in org.elasticsearch.util.xcontent
 
XContentQueryBuilder - Interface in org.elasticsearch.index.query.xcontent
 
XContentQueryParser - Interface in org.elasticsearch.index.query.xcontent
 
XContentQueryParserFactory - Interface in org.elasticsearch.index.query.xcontent
 
XContentQueryParserRegistry - Class in org.elasticsearch.index.query.xcontent
 
XContentQueryParserRegistry(Index, Settings, AnalysisService, Iterable<XContentQueryParser>, Iterable<XContentFilterParser>) - Constructor for class org.elasticsearch.index.query.xcontent.XContentQueryParserRegistry
 
XContentRestResponse - Class in org.elasticsearch.rest
 
XContentRestResponse(RestRequest, RestResponse.Status) - Constructor for class org.elasticsearch.rest.XContentRestResponse
 
XContentRestResponse(RestRequest, RestResponse.Status, XContentBuilder) - Constructor for class org.elasticsearch.rest.XContentRestResponse
 
XContentShortFieldMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentShortFieldMapper(FieldMapper.Names, int, Field.Index, Field.Store, float, boolean, boolean, Short) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper
 
XContentShortFieldMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentShortFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper.Builder
 
XContentShortFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentShortFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper.Defaults
 
XContentShortFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.xcontent
 
XContentShortFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentShortFieldMapper.TypeParser
 
XContentSourceFieldMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentSourceFieldMapper() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper
 
XContentSourceFieldMapper(String, boolean) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper
 
XContentSourceFieldMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentSourceFieldMapper.Builder() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper.Builder
 
XContentSourceFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentSourceFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentSourceFieldMapper.Defaults
 
XContentSpanQueryBuilder - Interface in org.elasticsearch.index.query.xcontent
 
XContentStringFieldMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentStringFieldMapper(FieldMapper.Names, Field.Index, Field.Store, Field.TermVector, float, boolean, boolean, String, NamedAnalyzer, NamedAnalyzer) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper
 
XContentStringFieldMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentStringFieldMapper.Builder(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper.Builder
 
XContentStringFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentStringFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper.Defaults
 
XContentStringFieldMapper.TypeParser - Class in org.elasticsearch.index.mapper.xcontent
 
XContentStringFieldMapper.TypeParser() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentStringFieldMapper.TypeParser
 
XContentThrowableRestResponse - Class in org.elasticsearch.rest
 
XContentThrowableRestResponse(RestRequest, Throwable) - Constructor for class org.elasticsearch.rest.XContentThrowableRestResponse
 
XContentThrowableRestResponse(RestRequest, RestResponse.Status, Throwable) - Constructor for class org.elasticsearch.rest.XContentThrowableRestResponse
 
xContentType(CharSequence) - Static method in class org.elasticsearch.util.xcontent.XContentFactory
Guesses the content type based on the provided char sequence.
xContentType(byte[]) - Static method in class org.elasticsearch.util.xcontent.XContentFactory
Guesses the content type based on the provided bytes.
xContentType(byte[], int, int) - Static method in class org.elasticsearch.util.xcontent.XContentFactory
Guesses the content type based on the provided bytes.
XContentType - Enum in org.elasticsearch.util.xcontent
The content type of XContent.
XContentTypeFieldMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentTypeFieldMapper() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper
 
XContentTypeFieldMapper(String, String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper
 
XContentTypeFieldMapper(String, String, Field.Store, Field.TermVector, float, boolean, boolean) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper
 
XContentTypeFieldMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentTypeFieldMapper.Builder() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper.Builder
 
XContentTypeFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentTypeFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentTypeFieldMapper.Defaults
 
XContentTypeParser - Interface in org.elasticsearch.index.mapper.xcontent
 
XContentTypeParser.ParserContext - Class in org.elasticsearch.index.mapper.xcontent
 
XContentTypeParser.ParserContext(Map<String, Object>, AnalysisService, ImmutableMap<String, XContentTypeParser>) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentTypeParser.ParserContext
 
XContentTypeParsers - Class in org.elasticsearch.index.mapper.xcontent
 
XContentTypeParsers() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentTypeParsers
 
XContentUidFieldMapper - Class in org.elasticsearch.index.mapper.xcontent
 
XContentUidFieldMapper() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper
 
XContentUidFieldMapper(String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper
 
XContentUidFieldMapper(String, String) - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper
 
XContentUidFieldMapper.Builder - Class in org.elasticsearch.index.mapper.xcontent
 
XContentUidFieldMapper.Builder() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper.Builder
 
XContentUidFieldMapper.Defaults - Class in org.elasticsearch.index.mapper.xcontent
 
XContentUidFieldMapper.Defaults() - Constructor for class org.elasticsearch.index.mapper.xcontent.XContentUidFieldMapper.Defaults
 
xsonBuilder() - Static method in class org.elasticsearch.util.xcontent.XContentFactory
Returns a binary content builder using XSON format (XContentType.XSON.
XsonType - Enum in org.elasticsearch.util.xcontent.xson
 
XsonXContent - Class in org.elasticsearch.util.xcontent.xson
A binary representation of content (basically, JSON encoded in optimized binary format).
XsonXContent() - Constructor for class org.elasticsearch.util.xcontent.xson.XsonXContent
 
XsonXContent.CachedBinaryBuilder - Class in org.elasticsearch.util.xcontent.xson
 
XsonXContent.CachedBinaryBuilder() - Constructor for class org.elasticsearch.util.xcontent.xson.XsonXContent.CachedBinaryBuilder
 
XsonXContentGenerator - Class in org.elasticsearch.util.xcontent.xson
 
XsonXContentGenerator(OutputStream) - Constructor for class org.elasticsearch.util.xcontent.xson.XsonXContentGenerator
 
XsonXContentParser - Class in org.elasticsearch.util.xcontent.xson
 
XsonXContentParser(InputStream) - Constructor for class org.elasticsearch.util.xcontent.xson.XsonXContentParser
 

Y

YamlSettingsLoader - Class in org.elasticsearch.util.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.util.settings.loader.YamlSettingsLoader
 
YELLOW - Static variable in class org.elasticsearch.util.jline.ANSI.Code
 

Z

ZenDiscovery - Class in org.elasticsearch.discovery.zen
 
ZenDiscovery(Settings, ClusterName, ThreadPool, TransportService, ClusterService, 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) - Constructor for class org.elasticsearch.discovery.zen.ping.ZenPingService
 
ZipCompressor - Class in org.elasticsearch.util.io.compression
 
ZipCompressor() - Constructor for class org.elasticsearch.util.io.compression.ZipCompressor
 
ZipCompressor(int) - Constructor for class org.elasticsearch.util.io.compression.ZipCompressor
 

_

_autoCompactionFactor - Variable in class org.elasticsearch.util.gnu.trove.THash
The auto-compaction factor for the table.
_autoCompactRemovesRemaining - Variable in class org.elasticsearch.util.gnu.trove.THash
The number of removes that should be performed before an auto-compaction occurs.
_data - Variable in class org.elasticsearch.util.gnu.trove.TByteArrayList
the data of the list
_data - Variable in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
the data of the list
_data - Variable in class org.elasticsearch.util.gnu.trove.TFloatArrayList
the data of the list
_data - Variable in class org.elasticsearch.util.gnu.trove.TIntArrayList
the data of the list
_data - Variable in class org.elasticsearch.util.gnu.trove.TLongArrayList
the data of the list
_data - Variable in class org.elasticsearch.util.gnu.trove.TShortArrayList
the data of the list
_free - Variable in class org.elasticsearch.util.gnu.trove.THash
the current number of free slots in the hash.
_hashingStrategy - Variable in class org.elasticsearch.util.gnu.trove.TByteHash
strategy used to hash values in this collection
_hashingStrategy - Variable in class org.elasticsearch.util.gnu.trove.TDoubleHash
strategy used to hash values in this collection
_hashingStrategy - Variable in class org.elasticsearch.util.gnu.trove.TFloatHash
strategy used to hash values in this collection
_hashingStrategy - Variable in class org.elasticsearch.util.gnu.trove.TIntHash
strategy used to hash values in this collection
_hashingStrategy - Variable in class org.elasticsearch.util.gnu.trove.TLongHash
strategy used to hash values in this collection
_hashingStrategy - Variable in class org.elasticsearch.util.gnu.trove.TObjectHash
the strategy used to hash objects in this collection.
_hashingStrategy - Variable in class org.elasticsearch.util.gnu.trove.TShortHash
strategy used to hash values in this collection
_head - Variable in class org.elasticsearch.util.gnu.trove.TLinkedList
the head of the list
_list - Variable in class org.elasticsearch.util.gnu.trove.TByteStack
the list used to hold the stack values.
_list - Variable in class org.elasticsearch.util.gnu.trove.TDoubleStack
the list used to hold the stack values.
_list - Variable in class org.elasticsearch.util.gnu.trove.TFloatStack
the list used to hold the stack values.
_list - Variable in class org.elasticsearch.util.gnu.trove.TIntStack
the list used to hold the stack values.
_list - Variable in class org.elasticsearch.util.gnu.trove.TLongStack
the list used to hold the stack values.
_list - Variable in class org.elasticsearch.util.gnu.trove.TShortStack
the list used to hold the stack values.
_loadFactor - Variable in class org.elasticsearch.util.gnu.trove.THash
Determines how full the internal table can become before rehashing is required.
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TByteByteHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TByteDoubleHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TByteFloatHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TByteIntHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TByteLongHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TByteObjectHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TByteShortHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TDoubleByteHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TDoubleDoubleHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TDoubleFloatHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TDoubleIntHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TDoubleLongHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TDoubleObjectHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TDoubleShortHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TFloatByteHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TFloatDoubleHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TFloatFloatHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TFloatIntHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TFloatLongHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TFloatObjectHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TFloatShortHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TIntByteHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TIntDoubleHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TIntFloatHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TIntIntHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TIntLongHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TIntObjectHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TIntShortHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TLongByteHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TLongDoubleHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TLongFloatHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TLongIntHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TLongLongHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TLongObjectHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TLongShortHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TObjectByteHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TObjectDoubleHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TObjectFloatHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TObjectIntHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TObjectLongHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TObjectShortHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TShortByteHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TShortDoubleHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TShortFloatHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TShortIntHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TShortLongHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TShortObjectHashMapDecorator
the wrapped primitive map
_map - Variable in class org.elasticsearch.util.gnu.trove.decorator.TShortShortHashMapDecorator
the wrapped primitive map
_maxSize - Variable in class org.elasticsearch.util.gnu.trove.THash
The maximum number of elements allowed without allocating more space.
_pos - Variable in class org.elasticsearch.util.gnu.trove.TByteArrayList
the index after the last entry in the list
_pos - Variable in class org.elasticsearch.util.gnu.trove.TDoubleArrayList
the index after the last entry in the list
_pos - Variable in class org.elasticsearch.util.gnu.trove.TFloatArrayList
the index after the last entry in the list
_pos - Variable in class org.elasticsearch.util.gnu.trove.TIntArrayList
the index after the last entry in the list
_pos - Variable in class org.elasticsearch.util.gnu.trove.TLongArrayList
the index after the last entry in the list
_pos - Variable in class org.elasticsearch.util.gnu.trove.TShortArrayList
the index after the last entry in the list
_set - Variable in class org.elasticsearch.util.gnu.trove.decorator.TByteHashSetDecorator
the wrapped primitive set
_set - Variable in class org.elasticsearch.util.gnu.trove.decorator.TDoubleHashSetDecorator
the wrapped primitive set
_set - Variable in class org.elasticsearch.util.gnu.trove.decorator.TFloatHashSetDecorator
the wrapped primitive set
_set - Variable in class org.elasticsearch.util.gnu.trove.decorator.TIntHashSetDecorator
the wrapped primitive set
_set - Variable in class org.elasticsearch.util.gnu.trove.decorator.TLongHashSetDecorator
the wrapped primitive set
_set - Variable in class org.elasticsearch.util.gnu.trove.decorator.TShortHashSetDecorator
the wrapped primitive set
_set - Variable in class org.elasticsearch.util.gnu.trove.TByteHash
the set of bytes
_set - Variable in class org.elasticsearch.util.gnu.trove.TDoubleHash
the set of doubles
_set - Variable in class org.elasticsearch.util.gnu.trove.TFloatHash
the set of floats
_set - Variable in class org.elasticsearch.util.gnu.trove.TIntHash
the set of ints
_set - Variable in class org.elasticsearch.util.gnu.trove.TLongHash
the set of longs
_set - Variable in class org.elasticsearch.util.gnu.trove.TObjectHash
the set of Objects
_set - Variable in class org.elasticsearch.util.gnu.trove.TShortHash
the set of shorts
_size - Variable in class org.elasticsearch.util.gnu.trove.THash
the current number of occupied slots in the hash.
_size - Variable in class org.elasticsearch.util.gnu.trove.TLinkedList
the number of elements in the list
_states - Variable in class org.elasticsearch.util.gnu.trove.TPrimitiveHash
flags indicating whether each position in the hash is FREE, FULL, or REMOVED
_tail - Variable in class org.elasticsearch.util.gnu.trove.TLinkedList
the tail of the list
_values - Variable in class org.elasticsearch.util.gnu.trove.TByteByteHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TByteDoubleHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TByteFloatHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TByteIntHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TByteLongHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TByteObjectHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TByteShortHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TDoubleByteHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TDoubleDoubleHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TDoubleFloatHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TDoubleIntHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TDoubleLongHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TDoubleObjectHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TDoubleShortHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TFloatByteHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TFloatDoubleHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TFloatFloatHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TFloatIntHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TFloatLongHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TFloatObjectHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TFloatShortHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.THashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TIntByteHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TIntDoubleHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TIntFloatHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TIntIntHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TIntLongHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TIntObjectHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TIntShortHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TLongByteHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TLongDoubleHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TLongFloatHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TLongIntHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TLongLongHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TLongObjectHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TLongShortHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TObjectByteHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TObjectDoubleHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TObjectFloatHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TObjectIntHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TObjectLongHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TObjectShortHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TShortByteHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TShortDoubleHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TShortFloatHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TShortIntHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TShortLongHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TShortObjectHashMap
the values of the map
_values - Variable in class org.elasticsearch.util.gnu.trove.TShortShortHashMap
the values of the map

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 _