Modifier and Type | Class and Description |
---|---|
static class |
ElasticsearchException.WithRestHeaders
A base class for exceptions that should carry rest headers
|
class |
ElasticsearchGenerationException
A generic exception indicating failure to generate.
|
class |
ElasticsearchIllegalArgumentException |
class |
ElasticsearchIllegalStateException |
class |
ElasticsearchNullPointerException |
class |
ElasticsearchParseException |
class |
ElasticsearchTimeoutException
The same as
TimeoutException simply a runtime one. |
Modifier and Type | Method and Description |
---|---|
static ElasticsearchException |
ExceptionsHelper.convertToElastic(Throwable t) |
Modifier and Type | Class and Description |
---|---|
class |
ActionRequestValidationException |
class |
FailedNodeException |
class |
NoShardAvailableActionException |
class |
NoSuchNodeException |
class |
PrimaryMissingActionException |
class |
RoutingMissingException |
class |
TimestampParsingException |
class |
UnavailableShardsException |
class |
WriteFailureException |
Modifier and Type | Method and Description |
---|---|
T |
ActionFuture.actionGet()
Similar to
Future.get() , just catching the InterruptedException and throwing
an ElasticsearchIllegalStateException instead. |
T |
ActionFuture.actionGet(long timeoutMillis)
Similar to
Future.get(long, java.util.concurrent.TimeUnit) , just catching the InterruptedException and throwing
an ElasticsearchIllegalStateException instead. |
T |
ActionFuture.actionGet(long timeout,
TimeUnit unit)
Similar to
Future.get(long, java.util.concurrent.TimeUnit) , just catching the InterruptedException and throwing
an ElasticsearchIllegalStateException instead. |
T |
ActionFuture.actionGet(String timeout)
Similar to
Future.get(long, java.util.concurrent.TimeUnit) , just catching the InterruptedException and throwing
an ElasticsearchIllegalStateException instead. |
T |
ActionFuture.actionGet(TimeValue timeout)
Similar to
Future.get(long, java.util.concurrent.TimeUnit) , just catching the InterruptedException and throwing
an ElasticsearchIllegalStateException instead. |
Response |
ActionRequestBuilder.get()
Short version of execute().actionGet().
|
Response |
ActionRequestBuilder.get(String timeout)
Short version of execute().actionGet().
|
Response |
ActionRequestBuilder.get(TimeValue timeout)
Short version of execute().actionGet().
|
Modifier and Type | Method and Description |
---|---|
protected void |
TransportClusterHealthAction.masterOperation(ClusterHealthRequest request,
ClusterState unusedState,
ActionListener<ClusterHealthResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected NodeHotThreads |
TransportNodesHotThreadsAction.nodeOperation(org.elasticsearch.action.admin.cluster.node.hotthreads.TransportNodesHotThreadsAction.NodeRequest request) |
Modifier and Type | Method and Description |
---|---|
protected NodeInfo |
TransportNodesInfoAction.nodeOperation(org.elasticsearch.action.admin.cluster.node.info.TransportNodesInfoAction.NodeInfoRequest nodeRequest) |
Modifier and Type | Method and Description |
---|---|
protected NodesRestartResponse.NodeRestartResponse |
TransportNodesRestartAction.nodeOperation(TransportNodesRestartAction.NodeRestartRequest request) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportNodesShutdownAction.masterOperation(NodesShutdownRequest request,
ClusterState state,
ActionListener<NodesShutdownResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected NodeStats |
TransportNodesStatsAction.nodeOperation(org.elasticsearch.action.admin.cluster.node.stats.TransportNodesStatsAction.NodeStatsRequest nodeStatsRequest) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportDeleteRepositoryAction.masterOperation(DeleteRepositoryRequest request,
ClusterState state,
ActionListener<DeleteRepositoryResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportGetRepositoriesAction.masterOperation(GetRepositoriesRequest request,
ClusterState state,
ActionListener<GetRepositoriesResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportPutRepositoryAction.masterOperation(PutRepositoryRequest request,
ClusterState state,
ActionListener<PutRepositoryResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportVerifyRepositoryAction.masterOperation(VerifyRepositoryRequest request,
ClusterState state,
ActionListener<VerifyRepositoryResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportClusterRerouteAction.masterOperation(ClusterRerouteRequest request,
ClusterState state,
ActionListener<ClusterRerouteResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportClusterUpdateSettingsAction.masterOperation(ClusterUpdateSettingsRequest request,
ClusterState state,
ActionListener<ClusterUpdateSettingsResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportClusterSearchShardsAction.masterOperation(ClusterSearchShardsRequest request,
ClusterState state,
ActionListener<ClusterSearchShardsResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportCreateSnapshotAction.masterOperation(CreateSnapshotRequest request,
ClusterState state,
ActionListener<CreateSnapshotResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportDeleteSnapshotAction.masterOperation(DeleteSnapshotRequest request,
ClusterState state,
ActionListener<DeleteSnapshotResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportGetSnapshotsAction.masterOperation(GetSnapshotsRequest request,
ClusterState state,
ActionListener<GetSnapshotsResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportRestoreSnapshotAction.masterOperation(RestoreSnapshotRequest request,
ClusterState state,
ActionListener<RestoreSnapshotResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportSnapshotsStatusAction.masterOperation(SnapshotsStatusRequest request,
ClusterState state,
ActionListener<SnapshotsStatusResponse> listener) |
protected TransportNodesSnapshotsStatus.NodeSnapshotStatus |
TransportNodesSnapshotsStatus.nodeOperation(org.elasticsearch.action.admin.cluster.snapshots.status.TransportNodesSnapshotsStatus.NodeRequest request) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportClusterStateAction.masterOperation(ClusterStateRequest request,
ClusterState state,
ActionListener<ClusterStateResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected ClusterStatsNodeResponse |
TransportClusterStatsAction.nodeOperation(org.elasticsearch.action.admin.cluster.stats.TransportClusterStatsAction.ClusterStatsNodeRequest nodeRequest) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportPendingClusterTasksAction.masterOperation(PendingClusterTasksRequest request,
ClusterState state,
ActionListener<PendingClusterTasksResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportIndicesAliasesAction.masterOperation(IndicesAliasesRequest request,
ClusterState state,
ActionListener<IndicesAliasesResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportAliasesExistAction.masterOperation(GetAliasesRequest request,
ClusterState state,
ActionListener<AliasesExistResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportGetAliasesAction.masterOperation(GetAliasesRequest request,
ClusterState state,
ActionListener<GetAliasesResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected AnalyzeResponse |
TransportAnalyzeAction.shardOperation(AnalyzeRequest request,
ShardId shardId) |
Modifier and Type | Method and Description |
---|---|
protected org.elasticsearch.action.admin.indices.cache.clear.ShardClearIndicesCacheResponse |
TransportClearIndicesCacheAction.shardOperation(org.elasticsearch.action.admin.indices.cache.clear.ShardClearIndicesCacheRequest request) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportCloseIndexAction.masterOperation(CloseIndexRequest request,
ClusterState state,
ActionListener<CloseIndexResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportCreateIndexAction.masterOperation(CreateIndexRequest request,
ClusterState state,
ActionListener<CreateIndexResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportDeleteIndexAction.masterOperation(DeleteIndexRequest request,
ClusterState state,
ActionListener<DeleteIndexResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportIndicesExistsAction.masterOperation(IndicesExistsRequest request,
ClusterState state,
ActionListener<IndicesExistsResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportTypesExistsAction.masterOperation(TypesExistsRequest request,
ClusterState state,
ActionListener<TypesExistsResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected org.elasticsearch.action.admin.indices.flush.ShardFlushResponse |
TransportFlushAction.shardOperation(org.elasticsearch.action.admin.indices.flush.ShardFlushRequest request) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportGetIndexAction.doMasterOperation(GetIndexRequest request,
String[] concreteIndices,
ClusterState state,
ActionListener<GetIndexResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportDeleteMappingAction.masterOperation(DeleteMappingRequest request,
ClusterState state,
ActionListener<DeleteMappingResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportGetMappingsAction.doMasterOperation(GetMappingsRequest request,
String[] concreteIndices,
ClusterState state,
ActionListener<GetMappingsResponse> listener) |
protected GetFieldMappingsResponse |
TransportGetFieldMappingsIndexAction.shardOperation(org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest request,
ShardId shardId) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportPutMappingAction.masterOperation(PutMappingRequest request,
ClusterState state,
ActionListener<PutMappingResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportOpenIndexAction.masterOperation(OpenIndexRequest request,
ClusterState state,
ActionListener<OpenIndexResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected org.elasticsearch.action.admin.indices.optimize.ShardOptimizeResponse |
TransportOptimizeAction.shardOperation(org.elasticsearch.action.admin.indices.optimize.ShardOptimizeRequest request) |
Modifier and Type | Method and Description |
---|---|
protected ShardRecoveryResponse |
TransportRecoveryAction.shardOperation(org.elasticsearch.action.admin.indices.recovery.TransportRecoveryAction.ShardRecoveryRequest request) |
Modifier and Type | Method and Description |
---|---|
protected org.elasticsearch.action.admin.indices.refresh.ShardRefreshResponse |
TransportRefreshAction.shardOperation(org.elasticsearch.action.admin.indices.refresh.ShardRefreshRequest request) |
Modifier and Type | Method and Description |
---|---|
protected ShardSegments |
TransportIndicesSegmentsAction.shardOperation(org.elasticsearch.action.admin.indices.segments.TransportIndicesSegmentsAction.IndexShardSegmentRequest request) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportGetSettingsAction.masterOperation(GetSettingsRequest request,
ClusterState state,
ActionListener<GetSettingsResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportUpdateSettingsAction.masterOperation(UpdateSettingsRequest request,
ClusterState state,
ActionListener<UpdateSettingsResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected ShardStats |
TransportIndicesStatsAction.shardOperation(org.elasticsearch.action.admin.indices.stats.TransportIndicesStatsAction.IndexShardStatsRequest request) |
Modifier and Type | Method and Description |
---|---|
protected ShardStatus |
TransportIndicesStatusAction.shardOperation(org.elasticsearch.action.admin.indices.status.TransportIndicesStatusAction.IndexShardStatusRequest request)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
protected void |
TransportDeleteIndexTemplateAction.masterOperation(DeleteIndexTemplateRequest request,
ClusterState state,
ActionListener<DeleteIndexTemplateResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportGetIndexTemplatesAction.masterOperation(GetIndexTemplatesRequest request,
ClusterState state,
ActionListener<GetIndexTemplatesResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportPutIndexTemplateAction.masterOperation(PutIndexTemplateRequest request,
ClusterState state,
ActionListener<PutIndexTemplateResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryResponse |
TransportValidateQueryAction.shardOperation(org.elasticsearch.action.admin.indices.validate.query.ShardValidateQueryRequest request) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportDeleteWarmerAction.masterOperation(DeleteWarmerRequest request,
ClusterState state,
ActionListener<DeleteWarmerResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportGetWarmersAction.doMasterOperation(GetWarmersRequest request,
String[] concreteIndices,
ClusterState state,
ActionListener<GetWarmersResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportPutWarmerAction.masterOperation(PutWarmerRequest request,
ClusterState state,
ActionListener<PutWarmerResponse> listener) |
Modifier and Type | Method and Description |
---|---|
protected org.elasticsearch.action.count.ShardCountResponse |
TransportCountAction.shardOperation(org.elasticsearch.action.count.ShardCountRequest request) |
Modifier and Type | Method and Description |
---|---|
protected Map<String,Set<String>> |
TransportDeleteByQueryAction.resolveRouting(ClusterState clusterState,
DeleteByQueryRequest request) |
Modifier and Type | Method and Description |
---|---|
protected org.elasticsearch.action.exists.ShardExistsResponse |
TransportExistsAction.shardOperation(org.elasticsearch.action.exists.ShardExistsRequest request) |
Modifier and Type | Method and Description |
---|---|
protected ExplainResponse |
TransportExplainAction.shardOperation(ExplainRequest request,
ShardId shardId) |
protected ShardIterator |
TransportExplainAction.shards(ClusterState state,
TransportShardSingleOperationAction.InternalRequest request) |
Modifier and Type | Method and Description |
---|---|
protected GetResponse |
TransportGetAction.shardOperation(GetRequest request,
ShardId shardId) |
protected MultiGetShardResponse |
TransportShardMultiGetAction.shardOperation(MultiGetShardRequest request,
ShardId shardId) |
Modifier and Type | Method and Description |
---|---|
void |
IndexRequest.process(MetaData metaData,
MappingMetaData mappingMd,
boolean allowIdGeneration,
String concreteIndex) |
Modifier and Type | Method and Description |
---|---|
protected PercolateShardResponse |
TransportPercolateAction.shardOperation(PercolateShardRequest request) |
protected TransportShardMultiPercolateAction.Response |
TransportShardMultiPercolateAction.shardOperation(TransportShardMultiPercolateAction.Request request,
ShardId shardId) |
protected ShardIterator |
TransportShardMultiPercolateAction.shards(ClusterState state,
TransportShardSingleOperationAction.InternalRequest request) |
Modifier and Type | Class and Description |
---|---|
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 |
Modifier and Type | Method and Description |
---|---|
protected org.elasticsearch.action.suggest.ShardSuggestResponse |
TransportSuggestAction.shardOperation(org.elasticsearch.action.suggest.ShardSuggestRequest request) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Class and Description |
---|---|
class |
BroadcastShardOperationFailedException
An exception indicating that a failure occurred performing an operation on the shard.
|
Modifier and Type | Method and Description |
---|---|
protected abstract ShardResponse |
TransportBroadcastOperationAction.shardOperation(ShardRequest request) |
Modifier and Type | Method and Description |
---|---|
protected abstract void |
TransportMasterNodeOperationAction.masterOperation(Request request,
ClusterState state,
ActionListener<Response> listener) |
Modifier and Type | Method and Description |
---|---|
protected abstract void |
TransportClusterInfoAction.doMasterOperation(Request request,
String[] concreteIndices,
ClusterState state,
ActionListener<Response> listener) |
protected void |
TransportClusterInfoAction.masterOperation(Request request,
ClusterState state,
ActionListener<Response> listener) |
Modifier and Type | Method and Description |
---|---|
protected abstract NodeResponse |
TransportNodesOperationAction.nodeOperation(NodeRequest request) |
Modifier and Type | Class and Description |
---|---|
class |
ReplicationShardOperationFailedException
An exception indicating that a failure occurred performing an operation on the shard.
|
Modifier and Type | Method and Description |
---|---|
protected void |
TransportShardReplicationOperationAction.AsyncShardOperationAction.doStart()
Returns true if the action starting to be performed on the primary (or is done).
|
protected abstract Map<String,Set<String>> |
TransportIndicesReplicationOperationAction.resolveRouting(ClusterState clusterState,
Request request) |
protected abstract ShardIterator |
TransportShardReplicationOperationAction.shards(ClusterState clusterState,
TransportShardReplicationOperationAction.InternalRequest request) |
protected abstract GroupShardsIterator |
TransportIndexReplicationOperationAction.shards(Request request) |
Modifier and Type | Method and Description |
---|---|
protected abstract Response |
TransportSingleCustomOperationAction.shardOperation(Request request,
ShardId shardId)
Operation to be executed at the shard level.
|
Modifier and Type | Method and Description |
---|---|
protected abstract void |
TransportInstanceSingleOperationAction.shardOperation(TransportInstanceSingleOperationAction.InternalRequest request,
ActionListener<Response> listener) |
protected abstract ShardIterator |
TransportInstanceSingleOperationAction.shards(ClusterState clusterState,
TransportInstanceSingleOperationAction.InternalRequest request)
Should return an iterator with a single shard!
|
Modifier and Type | Method and Description |
---|---|
protected abstract Response |
TransportShardSingleOperationAction.shardOperation(Request request,
ShardId shardId) |
protected abstract ShardIterator |
TransportShardSingleOperationAction.shards(ClusterState state,
TransportShardSingleOperationAction.InternalRequest request) |
Modifier and Type | Method and Description |
---|---|
protected MultiTermVectorsShardResponse |
TransportSingleShardMultiTermsVectorAction.shardOperation(MultiTermVectorsShardRequest request,
ShardId shardId) |
protected TermVectorResponse |
TransportSingleShardTermVectorAction.shardOperation(TermVectorRequest request,
ShardId shardId) |
Modifier and Type | Method and Description |
---|---|
protected void |
TransportUpdateAction.shardOperation(TransportInstanceSingleOperationAction.InternalRequest request,
ActionListener<UpdateResponse> listener) |
protected void |
TransportUpdateAction.shardOperation(TransportInstanceSingleOperationAction.InternalRequest request,
ActionListener<UpdateResponse> listener,
int retryCount) |
protected ShardIterator |
TransportUpdateAction.shards(ClusterState clusterState,
TransportInstanceSingleOperationAction.InternalRequest request) |
Modifier and Type | Method and Description |
---|---|
protected void |
BulkUdpService.doClose() |
protected void |
BulkUdpService.doStart() |
protected void |
BulkUdpService.doStop() |
Modifier and Type | Class and Description |
---|---|
class |
NoNodeAvailableException
An exception indicating no node is available to perform the operation.
|
Modifier and Type | Method and Description |
---|---|
<Response> void |
TransportClientNodesService.execute(TransportClientNodesService.NodeListenerCallback<Response> callback,
ActionListener<Response> listener) |
Constructor and Description |
---|
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/).
|
Modifier and Type | Method and Description |
---|---|
protected void |
MappingUpdatedAction.masterOperation(MappingUpdatedAction.MappingUpdatedRequest request,
ClusterState state,
ActionListener<MappingUpdatedAction.MappingUpdatedResponse> listener) |
void |
NodeIndexDeletedAction.nodeIndexDeleted(ClusterState clusterState,
String index,
Settings indexSettings,
String nodeId) |
void |
NodeMappingRefreshAction.nodeMappingRefresh(ClusterState state,
NodeMappingRefreshAction.NodeMappingRefreshRequest request) |
Modifier and Type | Method and Description |
---|---|
void |
ShardStateAction.resendShardFailed(ShardRouting shardRouting,
String indexUUID,
String reason,
DiscoveryNode masterNode) |
void |
ShardStateAction.shardFailed(ShardRouting shardRouting,
String indexUUID,
String reason) |
void |
ShardStateAction.shardStarted(ShardRouting shardRouting,
String indexUUID,
String reason) |
void |
ShardStateAction.shardStarted(ShardRouting shardRouting,
String indexUUID,
String reason,
DiscoveryNode masterNode) |
Modifier and Type | Class and Description |
---|---|
class |
ClusterBlockException |
Modifier and Type | Class and Description |
---|---|
class |
ProcessClusterEventTimeoutException |
Modifier and Type | Method and Description |
---|---|
void |
MetaDataCreateIndexService.validateIndexName(String index,
ClusterState state) |
Modifier and Type | Class and Description |
---|---|
class |
IllegalShardRoutingStateException
This exception defines illegal states of shard routing
|
class |
RoutingException
A base
Exception s for all exceptions thrown by routing related operations. |
class |
RoutingValidationException
This class defines
RoutingException s related to
the validation of routing |
Modifier and Type | Method and Description |
---|---|
protected void |
RoutingService.doClose() |
protected void |
RoutingService.doStart() |
protected void |
RoutingService.doStop() |
Modifier and Type | Method and Description |
---|---|
RoutingAllocation.Result |
AllocationService.reroute(ClusterState clusterState,
AllocationCommands commands,
boolean explain) |
Modifier and Type | Method and Description |
---|---|
RerouteExplanation |
AllocateAllocationCommand.execute(RoutingAllocation allocation,
boolean explain) |
RerouteExplanation |
CancelAllocationCommand.execute(RoutingAllocation allocation,
boolean explain) |
RoutingExplanations |
AllocationCommands.execute(RoutingAllocation allocation,
boolean explain)
Executes all wrapped commands on a given
RoutingAllocation |
RerouteExplanation |
MoveAllocationCommand.execute(RoutingAllocation allocation,
boolean explain) |
RerouteExplanation |
AllocationCommand.execute(RoutingAllocation allocation,
boolean explain)
Executes the command on a
RoutingAllocation setup |
Modifier and Type | Method and Description |
---|---|
protected void |
InternalClusterService.doClose() |
protected void |
InternalClusterService.doStart() |
protected void |
InternalClusterService.doStop() |
Modifier and Type | Class and Description |
---|---|
class |
BlobStoreException |
Modifier and Type | Class and Description |
---|---|
class |
CircuitBreakingException
Exception thrown when the circuit breaker trips
|
Modifier and Type | Method and Description |
---|---|
void |
ReleasablePagedBytesReference.close() |
Modifier and Type | Method and Description |
---|---|
void |
AbstractLifecycleComponent.close() |
protected abstract void |
AbstractLifecycleComponent.doClose() |
protected abstract void |
AbstractLifecycleComponent.doStart() |
protected abstract void |
AbstractLifecycleComponent.doStop() |
T |
AbstractLifecycleComponent.start() |
T |
LifecycleComponent.start() |
T |
AbstractLifecycleComponent.stop() |
T |
LifecycleComponent.stop() |
Modifier and Type | Method and Description |
---|---|
void |
Releasable.close() |
Modifier and Type | Class and Description |
---|---|
static class |
Lucene.EarlyTerminationException
This exception is thrown when
Lucene.EarlyTerminatingCollector
reaches early termination |
Modifier and Type | Method and Description |
---|---|
void |
FreqTermsEnum.close() |
Modifier and Type | Class and Description |
---|---|
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.
|
Modifier and Type | Class and Description |
---|---|
class |
CancellableThreads.ExecutionCancelledException |
Modifier and Type | Method and Description |
---|---|
void |
LongObjectPagedHashMap.close() |
Modifier and Type | Class and Description |
---|---|
class |
EsRejectedExecutionException |
class |
UncategorizedExecutionException |
Modifier and Type | Class and Description |
---|---|
class |
DiscoveryException |
class |
MasterNotDiscoveredException |
Modifier and Type | Method and Description |
---|---|
protected void |
DiscoveryService.doClose() |
protected void |
DiscoveryService.doStart() |
protected void |
DiscoveryService.doStop() |
Modifier and Type | Method and Description |
---|---|
protected void |
LocalDiscovery.doClose() |
protected void |
LocalDiscovery.doStart() |
protected void |
LocalDiscovery.doStop() |
Modifier and Type | Method and Description |
---|---|
protected void |
ZenDiscovery.doClose() |
protected void |
ZenDiscovery.doStart() |
protected void |
ZenDiscovery.doStop() |
Modifier and Type | Method and Description |
---|---|
void |
MembershipAction.sendJoinRequestBlocking(DiscoveryNode masterNode,
DiscoveryNode node,
TimeValue timeout) |
void |
MembershipAction.sendLeaveRequestBlocking(DiscoveryNode masterNode,
DiscoveryNode node,
TimeValue timeout) |
void |
MembershipAction.sendValidateJoinRequestBlocking(DiscoveryNode node,
TimeValue timeout)
Validates the join request, throwing a failure if it failed.
|
Modifier and Type | Class and Description |
---|---|
class |
ZenPingException |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
protected void |
MulticastZenPing.doClose() |
protected void |
MulticastZenPing.doStart() |
protected void |
MulticastZenPing.doStop() |
Modifier and Type | Method and Description |
---|---|
protected void |
UnicastZenPing.doClose() |
protected void |
UnicastZenPing.doStart() |
protected void |
UnicastZenPing.doStop() |
void |
UnicastZenPing.ping(ZenPing.PingListener listener,
TimeValue timeout) |
Modifier and Type | Class and Description |
---|---|
class |
FailedToResolveConfigException |
Modifier and Type | Class and Description |
---|---|
class |
GatewayException |
Modifier and Type | Method and Description |
---|---|
protected void |
GatewayService.doClose() |
protected void |
GatewayService.doStart() |
protected void |
GatewayService.doStop() |
Modifier and Type | Method and Description |
---|---|
protected void |
LocalGateway.doClose() |
protected void |
LocalGateway.doStart() |
protected void |
LocalGateway.doStop() |
Modifier and Type | Method and Description |
---|---|
protected TransportNodesListGatewayMetaState.NodeLocalGatewayMetaState |
TransportNodesListGatewayMetaState.nodeOperation(org.elasticsearch.gateway.local.state.meta.TransportNodesListGatewayMetaState.NodeRequest request) |
Modifier and Type | Method and Description |
---|---|
protected TransportNodesListGatewayStartedShards.NodeLocalGatewayStartedShards |
TransportNodesListGatewayStartedShards.nodeOperation(org.elasticsearch.gateway.local.state.shards.TransportNodesListGatewayStartedShards.NodeRequest request) |
Modifier and Type | Method and Description |
---|---|
protected void |
NoneGateway.doClose() |
protected void |
NoneGateway.doStart() |
protected void |
NoneGateway.doStop() |
Modifier and Type | Class and Description |
---|---|
class |
BindHttpException |
class |
HttpException |
Modifier and Type | Method and Description |
---|---|
protected void |
HttpServer.doClose() |
protected void |
HttpServer.doStart() |
protected void |
HttpServer.doStop() |
Modifier and Type | Method and Description |
---|---|
protected void |
NettyHttpServerTransport.doClose() |
protected void |
NettyHttpServerTransport.doStart() |
protected void |
NettyHttpServerTransport.doStop() |
Modifier and Type | Class and Description |
---|---|
class |
AlreadyExpiredException |
class |
IndexException |
class |
IndexShardAlreadyExistsException |
class |
IndexShardMissingException |
Modifier and Type | Method and Description |
---|---|
void |
CloseableIndexComponent.close()
Closes the index component.
|
IndexShard |
IndexService.createShard(int sShardId,
boolean primary) |
void |
IndexService.removeShard(int shardId,
String reason) |
Modifier and Type | Method and Description |
---|---|
void |
WeightedFilterCache.close() |
Modifier and Type | Method and Description |
---|---|
void |
FixedBitSetFilterCache.close() |
Modifier and Type | Method and Description |
---|---|
void |
NoneQueryParserCache.close() |
Modifier and Type | Method and Description |
---|---|
void |
ResidentQueryParserCache.close() |
Modifier and Type | Class and Description |
---|---|
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 |
Modifier and Type | Method and Description |
---|---|
void |
RecoveryCounter.close() |
void |
EngineSearcher.close() |
void |
Engine.Searcher.close() |
protected void |
InternalEngine.closeNoLock(String reason)
Closes the engine without acquiring the write lock.
|
protected void |
ShadowEngine.closeNoLock(String reason) |
protected abstract void |
Engine.closeNoLock(String reason)
Method to close the engine while the write lock is held.
|
void |
Engine.RecoveryHandler.phase1(SnapshotIndexCommit snapshot) |
void |
Engine.RecoveryHandler.phase2(Translog.Snapshot snapshot) |
void |
Engine.RecoveryHandler.phase3(Translog.Snapshot snapshot) |
Modifier and Type | Class and Description |
---|---|
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 |
Modifier and Type | Method and Description |
---|---|
GetResult |
ShardGetService.get(String type,
String id,
String[] gFields,
boolean realtime,
long version,
VersionType versionType,
FetchSourceContext fetchSourceContext,
boolean ignoreErrorsOnGeneratedFields) |
GetResult |
ShardGetService.innerGet(String type,
String id,
String[] gFields,
boolean realtime,
long version,
VersionType versionType,
FetchSourceContext fetchSourceContext,
boolean ignoreErrorsOnGeneratedFields) |
Modifier and Type | Class and Description |
---|---|
class |
MapperCompressionException |
class |
MapperException |
class |
MapperParsingException |
class |
MergeMappingException |
class |
StrictDynamicMappingException |
Modifier and Type | Method and Description |
---|---|
void |
TieredMergePolicyProvider.close() |
void |
LogDocMergePolicyProvider.close() |
void |
LogByteSizeMergePolicyProvider.close() |
Modifier and Type | Class and Description |
---|---|
class |
PercolatorException
Exception during indexing a percolator query.
|
Modifier and Type | Class and Description |
---|---|
class |
QueryParsingException |
Modifier and Type | Method and Description |
---|---|
BytesReference |
QueryBuilder.buildAsBytes() |
BytesReference |
BaseFilterBuilder.buildAsBytes() |
BytesReference |
FilterBuilder.buildAsBytes() |
BytesReference |
BaseQueryBuilder.buildAsBytes() |
BytesReference |
QueryBuilder.buildAsBytes(XContentType contentType) |
BytesReference |
BaseFilterBuilder.buildAsBytes(XContentType contentType) |
BytesReference |
FilterBuilder.buildAsBytes(XContentType contentType) |
BytesReference |
BaseQueryBuilder.buildAsBytes(XContentType contentType) |
ParsedQuery |
IndexQueryParserService.parse(byte[] source) |
ParsedQuery |
IndexQueryParserService.parse(byte[] source,
int offset,
int length) |
ParsedQuery |
IndexQueryParserService.parse(BytesReference source) |
ParsedQuery |
IndexQueryParserService.parse(QueryBuilder queryBuilder) |
ParsedQuery |
IndexQueryParserService.parse(QueryParseContext context,
BytesReference source) |
Modifier and Type | Method and Description |
---|---|
void |
CustomQueryWrappingFilter.close() |
void |
ChildrenQuery.ParentCollector.close() |
void |
ChildrenQuery.ParentScoreCollector.close() |
void |
ChildrenQuery.ParentScoreCountCollector.close() |
Modifier and Type | Class and Description |
---|---|
class |
IllegalIndexShardStateException |
class |
IndexShardClosedException |
class |
IndexShardCreationException |
class |
IndexShardException |
class |
IndexShardNotRecoveringException |
class |
IndexShardNotStartedException |
class |
IndexShardRecoveringException |
class |
IndexShardRelocatedException |
class |
IndexShardStartedException |
Modifier and Type | Method and Description |
---|---|
ParsedDocument |
IndexShard.create(Engine.Create create) |
void |
IndexShard.delete(Engine.Delete delete) |
void |
IndexShard.deleteByQuery(Engine.DeleteByQuery deleteByQuery) |
void |
IndexShard.flush(FlushRequest request) |
Engine.GetResult |
IndexShard.get(Engine.Get get) |
ParsedDocument |
IndexShard.index(Engine.Index index) |
void |
IndexShard.optimize(OptimizeRequest optimize) |
Engine.IndexingOperation |
IndexShard.performRecoveryOperation(Translog.Operation operation)
Performs a single recovery operation, and returns the indexing operation (or null if its not an indexing operation)
that can then be used for mapping updates (for example) if needed.
|
Engine.Create |
IndexShard.prepareCreate(SourceToParse source,
long version,
VersionType versionType,
Engine.Operation.Origin origin,
boolean canHaveDuplicates,
boolean autoGeneratedId) |
Engine.Delete |
IndexShard.prepareDelete(String type,
String id,
long version,
VersionType versionType,
Engine.Operation.Origin origin) |
Engine.DeleteByQuery |
IndexShard.prepareDeleteByQuery(BytesReference source,
String[] filteringAliases,
Engine.Operation.Origin origin,
String... types) |
void |
IndexShard.prepareForIndexRecovery()
called before starting to copy index files over
|
void |
IndexShard.prepareForTranslogRecovery()
After the store has been recovered, we need to start the engine in order to apply operations
|
Engine.Index |
IndexShard.prepareIndex(SourceToParse source,
long version,
VersionType versionType,
Engine.Operation.Origin origin,
boolean canHaveDuplicates) |
void |
IndexShard.refresh(String source) |
Modifier and Type | Class and Description |
---|---|
class |
IndexShardRestoreException
Generic shard restore exception
|
class |
IndexShardRestoreFailedException
Thrown when restore of a shard fails
|
class |
IndexShardSnapshotException
Generic shard snapshot exception
|
class |
IndexShardSnapshotFailedException
Thrown when snapshot process is failed on a shard level
|
Modifier and Type | Class and Description |
---|---|
class |
StoreException |
Modifier and Type | Method and Description |
---|---|
void |
AbstractIndexStore.close() |
Modifier and Type | Class and Description |
---|---|
class |
TranslogCorruptedException |
class |
TranslogException |
Modifier and Type | Method and Description |
---|---|
void |
FsChannelSnapshot.close() |
void |
FsTranslog.close() |
Modifier and Type | Class and Description |
---|---|
class |
AliasFilterParsingException |
class |
IndexAlreadyExistsException |
class |
IndexClosedException
Exception indicating that one or more requested indices are closed.
|
class |
IndexCreationException |
class |
IndexMissingException |
class |
IndexPrimaryShardNotAllocatedException
Thrown when some action cannot be performed because the primary shard of
some shard group in an index has not been allocated post api action.
|
class |
IndexTemplateAlreadyExistsException |
class |
IndexTemplateMissingException |
class |
InvalidAliasNameException |
class |
InvalidIndexNameException |
class |
InvalidIndexTemplateException |
class |
InvalidTypeNameException |
class |
TypeMissingException |
Modifier and Type | Method and Description |
---|---|
IndexService |
IndicesService.createIndex(String sIndexName,
Settings settings,
String localNodeId) |
protected void |
IndicesService.doClose() |
protected void |
IndicesService.doStart() |
protected void |
IndicesService.doStop() |
void |
IndicesService.removeIndex(String index,
String reason)
Removes the given index from this service and releases all associated resources.
|
Modifier and Type | Method and Description |
---|---|
protected void |
CircuitBreakerService.doClose() |
protected void |
CircuitBreakerService.doStart() |
protected void |
CircuitBreakerService.doStop() |
Modifier and Type | Method and Description |
---|---|
protected void |
IndicesClusterStateService.doClose() |
protected void |
IndicesClusterStateService.doStart() |
protected void |
IndicesClusterStateService.doStop() |
Modifier and Type | Method and Description |
---|---|
protected void |
IndexingMemoryController.doClose() |
protected void |
IndexingMemoryController.doStart() |
protected void |
IndexingMemoryController.doStop() |
Modifier and Type | Class and Description |
---|---|
class |
DelayRecoveryException
An exception marking that this recovery attempt should be ignored (since probably, we already recovered).
|
class |
IgnoreRecoveryException
An exception marking that this recovery attempt should be ignored (since probably, we already recovered).
|
class |
RecoverFilesRecoveryException |
class |
RecoveryFailedException |
Modifier and Type | Method and Description |
---|---|
void |
RecoverySourceHandler.phase1(SnapshotIndexCommit snapshot)
Perform phase1 of the recovery operations.
|
void |
SharedFSRecoverySourceHandler.phase1(SnapshotIndexCommit snapshot) |
void |
RecoverySourceHandler.phase2(Translog.Snapshot snapshot)
Perform phase2 of the recovery process
Phase2 takes a snapshot of the current translog *without* acquiring the
write lock (however, the translog snapshot is a point-in-time view of
the translog).
|
void |
SharedFSRecoverySourceHandler.phase2(Translog.Snapshot snapshot) |
void |
RecoverySourceHandler.phase3(Translog.Snapshot snapshot)
Perform phase 3 of the recovery process
Phase3 again takes a snapshot of the translog, however this time the
snapshot is acquired under a write lock.
|
void |
SharedFSRecoverySourceHandler.phase3(Translog.Snapshot snapshot) |
protected int |
RecoverySourceHandler.sendSnapshot(Translog.Snapshot snapshot)
Send the given snapshot's operations to this handler's target node.
|
protected int |
SharedFSRecoverySourceHandler.sendSnapshot(Translog.Snapshot snapshot) |
Modifier and Type | Method and Description |
---|---|
protected TransportNodesListShardStoreMetaData.NodeStoreFilesMetaData |
TransportNodesListShardStoreMetaData.nodeOperation(org.elasticsearch.indices.store.TransportNodesListShardStoreMetaData.NodeRequest request) |
Modifier and Type | Method and Description |
---|---|
protected void |
IndicesTTLService.doClose() |
protected void |
IndicesTTLService.doStart() |
protected void |
IndicesTTLService.doStop() |
Modifier and Type | Method and Description |
---|---|
protected void |
MonitorService.doClose() |
protected void |
MonitorService.doStart() |
protected void |
MonitorService.doStop() |
Modifier and Type | Method and Description |
---|---|
protected void |
JvmMonitorService.doClose() |
protected void |
JvmMonitorService.doStart() |
protected void |
JvmMonitorService.doStop() |
Modifier and Type | Class and Description |
---|---|
class |
NodeClosedException
An exception indicating that node is closed.
|
Constructor and Description |
---|
InternalNode() |
InternalNode(Settings preparedSettings,
boolean loadConfigSettings) |
Modifier and Type | Class and Description |
---|---|
class |
PercolateException
Exception during percolating document(s) at runtime.
|
Modifier and Type | Class and Description |
---|---|
class |
RepositoryException
Generic repository exception
|
class |
RepositoryMissingException
Repository missing exception
|
class |
RepositoryVerificationException
Repository verification exception
|
Modifier and Type | Method and Description |
---|---|
protected void |
BlobStoreRepository.doClose() |
protected void |
BlobStoreRepository.doStart() |
protected void |
BlobStoreRepository.doStop() |
Modifier and Type | Method and Description |
---|---|
void |
RestFilter.close() |
protected void |
RestController.doClose() |
protected void |
RestController.doStart() |
protected void |
RestController.doStop() |
Modifier and Type | Class and Description |
---|---|
class |
AliasesMissingException |
Modifier and Type | Class and Description |
---|---|
class |
RiverException |
Modifier and Type | Method and Description |
---|---|
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() |
Modifier and Type | Method and Description |
---|---|
protected void |
RiverClusterService.doClose() |
protected void |
RiverClusterService.doStart() |
protected void |
RiverClusterService.doStop() |
Modifier and Type | Method and Description |
---|---|
protected void |
RiversRouter.doClose() |
protected void |
RiversRouter.doStart() |
protected void |
RiversRouter.doStop() |
Modifier and Type | Class and Description |
---|---|
class |
ScriptException |
static class |
ScriptParameterParser.ScriptParameterParseException |
Modifier and Type | Class and Description |
---|---|
class |
ExpressionScriptCompilationException
Exception representing a compilation error in an expression.
|
class |
ExpressionScriptExecutionException
Exception used to wrap exceptions occuring while running expressions.
|
Modifier and Type | Class and Description |
---|---|
class |
GroovyScriptCompilationException
Exception used to wrap groovy script compilation exceptions so they are
correctly serialized between nodes.
|
class |
GroovyScriptExecutionException
Exception used to wrap groovy script execution exceptions so they are
correctly serialized between nodes.
|
Modifier and Type | Class and Description |
---|---|
class |
SearchContextException |
class |
SearchContextMissingException |
class |
SearchException |
class |
SearchParseException |
Modifier and Type | Class and Description |
---|---|
class |
AggregationExecutionException
Thrown when failing to execute an aggregation
|
class |
AggregationInitializationException
Thrown when failing to execute an aggregation
|
Modifier and Type | Method and Description |
---|---|
void |
FilteringBucketCollector.close() |
void |
RecordingPerReaderBucketCollector.close() |
void |
AggregationPhase.execute(SearchContext context) |
Modifier and Type | Method and Description |
---|---|
void |
DeferringBucketCollector.close() |
Modifier and Type | Method and Description |
---|---|
void |
SignificantTermsAggregatorFactory.close() |
Modifier and Type | Method and Description |
---|---|
void |
HyperLogLogPlusPlus.close() |
Modifier and Type | Class and Description |
---|---|
class |
SearchSourceBuilderException |
Modifier and Type | Class and Description |
---|---|
class |
DfsPhaseExecutionException |
Modifier and Type | Class and Description |
---|---|
class |
FacetPhaseExecutionException |
Modifier and Type | Method and Description |
---|---|
void |
FacetPhase.execute(SearchContext context) |
Modifier and Type | Class and Description |
---|---|
class |
FetchPhaseExecutionException |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
void |
ExplainFetchSubPhase.hitExecute(SearchContext context,
FetchSubPhase.HitContext hitContext) |
void |
ExplainFetchSubPhase.hitsExecute(SearchContext context,
InternalSearchHit[] hits) |
Modifier and Type | Method and Description |
---|---|
void |
FieldDataFieldsFetchSubPhase.hitExecute(SearchContext context,
FetchSubPhase.HitContext hitContext) |
void |
FieldDataFieldsFetchSubPhase.hitsExecute(SearchContext context,
InternalSearchHit[] hits) |
Modifier and Type | Method and Description |
---|---|
void |
InnerHitsFetchSubPhase.hitExecute(SearchContext context,
FetchSubPhase.HitContext hitContext) |
void |
InnerHitsFetchSubPhase.hitsExecute(SearchContext context,
InternalSearchHit[] hits) |
Modifier and Type | Method and Description |
---|---|
void |
MatchedQueriesFetchSubPhase.hitExecute(SearchContext context,
FetchSubPhase.HitContext hitContext) |
void |
MatchedQueriesFetchSubPhase.hitsExecute(SearchContext context,
InternalSearchHit[] hits) |
Modifier and Type | Method and Description |
---|---|
void |
PartialFieldsFetchSubPhase.hitExecute(SearchContext context,
FetchSubPhase.HitContext hitContext) |
void |
PartialFieldsFetchSubPhase.hitsExecute(SearchContext context,
InternalSearchHit[] hits) |
Modifier and Type | Method and Description |
---|---|
void |
ScriptFieldsFetchSubPhase.hitExecute(SearchContext context,
FetchSubPhase.HitContext hitContext) |
void |
ScriptFieldsFetchSubPhase.hitsExecute(SearchContext context,
InternalSearchHit[] hits) |
Modifier and Type | Method and Description |
---|---|
void |
FetchSourceSubPhase.hitExecute(SearchContext context,
FetchSubPhase.HitContext hitContext) |
void |
FetchSourceSubPhase.hitsExecute(SearchContext context,
InternalSearchHit[] hits) |
Modifier and Type | Method and Description |
---|---|
void |
VersionFetchSubPhase.hitExecute(SearchContext context,
FetchSubPhase.HitContext hitContext) |
void |
VersionFetchSubPhase.hitsExecute(SearchContext context,
InternalSearchHit[] hits) |
Modifier and Type | Method and Description |
---|---|
void |
HighlightPhase.hitExecute(SearchContext context,
FetchSubPhase.HitContext hitContext) |
void |
HighlightPhase.hitsExecute(SearchContext context,
InternalSearchHit[] hits) |
Modifier and Type | Method and Description |
---|---|
void |
DefaultSearchContext.doClose() |
Modifier and Type | Class and Description |
---|---|
class |
QueryPhaseExecutionException |
Modifier and Type | Method and Description |
---|---|
void |
RescorePhase.execute(SearchContext context) |
Modifier and Type | Class and Description |
---|---|
class |
SuggestBuilderException
Exception thrown when errors are encountered in building Suggest lookup queries
via
SuggestBuilder |
Modifier and Type | Method and Description |
---|---|
void |
SuggestPhase.execute(SearchContext context) |
Modifier and Type | Class and Description |
---|---|
class |
IndexWarmerMissingException |
Modifier and Type | Class and Description |
---|---|
class |
ConcurrentSnapshotExecutionException
Thrown when a user tries to start multiple snapshots at the same time
|
class |
InvalidSnapshotNameException
Thrown on the attempt to create a snapshot with invalid name
|
class |
SnapshotCreationException
Thrown when snapshot creation fails completely
|
class |
SnapshotException
Generic snapshot exception
|
class |
SnapshotMissingException
Thrown if requested snapshot doesn't exist
|
class |
SnapshotRestoreException
Snapshot restore exception
|
Modifier and Type | Method and Description |
---|---|
protected void |
SnapshotsService.doClose() |
protected void |
SnapshotsService.doStart() |
protected void |
SnapshotsService.doStop() |
Modifier and Type | Class and Description |
---|---|
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 |
NodeShouldNotConnectException |
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 |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
protected void |
LocalTransport.doClose() |
protected void |
LocalTransport.doStart() |
protected void |
LocalTransport.doStop() |
Modifier and Type | Method and Description |
---|---|
protected void |
NettyTransport.doClose() |
protected void |
NettyTransport.doStart() |
protected void |
NettyTransport.doStop() |
Modifier and Type | Method and Description |
---|---|
protected void |
TribeService.doClose() |
protected void |
TribeService.doStart() |
protected void |
TribeService.doStop() |
Modifier and Type | Method and Description |
---|---|
protected void |
ResourceWatcherService.doClose() |
protected void |
ResourceWatcherService.doStart() |
protected void |
ResourceWatcherService.doStop() |
Copyright © 2009–2015. All rights reserved.