Uses of Class
org.elasticsearch.ElasticSearchException

Packages that use ElasticSearchException
org.elasticsearch   
org.elasticsearch.action   
org.elasticsearch.action.admin.cluster.health   
org.elasticsearch.action.admin.cluster.node.hotthreads   
org.elasticsearch.action.admin.cluster.node.info   
org.elasticsearch.action.admin.cluster.node.restart   
org.elasticsearch.action.admin.cluster.node.shutdown   
org.elasticsearch.action.admin.cluster.node.stats   
org.elasticsearch.action.admin.cluster.reroute   
org.elasticsearch.action.admin.cluster.settings   
org.elasticsearch.action.admin.cluster.state   
org.elasticsearch.action.admin.indices.alias   
org.elasticsearch.action.admin.indices.analyze   
org.elasticsearch.action.admin.indices.cache.clear   
org.elasticsearch.action.admin.indices.close   
org.elasticsearch.action.admin.indices.create Create index action. 
org.elasticsearch.action.admin.indices.delete Delete index action. 
org.elasticsearch.action.admin.indices.exists   
org.elasticsearch.action.admin.indices.flush Flush index/indices action. 
org.elasticsearch.action.admin.indices.gateway.snapshot GAteway Snapshot Action. 
org.elasticsearch.action.admin.indices.mapping.delete   
org.elasticsearch.action.admin.indices.mapping.put Put Mapping Action. 
org.elasticsearch.action.admin.indices.open   
org.elasticsearch.action.admin.indices.optimize Optimize index/indices action. 
org.elasticsearch.action.admin.indices.refresh Refresh index/indices action. 
org.elasticsearch.action.admin.indices.segments   
org.elasticsearch.action.admin.indices.settings   
org.elasticsearch.action.admin.indices.stats   
org.elasticsearch.action.admin.indices.status   
org.elasticsearch.action.admin.indices.template.delete   
org.elasticsearch.action.admin.indices.template.put   
org.elasticsearch.action.admin.indices.validate.query Validate action. 
org.elasticsearch.action.admin.indices.warmer.delete   
org.elasticsearch.action.admin.indices.warmer.put   
org.elasticsearch.action.count Count action. 
org.elasticsearch.action.explain Explain action. 
org.elasticsearch.action.get Get action. 
org.elasticsearch.action.index Index action. 
org.elasticsearch.action.percolate   
org.elasticsearch.action.search Search action. 
org.elasticsearch.action.support   
org.elasticsearch.action.support.broadcast   
org.elasticsearch.action.support.master   
org.elasticsearch.action.support.nodes   
org.elasticsearch.action.support.replication   
org.elasticsearch.action.support.single.custom   
org.elasticsearch.action.support.single.instance   
org.elasticsearch.action.support.single.shard   
org.elasticsearch.action.update   
org.elasticsearch.bulk.udp   
org.elasticsearch.client.transport   
org.elasticsearch.cluster.action.index   
org.elasticsearch.cluster.action.shard   
org.elasticsearch.cluster.block   
org.elasticsearch.cluster.routing   
org.elasticsearch.cluster.service   
org.elasticsearch.common.blobstore   
org.elasticsearch.common.component   
org.elasticsearch.common.lease   
org.elasticsearch.common.settings Settings based utility. 
org.elasticsearch.common.util.concurrent   
org.elasticsearch.discovery   
org.elasticsearch.discovery.local   
org.elasticsearch.discovery.zen   
org.elasticsearch.discovery.zen.membership   
org.elasticsearch.discovery.zen.ping   
org.elasticsearch.discovery.zen.ping.multicast   
org.elasticsearch.discovery.zen.ping.unicast   
org.elasticsearch.env   
org.elasticsearch.gateway   
org.elasticsearch.gateway.blobstore   
org.elasticsearch.gateway.fs   
org.elasticsearch.gateway.local   
org.elasticsearch.gateway.local.state.meta   
org.elasticsearch.gateway.local.state.shards   
org.elasticsearch.gateway.none   
org.elasticsearch.gateway.shared   
org.elasticsearch.http   
org.elasticsearch.http.netty   
org.elasticsearch.index   
org.elasticsearch.index.cache   
org.elasticsearch.index.cache.bloom.none   
org.elasticsearch.index.cache.bloom.simple   
org.elasticsearch.index.cache.field.data.none   
org.elasticsearch.index.cache.field.data.resident   
org.elasticsearch.index.cache.field.data.support   
org.elasticsearch.index.cache.filter.weighted   
org.elasticsearch.index.cache.id.simple   
org.elasticsearch.index.cache.query.parser.none   
org.elasticsearch.index.cache.query.parser.resident   
org.elasticsearch.index.cache.query.parser.support   
org.elasticsearch.index.engine   
org.elasticsearch.index.engine.robin   
org.elasticsearch.index.gateway   
org.elasticsearch.index.gateway.blobstore   
org.elasticsearch.index.get   
org.elasticsearch.index.mapper   
org.elasticsearch.index.merge.policy   
org.elasticsearch.index.percolator   
org.elasticsearch.index.query   
org.elasticsearch.index.service   
org.elasticsearch.index.shard   
org.elasticsearch.index.shard.service   
org.elasticsearch.index.store   
org.elasticsearch.index.store.support   
org.elasticsearch.index.translog   
org.elasticsearch.index.translog.fs   
org.elasticsearch.indices   
org.elasticsearch.indices.cluster   
org.elasticsearch.indices.memory   
org.elasticsearch.indices.recovery   
org.elasticsearch.indices.store   
org.elasticsearch.indices.ttl   
org.elasticsearch.jmx   
org.elasticsearch.jmx.action   
org.elasticsearch.monitor   
org.elasticsearch.monitor.dump   
org.elasticsearch.monitor.jvm   
org.elasticsearch.node Allow to build a Node using NodeBuilder which is a node within the cluster. 
org.elasticsearch.node.internal   
org.elasticsearch.rest   
org.elasticsearch.river   
org.elasticsearch.river.cluster   
org.elasticsearch.river.routing   
org.elasticsearch.script   
org.elasticsearch.search   
org.elasticsearch.search.builder   
org.elasticsearch.search.dfs   
org.elasticsearch.search.facet   
org.elasticsearch.search.fetch   
org.elasticsearch.search.fetch.explain   
org.elasticsearch.search.fetch.matchedfilters   
org.elasticsearch.search.fetch.partial   
org.elasticsearch.search.fetch.script   
org.elasticsearch.search.fetch.version   
org.elasticsearch.search.highlight   
org.elasticsearch.search.internal   
org.elasticsearch.search.query   
org.elasticsearch.search.warmer   
org.elasticsearch.transport   
org.elasticsearch.transport.local   
org.elasticsearch.transport.netty   
 

Uses of ElasticSearchException in org.elasticsearch
 

Subclasses of ElasticSearchException in org.elasticsearch
 class ElasticSearchGenerationException
          A generic exception indicating failure to generate.
 class ElasticSearchIllegalArgumentException
           
 class ElasticSearchIllegalStateException
           
 class ElasticSearchInterruptedException
          The same as InterruptedException simply a runtime one.
 class ElasticSearchNullPointerException
           
 class ElasticSearchParseException
           
 class ElasticSearchTimeoutException
          The same as TimeoutException simply a runtime one.
 

Uses of ElasticSearchException in org.elasticsearch.action
 

Subclasses of ElasticSearchException in org.elasticsearch.action
 class ActionRequestValidationException
           
 class FailedNodeException
           
 class NoShardAvailableActionException
           
 class NoSuchNodeException
           
 class PrimaryMissingActionException
           
 class RoutingMissingException
           
 class TimestampParsingException
           
 class UnavailableShardsException
           
 

Methods in org.elasticsearch.action that throw ElasticSearchException
 T ActionFuture.actionGet()
          Similar to Future.get(), just wrapping the InterruptedException with ElasticSearchInterruptedException, and throwing the actual cause of the ExecutionException.
 T ActionFuture.actionGet(long timeoutMillis)
          Similar to Future.get(long, java.util.concurrent.TimeUnit), just wrapping the InterruptedException with ElasticSearchInterruptedException, and throwing the actual cause of the ExecutionException.
 T ActionFuture.actionGet(long timeout, TimeUnit unit)
          Similar to Future.get(long, java.util.concurrent.TimeUnit), just wrapping the InterruptedException with ElasticSearchInterruptedException, and throwing the actual cause of the ExecutionException.
 T ActionFuture.actionGet(String timeout)
          Similar to Future.get(long, java.util.concurrent.TimeUnit), just wrapping the InterruptedException with ElasticSearchInterruptedException, and throwing the actual cause of the ExecutionException.
 T ActionFuture.actionGet(TimeValue timeout)
          Similar to Future.get(long, java.util.concurrent.TimeUnit), just wrapping the InterruptedException with ElasticSearchInterruptedException, and throwing the actual cause of the ExecutionException.
 ActionFuture<Response> TransportActionNodeProxy.execute(DiscoveryNode node, Request request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.cluster.health
 

Methods in org.elasticsearch.action.admin.cluster.health that throw ElasticSearchException
protected  ClusterHealthResponse TransportClusterHealthAction.masterOperation(ClusterHealthRequest request, ClusterState unusedState)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.cluster.node.hotthreads
 

Methods in org.elasticsearch.action.admin.cluster.node.hotthreads that throw ElasticSearchException
protected  NodeHotThreads TransportNodesHotThreadsAction.nodeOperation(org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction.NodeRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.cluster.node.info
 

Methods in org.elasticsearch.action.admin.cluster.node.info that throw ElasticSearchException
protected  NodeInfo TransportNodesInfoAction.nodeOperation(org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction.NodeInfoRequest nodeRequest)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.cluster.node.restart
 

Methods in org.elasticsearch.action.admin.cluster.node.restart that throw ElasticSearchException
protected  NodesRestartResponse.NodeRestartResponse TransportNodesRestartAction.nodeOperation(TransportNodesRestartAction.NodeRestartRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.cluster.node.shutdown
 

Methods in org.elasticsearch.action.admin.cluster.node.shutdown that throw ElasticSearchException
protected  NodesShutdownResponse TransportNodesShutdownAction.masterOperation(NodesShutdownRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.cluster.node.stats
 

Methods in org.elasticsearch.action.admin.cluster.node.stats that throw ElasticSearchException
protected  NodeStats TransportNodesStatsAction.nodeOperation(org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction.NodeStatsRequest nodeStatsRequest)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.cluster.reroute
 

Methods in org.elasticsearch.action.admin.cluster.reroute that throw ElasticSearchException
protected  ClusterRerouteResponse TransportClusterRerouteAction.masterOperation(ClusterRerouteRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.cluster.settings
 

Methods in org.elasticsearch.action.admin.cluster.settings that throw ElasticSearchException
protected  ClusterUpdateSettingsResponse TransportClusterUpdateSettingsAction.masterOperation(ClusterUpdateSettingsRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.cluster.state
 

Methods in org.elasticsearch.action.admin.cluster.state that throw ElasticSearchException
protected  ClusterStateResponse TransportClusterStateAction.masterOperation(ClusterStateRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.alias
 

Methods in org.elasticsearch.action.admin.indices.alias that throw ElasticSearchException
protected  IndicesAliasesResponse TransportIndicesAliasesAction.masterOperation(IndicesAliasesRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.analyze
 

Methods in org.elasticsearch.action.admin.indices.analyze that throw ElasticSearchException
protected  AnalyzeResponse TransportAnalyzeAction.shardOperation(AnalyzeRequest request, int shardId)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.cache.clear
 

Methods in org.elasticsearch.action.admin.indices.cache.clear that throw ElasticSearchException
protected  org.elasticsearch.action.admin.indices.cache.clear.ShardClearIndicesCacheResponse TransportClearIndicesCacheAction.shardOperation(org.elasticsearch.action.admin.indices.cache.clear.ShardClearIndicesCacheRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.close
 

Methods in org.elasticsearch.action.admin.indices.close that throw ElasticSearchException
protected  CloseIndexResponse TransportCloseIndexAction.masterOperation(CloseIndexRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.create
 

Methods in org.elasticsearch.action.admin.indices.create that throw ElasticSearchException
protected  CreateIndexResponse TransportCreateIndexAction.masterOperation(CreateIndexRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.delete
 

Methods in org.elasticsearch.action.admin.indices.delete that throw ElasticSearchException
protected  DeleteIndexResponse TransportDeleteIndexAction.masterOperation(DeleteIndexRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.exists
 

Methods in org.elasticsearch.action.admin.indices.exists that throw ElasticSearchException
protected  IndicesExistsResponse TransportIndicesExistsAction.masterOperation(IndicesExistsRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.flush
 

Methods in org.elasticsearch.action.admin.indices.flush that throw ElasticSearchException
protected  org.elasticsearch.action.admin.indices.flush.ShardFlushResponse TransportFlushAction.shardOperation(org.elasticsearch.action.admin.indices.flush.ShardFlushRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.gateway.snapshot
 

Methods in org.elasticsearch.action.admin.indices.gateway.snapshot that throw ElasticSearchException
protected  org.elasticsearch.action.admin.indices.gateway.snapshot.ShardGatewaySnapshotResponse TransportGatewaySnapshotAction.shardOperation(org.elasticsearch.action.admin.indices.gateway.snapshot.ShardGatewaySnapshotRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.mapping.delete
 

Methods in org.elasticsearch.action.admin.indices.mapping.delete that throw ElasticSearchException
protected  DeleteMappingResponse TransportDeleteMappingAction.masterOperation(DeleteMappingRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.mapping.put
 

Methods in org.elasticsearch.action.admin.indices.mapping.put that throw ElasticSearchException
protected  PutMappingResponse TransportPutMappingAction.masterOperation(PutMappingRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.open
 

Methods in org.elasticsearch.action.admin.indices.open that throw ElasticSearchException
protected  OpenIndexResponse TransportOpenIndexAction.masterOperation(OpenIndexRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.optimize
 

Methods in org.elasticsearch.action.admin.indices.optimize that throw ElasticSearchException
protected  org.elasticsearch.action.admin.indices.optimize.ShardOptimizeResponse TransportOptimizeAction.shardOperation(org.elasticsearch.action.admin.indices.optimize.ShardOptimizeRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.refresh
 

Methods in org.elasticsearch.action.admin.indices.refresh that throw ElasticSearchException
protected  org.elasticsearch.action.admin.indices.refresh.ShardRefreshResponse TransportRefreshAction.shardOperation(org.elasticsearch.action.admin.indices.refresh.ShardRefreshRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.segments
 

Methods in org.elasticsearch.action.admin.indices.segments that throw ElasticSearchException
protected  ShardSegments TransportIndicesSegmentsAction.shardOperation(TransportIndicesSegmentsAction.IndexShardSegmentRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.settings
 

Methods in org.elasticsearch.action.admin.indices.settings that throw ElasticSearchException
protected  UpdateSettingsResponse TransportUpdateSettingsAction.masterOperation(UpdateSettingsRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.stats
 

Methods in org.elasticsearch.action.admin.indices.stats that throw ElasticSearchException
protected  ShardStats TransportIndicesStatsAction.shardOperation(TransportIndicesStatsAction.IndexShardStatsRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.status
 

Methods in org.elasticsearch.action.admin.indices.status that throw ElasticSearchException
protected  ShardStatus TransportIndicesStatusAction.shardOperation(TransportIndicesStatusAction.IndexShardStatusRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.template.delete
 

Methods in org.elasticsearch.action.admin.indices.template.delete that throw ElasticSearchException
protected  DeleteIndexTemplateResponse TransportDeleteIndexTemplateAction.masterOperation(DeleteIndexTemplateRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.template.put
 

Methods in org.elasticsearch.action.admin.indices.template.put that throw ElasticSearchException
protected  PutIndexTemplateResponse TransportPutIndexTemplateAction.masterOperation(PutIndexTemplateRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.validate.query
 

Methods in org.elasticsearch.action.admin.indices.validate.query that throw ElasticSearchException
protected  org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryResponse TransportValidateQueryAction.shardOperation(org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.warmer.delete
 

Methods in org.elasticsearch.action.admin.indices.warmer.delete that throw ElasticSearchException
protected  DeleteWarmerResponse TransportDeleteWarmerAction.masterOperation(DeleteWarmerRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.admin.indices.warmer.put
 

Methods in org.elasticsearch.action.admin.indices.warmer.put that throw ElasticSearchException
protected  PutWarmerResponse TransportPutWarmerAction.masterOperation(PutWarmerRequest request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.count
 

Methods in org.elasticsearch.action.count that throw ElasticSearchException
protected  org.elasticsearch.action.count.ShardCountResponse TransportCountAction.shardOperation(org.elasticsearch.action.count.ShardCountRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.explain
 

Methods in org.elasticsearch.action.explain that throw ElasticSearchException
protected  ExplainResponse TransportExplainAction.shardOperation(ExplainRequest request, int shardId)
           
protected  ShardIterator TransportExplainAction.shards(ClusterState state, ExplainRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.get
 

Methods in org.elasticsearch.action.get that throw ElasticSearchException
protected  GetResponse TransportGetAction.shardOperation(GetRequest request, int shardId)
           
protected  MultiGetShardResponse TransportShardMultiGetAction.shardOperation(MultiGetShardRequest request, int shardId)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.index
 

Methods in org.elasticsearch.action.index that throw ElasticSearchException
 void IndexRequest.process(MetaData metaData, String aliasOrIndex, MappingMetaData mappingMd, boolean allowIdGeneration)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.percolate
 

Methods in org.elasticsearch.action.percolate that throw ElasticSearchException
protected  PercolateResponse TransportPercolateAction.shardOperation(PercolateRequest request, int shardId)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.search
 

Subclasses of ElasticSearchException in org.elasticsearch.action.search
 class ReduceSearchPhaseException
          A failure during a reduce phase (when receiving results from several shards, and reducing them into one or more results and possible actions).
 class SearchPhaseExecutionException
           
 

Uses of ElasticSearchException in org.elasticsearch.action.support
 

Methods in org.elasticsearch.action.support that throw ElasticSearchException
 T AdapterActionFuture.actionGet()
           
 T AdapterActionFuture.actionGet(long timeoutMillis)
           
 T AdapterActionFuture.actionGet(long timeout, TimeUnit unit)
           
 T AdapterActionFuture.actionGet(String timeout)
           
 T AdapterActionFuture.actionGet(TimeValue timeout)
           
 ActionFuture<Response> TransportAction.execute(Request request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.support.broadcast
 

Subclasses of ElasticSearchException in org.elasticsearch.action.support.broadcast
 class BroadcastShardOperationFailedException
          An exception indicating that a failure occurred performing an operation on the shard.
 

Methods in org.elasticsearch.action.support.broadcast that throw ElasticSearchException
protected abstract  ShardResponse TransportBroadcastOperationAction.shardOperation(ShardRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.support.master
 

Methods in org.elasticsearch.action.support.master that throw ElasticSearchException
protected abstract  Response TransportMasterNodeOperationAction.masterOperation(Request request, ClusterState state)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.support.nodes
 

Methods in org.elasticsearch.action.support.nodes that throw ElasticSearchException
protected abstract  NodeResponse TransportNodesOperationAction.nodeOperation(NodeRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.support.replication
 

Subclasses of ElasticSearchException in org.elasticsearch.action.support.replication
 class ReplicationShardOperationFailedException
          An exception indicating that a failure occurred performing an operation on the shard.
 

Methods in org.elasticsearch.action.support.replication that throw ElasticSearchException
protected abstract  ShardIterator TransportShardReplicationOperationAction.shards(ClusterState clusterState, Request request)
           
protected abstract  GroupShardsIterator TransportIndexReplicationOperationAction.shards(Request request)
           
 boolean TransportShardReplicationOperationAction.AsyncShardOperationAction.start(boolean fromClusterEvent)
          Returns true if the action starting to be performed on the primary (or is done).
 

Uses of ElasticSearchException in org.elasticsearch.action.support.single.custom
 

Methods in org.elasticsearch.action.support.single.custom that throw ElasticSearchException
protected abstract  Response TransportSingleCustomOperationAction.shardOperation(Request request, int shardId)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.support.single.instance
 

Methods in org.elasticsearch.action.support.single.instance that throw ElasticSearchException
protected abstract  void TransportInstanceSingleOperationAction.shardOperation(Request request, ActionListener<Response> listener)
           
protected abstract  ShardIterator TransportInstanceSingleOperationAction.shards(ClusterState clusterState, Request request)
          Should return an iterator with a single shard!
 

Uses of ElasticSearchException in org.elasticsearch.action.support.single.shard
 

Methods in org.elasticsearch.action.support.single.shard that throw ElasticSearchException
protected abstract  Response TransportShardSingleOperationAction.shardOperation(Request request, int shardId)
           
protected abstract  ShardIterator TransportShardSingleOperationAction.shards(ClusterState state, Request request)
           
 

Uses of ElasticSearchException in org.elasticsearch.action.update
 

Methods in org.elasticsearch.action.update that throw ElasticSearchException
protected  void TransportUpdateAction.shardOperation(UpdateRequest request, ActionListener<UpdateResponse> listener)
           
protected  void TransportUpdateAction.shardOperation(UpdateRequest request, ActionListener<UpdateResponse> listener, int retryCount)
           
protected  ShardIterator TransportUpdateAction.shards(ClusterState clusterState, UpdateRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.bulk.udp
 

Methods in org.elasticsearch.bulk.udp that throw ElasticSearchException
protected  void BulkUdpService.doClose()
           
protected  void BulkUdpService.doStart()
           
protected  void BulkUdpService.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.client.transport
 

Subclasses of ElasticSearchException in org.elasticsearch.client.transport
 class NoNodeAvailableException
          An exception indicating no node is available to perform the operation.
 

Methods in org.elasticsearch.client.transport that throw ElasticSearchException
 T TransportClientNodesService.NodeCallback.doWithNode(DiscoveryNode node)
           
 void TransportClientNodesService.NodeListenerCallback.doWithNode(DiscoveryNode node, ActionListener<Response> listener)
           
<T> T
TransportClientNodesService.execute(TransportClientNodesService.NodeCallback<T> callback)
           
<Response> void
TransportClientNodesService.execute(TransportClientNodesService.NodeListenerCallback<Response> callback, ActionListener<Response> listener)
           
 

Constructors in org.elasticsearch.client.transport that throw ElasticSearchException
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.Builder settings, boolean loadConfigSettings)
          Constructs a new transport client with the provided settings and the ability to control if settings will be loaded from the classpath / file system (the elasticsearch.(yml|json) files optionally prefixed with config/).
TransportClient(Settings pSettings, boolean loadConfigSettings)
          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/).
 

Uses of ElasticSearchException in org.elasticsearch.cluster.action.index
 

Methods in org.elasticsearch.cluster.action.index that throw ElasticSearchException
protected  MappingUpdatedAction.MappingUpdatedResponse MappingUpdatedAction.masterOperation(MappingUpdatedAction.MappingUpdatedRequest request, ClusterState state)
           
 void NodeAliasesUpdatedAction.nodeAliasesUpdated(NodeAliasesUpdatedAction.NodeAliasesUpdatedResponse response)
           
 void NodeIndexCreatedAction.nodeIndexCreated(String index, String nodeId)
           
 void NodeIndexDeletedAction.nodeIndexDeleted(String index, String nodeId)
           
 void NodeMappingCreatedAction.nodeMappingCreated(NodeMappingCreatedAction.NodeMappingCreatedResponse response)
           
 void NodeMappingRefreshAction.nodeMappingRefresh(NodeMappingRefreshAction.NodeMappingRefreshRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.cluster.action.shard
 

Methods in org.elasticsearch.cluster.action.shard that throw ElasticSearchException
 void ShardStateAction.shardFailed(ShardRouting shardRouting, String reason)
           
 void ShardStateAction.shardStarted(ShardRouting shardRouting, String reason)
           
 

Uses of ElasticSearchException in org.elasticsearch.cluster.block
 

Subclasses of ElasticSearchException in org.elasticsearch.cluster.block
 class ClusterBlockException
           
 

Uses of ElasticSearchException in org.elasticsearch.cluster.routing
 

Subclasses of ElasticSearchException in org.elasticsearch.cluster.routing
 class IllegalShardRoutingStateException
           
 class RoutingException
           
 class RoutingValidationException
           
 

Methods in org.elasticsearch.cluster.routing that throw ElasticSearchException
protected  void RoutingService.doClose()
           
protected  void RoutingService.doStart()
           
protected  void RoutingService.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.cluster.service
 

Methods in org.elasticsearch.cluster.service that throw ElasticSearchException
protected  void InternalClusterService.doClose()
           
protected  void InternalClusterService.doStart()
           
protected  void InternalClusterService.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.common.blobstore
 

Subclasses of ElasticSearchException in org.elasticsearch.common.blobstore
 class BlobStoreException
           
 

Uses of ElasticSearchException in org.elasticsearch.common.component
 

Methods in org.elasticsearch.common.component that throw ElasticSearchException
 void AbstractLifecycleComponent.close()
           
 void CloseableComponent.close()
           
protected abstract  void AbstractLifecycleComponent.doClose()
           
protected abstract  void AbstractLifecycleComponent.doStart()
           
protected abstract  void AbstractLifecycleComponent.doStop()
           
 T LifecycleComponent.start()
           
 T AbstractLifecycleComponent.start()
           
 T LifecycleComponent.stop()
           
 T AbstractLifecycleComponent.stop()
           
 

Uses of ElasticSearchException in org.elasticsearch.common.lease
 

Methods in org.elasticsearch.common.lease that throw ElasticSearchException
 boolean Releasable.release()
           
 

Uses of ElasticSearchException in org.elasticsearch.common.settings
 

Subclasses of ElasticSearchException in org.elasticsearch.common.settings
 class NoClassSettingsException
          A specific type of SettingsException indicating failure to load a class based on a settings value.
 class SettingsException
          A generic failure to handle settings.
 

Uses of ElasticSearchException in org.elasticsearch.common.util.concurrent
 

Subclasses of ElasticSearchException in org.elasticsearch.common.util.concurrent
 class EsRejectedExecutionException
           
 class UncategorizedExecutionException
           
 

Uses of ElasticSearchException in org.elasticsearch.discovery
 

Subclasses of ElasticSearchException in org.elasticsearch.discovery
 class DiscoveryException
           
 class MasterNotDiscoveredException
           
 

Methods in org.elasticsearch.discovery that throw ElasticSearchException
protected  void DiscoveryService.doClose()
           
protected  void DiscoveryService.doStart()
           
protected  void DiscoveryService.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.discovery.local
 

Methods in org.elasticsearch.discovery.local that throw ElasticSearchException
protected  void LocalDiscovery.doClose()
           
protected  void LocalDiscovery.doStart()
           
protected  void LocalDiscovery.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.discovery.zen
 

Methods in org.elasticsearch.discovery.zen that throw ElasticSearchException
protected  void ZenDiscovery.doClose()
           
protected  void ZenDiscovery.doStart()
           
protected  void ZenDiscovery.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.discovery.zen.membership
 

Methods in org.elasticsearch.discovery.zen.membership that throw ElasticSearchException
 ClusterState MembershipAction.sendJoinRequestBlocking(DiscoveryNode masterNode, DiscoveryNode node, TimeValue timeout)
           
 void MembershipAction.sendLeaveRequestBlocking(DiscoveryNode masterNode, DiscoveryNode node, TimeValue timeout)
           
 void MembershipAction.sendValidateJoinRequestBlocking(DiscoveryNode node, ClusterState clusterState, TimeValue timeout)
          Validates the join request, throwing a failure if it failed.
 

Uses of ElasticSearchException in org.elasticsearch.discovery.zen.ping
 

Subclasses of ElasticSearchException in org.elasticsearch.discovery.zen.ping
 class ZenPingException
           
 

Methods in org.elasticsearch.discovery.zen.ping that throw ElasticSearchException
protected  void ZenPingService.doClose()
           
protected  void ZenPingService.doStart()
           
protected  void ZenPingService.doStop()
           
 void ZenPingService.ping(ZenPing.PingListener listener, TimeValue timeout)
           
 void ZenPing.ping(ZenPing.PingListener listener, TimeValue timeout)
           
 

Uses of ElasticSearchException in org.elasticsearch.discovery.zen.ping.multicast
 

Methods in org.elasticsearch.discovery.zen.ping.multicast that throw ElasticSearchException
protected  void MulticastZenPing.doClose()
           
protected  void MulticastZenPing.doStart()
           
protected  void MulticastZenPing.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.discovery.zen.ping.unicast
 

Methods in org.elasticsearch.discovery.zen.ping.unicast that throw ElasticSearchException
protected  void UnicastZenPing.doClose()
           
protected  void UnicastZenPing.doStart()
           
protected  void UnicastZenPing.doStop()
           
 void UnicastZenPing.ping(ZenPing.PingListener listener, TimeValue timeout)
           
 

Uses of ElasticSearchException in org.elasticsearch.env
 

Subclasses of ElasticSearchException in org.elasticsearch.env
 class FailedToResolveConfigException
           
 

Uses of ElasticSearchException in org.elasticsearch.gateway
 

Subclasses of ElasticSearchException in org.elasticsearch.gateway
 class GatewayException
           
 

Methods in org.elasticsearch.gateway that throw ElasticSearchException
protected  void GatewayService.doClose()
           
protected  void GatewayService.doStart()
           
protected  void GatewayService.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.gateway.blobstore
 

Methods in org.elasticsearch.gateway.blobstore that throw ElasticSearchException
protected  void BlobStoreGateway.delete(IndexMetaData indexMetaData)
           
 

Uses of ElasticSearchException in org.elasticsearch.gateway.fs
 

Methods in org.elasticsearch.gateway.fs that throw ElasticSearchException
protected  void FsGateway.doClose()
           
 

Uses of ElasticSearchException in org.elasticsearch.gateway.local
 

Methods in org.elasticsearch.gateway.local that throw ElasticSearchException
protected  void LocalGateway.doClose()
           
protected  void LocalGateway.doStart()
           
protected  void LocalGateway.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.gateway.local.state.meta
 

Methods in org.elasticsearch.gateway.local.state.meta that throw ElasticSearchException
protected  TransportNodesListGatewayMetaState.NodeLocalGatewayMetaState TransportNodesListGatewayMetaState.nodeOperation(org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState.NodeRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.gateway.local.state.shards
 

Methods in org.elasticsearch.gateway.local.state.shards that throw ElasticSearchException
protected  TransportNodesListGatewayStartedShards.NodeLocalGatewayStartedShards TransportNodesListGatewayStartedShards.nodeOperation(org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards.NodeRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.gateway.none
 

Methods in org.elasticsearch.gateway.none that throw ElasticSearchException
protected  void NoneGateway.doClose()
           
protected  void NoneGateway.doStart()
           
protected  void NoneGateway.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.gateway.shared
 

Methods in org.elasticsearch.gateway.shared that throw ElasticSearchException
protected abstract  void SharedStorageGateway.delete(IndexMetaData indexMetaData)
           
protected  void SharedStorageGateway.doClose()
           
protected  void SharedStorageGateway.doStart()
           
protected  void SharedStorageGateway.doStop()
           
protected abstract  MetaData SharedStorageGateway.read()
           
protected abstract  void SharedStorageGateway.write(MetaData metaData)
           
 

Uses of ElasticSearchException in org.elasticsearch.http
 

Subclasses of ElasticSearchException in org.elasticsearch.http
 class BindHttpException
           
 class HttpException
           
 

Methods in org.elasticsearch.http that throw ElasticSearchException
protected  void HttpServer.doClose()
           
protected  void HttpServer.doStart()
           
protected  void HttpServer.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.http.netty
 

Methods in org.elasticsearch.http.netty that throw ElasticSearchException
protected  void NettyHttpServerTransport.doClose()
           
protected  void NettyHttpServerTransport.doStart()
           
protected  void NettyHttpServerTransport.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.index
 

Subclasses of ElasticSearchException in org.elasticsearch.index
 class AlreadyExpiredException
           
 class IndexException
           
 class IndexShardAlreadyExistsException
           
 class IndexShardMissingException
           
 

Methods in org.elasticsearch.index that throw ElasticSearchException
 void CloseableIndexComponent.close(boolean delete)
          Closes the index component.
 

Uses of ElasticSearchException in org.elasticsearch.index.cache
 

Methods in org.elasticsearch.index.cache that throw ElasticSearchException
 void IndexCache.close()
           
 

Uses of ElasticSearchException in org.elasticsearch.index.cache.bloom.none
 

Methods in org.elasticsearch.index.cache.bloom.none that throw ElasticSearchException
 void NoneBloomCache.close()
           
 

Uses of ElasticSearchException in org.elasticsearch.index.cache.bloom.simple
 

Methods in org.elasticsearch.index.cache.bloom.simple that throw ElasticSearchException
 void SimpleBloomCache.close()
           
 

Uses of ElasticSearchException in org.elasticsearch.index.cache.field.data.none
 

Methods in org.elasticsearch.index.cache.field.data.none that throw ElasticSearchException
 void NoneFieldDataCache.close()
           
 

Uses of ElasticSearchException in org.elasticsearch.index.cache.field.data.resident
 

Methods in org.elasticsearch.index.cache.field.data.resident that throw ElasticSearchException
 void ResidentFieldDataCache.close()
           
 

Uses of ElasticSearchException in org.elasticsearch.index.cache.field.data.support
 

Methods in org.elasticsearch.index.cache.field.data.support that throw ElasticSearchException
 void AbstractConcurrentMapFieldDataCache.close()
           
 

Uses of ElasticSearchException in org.elasticsearch.index.cache.filter.weighted
 

Methods in org.elasticsearch.index.cache.filter.weighted that throw ElasticSearchException
 void WeightedFilterCache.close()
           
 

Uses of ElasticSearchException in org.elasticsearch.index.cache.id.simple
 

Methods in org.elasticsearch.index.cache.id.simple that throw ElasticSearchException
 void SimpleIdCache.close()
           
 

Uses of ElasticSearchException in org.elasticsearch.index.cache.query.parser.none
 

Methods in org.elasticsearch.index.cache.query.parser.none that throw ElasticSearchException
 void NoneQueryParserCache.close()
           
 

Uses of ElasticSearchException in org.elasticsearch.index.cache.query.parser.resident
 

Methods in org.elasticsearch.index.cache.query.parser.resident that throw ElasticSearchException
 void ResidentQueryParserCache.close()
           
 

Uses of ElasticSearchException in org.elasticsearch.index.cache.query.parser.support
 

Methods in org.elasticsearch.index.cache.query.parser.support that throw ElasticSearchException
 void AbstractJvmQueryParserCache.close()
           
 

Uses of ElasticSearchException in org.elasticsearch.index.engine
 

Subclasses of ElasticSearchException in org.elasticsearch.index.engine
 class CloseEngineException
          An exception indicating that an Engine close failed.
 class CreateFailedEngineException
           
 class DeleteByQueryFailedEngineException
           
 class DeleteFailedEngineException
           
 class DocumentAlreadyExistsException
           
 class DocumentMissingException
           
 class DocumentSourceMissingException
           
 class EngineAlreadyStartedException
           
 class EngineClosedException
          An engine is already closed.
 class EngineCreationFailureException
          An exception indicating that an Engine creation failed.
 class EngineException
           
 class FlushFailedEngineException
           
 class FlushNotAllowedEngineException
           
 class IndexFailedEngineException
           
 class OptimizeFailedEngineException
           
 class RecoveryEngineException
           
 class RefreshFailedEngineException
           
 class RollbackFailedEngineException
           
 class RollbackNotAllowedEngineException
           
 class SnapshotFailedEngineException
           
 class VersionConflictEngineException
           
 

Methods in org.elasticsearch.index.engine that throw ElasticSearchException
 void Engine.RecoveryHandler.phase1(SnapshotIndexCommit snapshot)
           
 void Engine.RecoveryHandler.phase2(Translog.Snapshot snapshot)
           
 void Engine.RecoveryHandler.phase3(Translog.Snapshot snapshot)
           
 boolean Engine.SimpleSearcher.release()
           
 

Uses of ElasticSearchException in org.elasticsearch.index.engine.robin
 

Methods in org.elasticsearch.index.engine.robin that throw ElasticSearchException
 void RobinEngine.close()
           
 

Uses of ElasticSearchException in org.elasticsearch.index.gateway
 

Subclasses of ElasticSearchException in org.elasticsearch.index.gateway
 class IgnoreGatewayRecoveryException
          An exception marking that this recovery attempt should be ignored (since probably, we already recovered).
 class IndexShardGatewayException
           
 class IndexShardGatewayRecoveryException
           
 class IndexShardGatewaySnapshotFailedException
           
 class IndexShardGatewaySnapshotNotAllowedException
           
 

Uses of ElasticSearchException in org.elasticsearch.index.gateway.blobstore
 

Methods in org.elasticsearch.index.gateway.blobstore that throw ElasticSearchException
 void BlobStoreIndexShardGateway.close(boolean delete)
           
 void BlobStoreIndexGateway.close(boolean delete)
           
 

Uses of ElasticSearchException in org.elasticsearch.index.get
 

Methods in org.elasticsearch.index.get that throw ElasticSearchException
 GetResult ShardGetService.get(String type, String id, String[] gFields, boolean realtime)
           
 GetResult ShardGetService.innerGet(String type, String id, String[] gFields, boolean realtime)
           
 

Uses of ElasticSearchException in org.elasticsearch.index.mapper
 

Subclasses of ElasticSearchException in org.elasticsearch.index.mapper
 class FailedToGenerateSourceMapperException
           
 class MapperCompressionException
           
 class MapperException
           
 class MapperParsingException
           
 class MergeMappingException
           
 class StrictDynamicMappingException
           
 

Uses of ElasticSearchException in org.elasticsearch.index.merge.policy
 

Methods in org.elasticsearch.index.merge.policy that throw ElasticSearchException
 void TieredMergePolicyProvider.close(boolean delete)
           
 void LogByteSizeMergePolicyProvider.close(boolean delete)
           
 void LogDocMergePolicyProvider.close(boolean delete)
           
 

Uses of ElasticSearchException in org.elasticsearch.index.percolator
 

Subclasses of ElasticSearchException in org.elasticsearch.index.percolator
 class PercolateIndexUnavailable
           
 class PercolatorException
           
 

Methods in org.elasticsearch.index.percolator that throw ElasticSearchException
 void PercolatorExecutor.addQuery(String name, BytesReference source)
           
 void PercolatorExecutor.addQuery(String name, QueryBuilder queryBuilder)
           
 org.apache.lucene.search.Query PercolatorExecutor.parseQuery(String name, BytesReference source)
           
 PercolatorExecutor.Response PercolatorExecutor.percolate(PercolatorExecutor.DocAndSourceQueryRequest request)
           
 PercolatorExecutor.Response PercolatorExecutor.percolate(PercolatorExecutor.SourceRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.index.query
 

Subclasses of ElasticSearchException in org.elasticsearch.index.query
 class QueryBuilderException
           
 class QueryParsingException
           
 

Methods in org.elasticsearch.index.query that throw ElasticSearchException
 ParsedQuery IndexQueryParserService.parse(byte[] source)
           
 ParsedQuery IndexQueryParserService.parse(byte[] source, int offset, int length)
           
 ParsedQuery IndexQueryParserService.parse(BytesReference source)
           
 ParsedQuery IndexQueryParserService.parse(QueryBuilder queryBuilder)
           
 

Uses of ElasticSearchException in org.elasticsearch.index.service
 

Methods in org.elasticsearch.index.service that throw ElasticSearchException
 void IndexService.cleanShard(int shardId, String reason)
          Cleans the shard locally, does not touch the gateway!.
 void InternalIndexService.cleanShard(int shardId, String reason)
           
 IndexShard IndexService.createShard(int sShardId)
           
 IndexShard InternalIndexService.createShard(int sShardId)
           
 void IndexService.removeShard(int shardId, String reason)
          Removes the shard, does not delete local data or the gateway.
 void InternalIndexService.removeShard(int shardId, String reason)
           
 Injector InternalIndexService.shardInjector(int shardId)
           
 

Uses of ElasticSearchException in org.elasticsearch.index.shard
 

Subclasses of ElasticSearchException in org.elasticsearch.index.shard
 class IllegalIndexShardStateException
           
 class IndexShardClosedException
           
 class IndexShardCreationException
           
 class IndexShardException
           
 class IndexShardNotRecoveringException
           
 class IndexShardNotStartedException
           
 class IndexShardRecoveringException
           
 class IndexShardRelocatedException
           
 class IndexShardStartedException
           
 

Uses of ElasticSearchException in org.elasticsearch.index.shard.service
 

Methods in org.elasticsearch.index.shard.service that throw ElasticSearchException
 ParsedDocument IndexShard.create(Engine.Create create)
           
 ParsedDocument InternalIndexShard.create(Engine.Create create)
           
 void IndexShard.delete(Engine.Delete delete)
           
 void InternalIndexShard.delete(Engine.Delete delete)
           
 void IndexShard.deleteByQuery(Engine.DeleteByQuery deleteByQuery)
           
 void InternalIndexShard.deleteByQuery(Engine.DeleteByQuery deleteByQuery)
           
 void IndexShard.flush(Engine.Flush flush)
           
 void InternalIndexShard.flush(Engine.Flush flush)
           
 Engine.GetResult IndexShard.get(Engine.Get get)
           
 Engine.GetResult InternalIndexShard.get(Engine.Get get)
           
 ParsedDocument IndexShard.index(Engine.Index index)
           
 ParsedDocument InternalIndexShard.index(Engine.Index index)
           
 void IndexShard.optimize(Engine.Optimize optimize)
           
 void InternalIndexShard.optimize(Engine.Optimize optimize)
           
 void InternalIndexShard.performRecoveryFinalization(boolean withFlush)
           
 void InternalIndexShard.performRecoveryFinalization(boolean withFlush, RecoveryStatus peerRecoveryStatus)
           
 void InternalIndexShard.performRecoveryOperation(Translog.Operation operation)
           
 void InternalIndexShard.performRecoveryPrepareForTranslog()
          After the store has been recovered, we need to start the engine in order to apply operations
 Engine.Create IndexShard.prepareCreate(SourceToParse source)
           
 Engine.Create InternalIndexShard.prepareCreate(SourceToParse source)
           
 Engine.Delete IndexShard.prepareDelete(String type, String id, long version)
           
 Engine.Delete InternalIndexShard.prepareDelete(String type, String id, long version)
           
 Engine.DeleteByQuery IndexShard.prepareDeleteByQuery(BytesReference querySource, String[] filteringAliases, String... types)
           
 Engine.DeleteByQuery InternalIndexShard.prepareDeleteByQuery(BytesReference querySource, String[] filteringAliases, String... types)
           
 Engine.Index IndexShard.prepareIndex(SourceToParse source)
           
 Engine.Index InternalIndexShard.prepareIndex(SourceToParse source)
           
 void IndexShard.refresh(Engine.Refresh refresh)
           
 void InternalIndexShard.refresh(Engine.Refresh refresh)
           
 

Uses of ElasticSearchException in org.elasticsearch.index.store
 

Subclasses of ElasticSearchException in org.elasticsearch.index.store
 class StoreException
           
 

Uses of ElasticSearchException in org.elasticsearch.index.store.support
 

Methods in org.elasticsearch.index.store.support that throw ElasticSearchException
 void AbstractIndexStore.close(boolean delete)
           
 

Uses of ElasticSearchException in org.elasticsearch.index.translog
 

Subclasses of ElasticSearchException in org.elasticsearch.index.translog
 class TranslogException
           
 

Uses of ElasticSearchException in org.elasticsearch.index.translog.fs
 

Methods in org.elasticsearch.index.translog.fs that throw ElasticSearchException
 boolean FsChannelSnapshot.release()
           
 

Uses of ElasticSearchException in org.elasticsearch.indices
 

Subclasses of ElasticSearchException in org.elasticsearch.indices
 class AliasFilterParsingException
           
 class IndexAlreadyExistsException
           
 class IndexCreationException
           
 class IndexMissingException
           
 class IndexTemplateAlreadyExistsException
           
 class IndexTemplateMissingException
           
 class InvalidAliasNameException
           
 class InvalidIndexNameException
           
 class InvalidIndexTemplateException
           
 class InvalidTypeNameException
           
 class TypeMissingException
           
 

Methods in org.elasticsearch.indices that throw ElasticSearchException
 void InternalIndicesService.cleanIndex(String index, String reason)
           
 void IndicesService.cleanIndex(String index, String reason)
          Cleans the index without actually deleting any content for it.
 IndexService InternalIndicesService.createIndex(String sIndexName, Settings settings, String localNodeId)
           
 IndexService IndicesService.createIndex(String index, Settings settings, String localNodeId)
           
 void InternalIndicesService.deleteIndex(String index, String reason)
           
 void IndicesService.deleteIndex(String index, String reason)
           
protected  void InternalIndicesService.doClose()
           
protected  void InternalIndicesService.doStart()
           
protected  void InternalIndicesService.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.indices.cluster
 

Methods in org.elasticsearch.indices.cluster that throw ElasticSearchException
protected  void IndicesClusterStateService.doClose()
           
protected  void IndicesClusterStateService.doStart()
           
protected  void IndicesClusterStateService.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.indices.memory
 

Methods in org.elasticsearch.indices.memory that throw ElasticSearchException
protected  void IndexingMemoryController.doClose()
           
protected  void IndexingMemoryController.doStart()
           
protected  void IndexingMemoryController.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.indices.recovery
 

Subclasses of ElasticSearchException in org.elasticsearch.indices.recovery
 class IgnoreRecoveryException
          An exception marking that this recovery attempt should be ignored (since probably, we already recovered).
 class RecoverFilesRecoveryException
           
 class RecoveryFailedException
           
 

Uses of ElasticSearchException in org.elasticsearch.indices.store
 

Methods in org.elasticsearch.indices.store that throw ElasticSearchException
protected  TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData TransportNodesListShardStoreMetaData.nodeOperation(org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.indices.ttl
 

Methods in org.elasticsearch.indices.ttl that throw ElasticSearchException
protected  void IndicesTTLService.doClose()
           
protected  void IndicesTTLService.doStart()
           
protected  void IndicesTTLService.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.jmx
 

Subclasses of ElasticSearchException in org.elasticsearch.jmx
 class JmxConnectorCreationException
           
 class JmxException
           
 class JmxRegistrationException
           
 

Uses of ElasticSearchException in org.elasticsearch.jmx.action
 

Methods in org.elasticsearch.jmx.action that throw ElasticSearchException
 String GetJmxServiceUrlAction.obtainPublishUrl(DiscoveryNode node)
           
 

Uses of ElasticSearchException in org.elasticsearch.monitor
 

Methods in org.elasticsearch.monitor that throw ElasticSearchException
protected  void MonitorService.doClose()
           
protected  void MonitorService.doStart()
           
protected  void MonitorService.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.monitor.dump
 

Subclasses of ElasticSearchException in org.elasticsearch.monitor.dump
 class DumpContributionFailedException
           
 class DumpException
           
 class DumpGenerationFailedException
           
 

Uses of ElasticSearchException in org.elasticsearch.monitor.jvm
 

Methods in org.elasticsearch.monitor.jvm that throw ElasticSearchException
protected  void JvmMonitorService.doClose()
           
protected  void JvmMonitorService.doStart()
           
protected  void JvmMonitorService.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.node
 

Subclasses of ElasticSearchException in org.elasticsearch.node
 class NodeClosedException
          An exception indicating that node is closed.
 

Uses of ElasticSearchException in org.elasticsearch.node.internal
 

Constructors in org.elasticsearch.node.internal that throw ElasticSearchException
InternalNode()
           
InternalNode(Settings pSettings, boolean loadConfigSettings)
           
 

Uses of ElasticSearchException in org.elasticsearch.rest
 

Methods in org.elasticsearch.rest that throw ElasticSearchException
 void RestFilter.close()
           
protected  void RestController.doClose()
           
protected  void RestController.doStart()
           
protected  void RestController.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.river
 

Subclasses of ElasticSearchException in org.elasticsearch.river
 class RiverException
           
 

Methods in org.elasticsearch.river that throw ElasticSearchException
 void RiversService.closeRiver(RiverName riverName)
           
 void RiversService.createRiver(RiverName riverName, Map<String,Object> settings)
           
protected  void RiversService.doClose()
           
protected  void RiversManager.doClose()
           
protected  void RiversService.doStart()
           
protected  void RiversManager.doStart()
           
protected  void RiversService.doStop()
           
protected  void RiversManager.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.river.cluster
 

Methods in org.elasticsearch.river.cluster that throw ElasticSearchException
protected  void RiverClusterService.doClose()
           
protected  void RiverClusterService.doStart()
           
protected  void RiverClusterService.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.river.routing
 

Methods in org.elasticsearch.river.routing that throw ElasticSearchException
protected  void RiversRouter.doClose()
           
protected  void RiversRouter.doStart()
           
protected  void RiversRouter.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.script
 

Subclasses of ElasticSearchException in org.elasticsearch.script
 class ScriptException
           
 

Uses of ElasticSearchException in org.elasticsearch.search
 

Subclasses of ElasticSearchException in org.elasticsearch.search
 class SearchContextException
           
 class SearchContextMissingException
           
 class SearchException
           
 class SearchParseException
           
 

Methods in org.elasticsearch.search that throw ElasticSearchException
protected  void SearchService.doClose()
           
protected  void SearchService.doStart()
           
protected  void SearchService.doStop()
           
 void SearchPhase.execute(SearchContext context)
           
 DfsSearchResult SearchService.executeDfsPhase(InternalSearchRequest request)
           
 FetchSearchResult SearchService.executeFetchPhase(FetchSearchRequest request)
           
 ScrollQueryFetchSearchResult SearchService.executeFetchPhase(InternalScrollSearchRequest request)
           
 QueryFetchSearchResult SearchService.executeFetchPhase(InternalSearchRequest request)
           
 QueryFetchSearchResult SearchService.executeFetchPhase(QuerySearchRequest request)
           
 ScrollQuerySearchResult SearchService.executeQueryPhase(InternalScrollSearchRequest request)
           
 QuerySearchResult SearchService.executeQueryPhase(InternalSearchRequest request)
           
 QuerySearchResult SearchService.executeQueryPhase(QuerySearchRequest request)
           
 ScrollQueryFetchSearchResult SearchService.executeScan(InternalScrollSearchRequest request)
           
 QuerySearchResult SearchService.executeScan(InternalSearchRequest request)
           
 

Uses of ElasticSearchException in org.elasticsearch.search.builder
 

Subclasses of ElasticSearchException in org.elasticsearch.search.builder
 class SearchSourceBuilderException
           
 

Uses of ElasticSearchException in org.elasticsearch.search.dfs
 

Subclasses of ElasticSearchException in org.elasticsearch.search.dfs
 class DfsPhaseExecutionException
           
 

Uses of ElasticSearchException in org.elasticsearch.search.facet
 

Subclasses of ElasticSearchException in org.elasticsearch.search.facet
 class FacetPhaseExecutionException
           
 

Methods in org.elasticsearch.search.facet that throw ElasticSearchException
 void FacetPhase.execute(SearchContext context)
           
 

Uses of ElasticSearchException in org.elasticsearch.search.fetch
 

Subclasses of ElasticSearchException in org.elasticsearch.search.fetch
 class FetchPhaseExecutionException
           
 

Methods in org.elasticsearch.search.fetch that throw ElasticSearchException
 void FetchSubPhase.hitExecute(SearchContext context, FetchSubPhase.HitContext hitContext)
          Executes the hit level phase, with a reader and doc id (note, its a low level reader, and the matching doc).
 void FetchSubPhase.hitsExecute(SearchContext context, InternalSearchHit[] hits)
           
 

Uses of ElasticSearchException in org.elasticsearch.search.fetch.explain
 

Methods in org.elasticsearch.search.fetch.explain that throw ElasticSearchException
 void ExplainFetchSubPhase.hitExecute(SearchContext context, FetchSubPhase.HitContext hitContext)
           
 void ExplainFetchSubPhase.hitsExecute(SearchContext context, InternalSearchHit[] hits)
           
 

Uses of ElasticSearchException in org.elasticsearch.search.fetch.matchedfilters
 

Methods in org.elasticsearch.search.fetch.matchedfilters that throw ElasticSearchException
 void MatchedFiltersFetchSubPhase.hitExecute(SearchContext context, FetchSubPhase.HitContext hitContext)
           
 void MatchedFiltersFetchSubPhase.hitsExecute(SearchContext context, InternalSearchHit[] hits)
           
 

Uses of ElasticSearchException in org.elasticsearch.search.fetch.partial
 

Methods in org.elasticsearch.search.fetch.partial that throw ElasticSearchException
 void PartialFieldsFetchSubPhase.hitExecute(SearchContext context, FetchSubPhase.HitContext hitContext)
           
 void PartialFieldsFetchSubPhase.hitsExecute(SearchContext context, InternalSearchHit[] hits)
           
 

Uses of ElasticSearchException in org.elasticsearch.search.fetch.script
 

Methods in org.elasticsearch.search.fetch.script that throw ElasticSearchException
 void ScriptFieldsFetchSubPhase.hitExecute(SearchContext context, FetchSubPhase.HitContext hitContext)
           
 void ScriptFieldsFetchSubPhase.hitsExecute(SearchContext context, InternalSearchHit[] hits)
           
 

Uses of ElasticSearchException in org.elasticsearch.search.fetch.version
 

Methods in org.elasticsearch.search.fetch.version that throw ElasticSearchException
 void VersionFetchSubPhase.hitExecute(SearchContext context, FetchSubPhase.HitContext hitContext)
           
 void VersionFetchSubPhase.hitsExecute(SearchContext context, InternalSearchHit[] hits)
           
 

Uses of ElasticSearchException in org.elasticsearch.search.highlight
 

Methods in org.elasticsearch.search.highlight that throw ElasticSearchException
 void HighlightPhase.hitExecute(SearchContext context, FetchSubPhase.HitContext hitContext)
           
 void HighlightPhase.hitsExecute(SearchContext context, InternalSearchHit[] hits)
           
 

Uses of ElasticSearchException in org.elasticsearch.search.internal
 

Methods in org.elasticsearch.search.internal that throw ElasticSearchException
 boolean SearchContext.release()
           
 

Uses of ElasticSearchException in org.elasticsearch.search.query
 

Subclasses of ElasticSearchException in org.elasticsearch.search.query
 class QueryPhaseExecutionException
           
 

Uses of ElasticSearchException in org.elasticsearch.search.warmer
 

Subclasses of ElasticSearchException in org.elasticsearch.search.warmer
 class IndexWarmerMissingException
           
 

Uses of ElasticSearchException in org.elasticsearch.transport
 

Subclasses of ElasticSearchException in org.elasticsearch.transport
 class ActionNotFoundTransportException
          An exception indicating that a transport action was not found.
 class ActionTransportException
          An action invocation failure.
 class BindTransportException
           
 class ConnectTransportException
           
 class FailedCommunicationException
           
 class NodeDisconnectedException
           
 class NodeNotConnectedException
          An exception indicating that a message is sent to a node that is not connected.
 class NotSerializableTransportException
           
 class ReceiveTimeoutTransportException
           
 class RemoteTransportException
          A remote exception for an action.
 class ResponseHandlerFailureTransportException
          A failure to handle the response of a transaction action.
 class ResponseHandlerNotFoundTransportException
           
 class SendRequestTransportException
           
 class TransportException
           
 class TransportSerializationException
           
 

Methods in org.elasticsearch.transport that throw ElasticSearchException
protected  void TransportService.doClose()
           
protected  void TransportService.doStart()
           
protected  void TransportService.doStop()
           
 V TransportFuture.txGet()
          Waits if necessary for the computation to complete, and then retrieves its result.
 V PlainTransportFuture.txGet()
           
 V TransportFuture.txGet(long timeout, TimeUnit unit)
          Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.
 V PlainTransportFuture.txGet(long timeout, TimeUnit unit)
           
 

Uses of ElasticSearchException in org.elasticsearch.transport.local
 

Methods in org.elasticsearch.transport.local that throw ElasticSearchException
protected  void LocalTransport.doClose()
           
protected  void LocalTransport.doStart()
           
protected  void LocalTransport.doStop()
           
 

Uses of ElasticSearchException in org.elasticsearch.transport.netty
 

Methods in org.elasticsearch.transport.netty that throw ElasticSearchException
protected  void NettyTransport.doClose()
           
protected  void NettyTransport.doStart()
           
protected  void NettyTransport.doStop()
           
 



Copyright © 2009-2012. All Rights Reserved.