Serialized Form
- 
Package org.elasticsearch.action- 
Exception Class org.elasticsearch.action.ActionRequestValidationExceptionclass ActionRequestValidationException extends ValidationException implements Serializable
- 
Exception Class org.elasticsearch.action.FailedNodeExceptionclass FailedNodeException extends ElasticsearchException implements Serializable- 
Serialized Fields- 
nodeIdString nodeId 
 
- 
 
- 
- 
Exception Class org.elasticsearch.action.NoShardAvailableActionExceptionclass NoShardAvailableActionException extends ElasticsearchException implements Serializable- 
Serialized Fields- 
onShardFailureWrapperboolean onShardFailureWrapper 
 
- 
 
- 
- 
Exception Class org.elasticsearch.action.NoSuchNodeExceptionclass NoSuchNodeException extends FailedNodeException implements Serializable
- 
Exception Class org.elasticsearch.action.PrimaryMissingActionExceptionclass PrimaryMissingActionException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.action.RoutingMissingExceptionclass RoutingMissingException extends ElasticsearchException implements Serializable- 
Serialized Fields- 
idString id 
 
- 
 
- 
- 
Exception Class org.elasticsearch.action.ShardOperationFailedExceptionclass ShardOperationFailedException extends Exception implements Serializable- 
Serialized Fields- 
causeThrowable cause 
- 
indexString index 
- 
reasonString reason 
- 
shardIdint shardId 
- 
statusRestStatus status 
 
- 
 
- 
- 
Exception Class org.elasticsearch.action.TimestampParsingExceptionclass TimestampParsingException extends ElasticsearchException implements Serializable- 
Serialized Fields- 
timestampString timestamp 
 
- 
 
- 
 
- 
- 
Package org.elasticsearch.action.support- 
Exception Class org.elasticsearch.action.support.DefaultShardOperationFailedExceptionclass DefaultShardOperationFailedException extends ShardOperationFailedException implements Serializable
 
- 
- 
Package org.elasticsearch.action.support.replication- 
Exception Class org.elasticsearch.action.support.replication.ReplicationOperation.RetryOnPrimaryExceptionclass RetryOnPrimaryException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failureclass Failure extends ShardOperationFailedException implements Serializable
- 
Exception Class org.elasticsearch.action.support.replication.TransportReplicationAction.RetryOnReplicaExceptionclass RetryOnReplicaException extends ElasticsearchException implements Serializable
 
- 
- 
Package org.elasticsearch.bootstrap- 
Exception Class org.elasticsearch.bootstrap.StartupExceptionclass StartupException extends Exception implements Serializable
 
- 
- 
Package org.elasticsearch.cli- 
Exception Class org.elasticsearch.cli.UserExceptionclass UserException extends Exception implements Serializable- 
Serialized Fields- 
exitCodeint exitCode 
 
- 
 
- 
 
- 
- 
Package org.elasticsearch.client- 
Exception Class org.elasticsearch.client.ResponseExceptionclass ResponseException extends IOException implements Serializable- 
Serialized Fields- 
responseResponse response 
 
- 
 
- 
- 
Exception Class org.elasticsearch.client.WarningFailureExceptionclass WarningFailureException extends RuntimeException implements Serializable- 
Serialized Fields- 
responseResponse response 
 
- 
 
- 
 
- 
- 
Package org.elasticsearch.cluster- 
Exception Class org.elasticsearch.cluster.IncompatibleClusterStateVersionExceptionclass IncompatibleClusterStateVersionException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.cluster.NotMasterExceptionclass NotMasterException extends ElasticsearchException implements Serializable
 
- 
- 
Package org.elasticsearch.cluster.coordination- 
Exception Class org.elasticsearch.cluster.coordination.CoordinationStateRejectedExceptionclass CoordinationStateRejectedException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.cluster.coordination.FailedToCommitClusterStateExceptionclass FailedToCommitClusterStateException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.cluster.coordination.LinearizabilityChecker.LinearizabilityCheckAbortedclass LinearizabilityCheckAborted extends Exception implements Serializable
- 
Exception Class org.elasticsearch.cluster.coordination.NodeHealthCheckFailureExceptionclass NodeHealthCheckFailureException extends ElasticsearchException implements Serializable
 
- 
- 
Package org.elasticsearch.cluster.metadata- 
Exception Class org.elasticsearch.cluster.metadata.DataStream.TimestampErrorclass TimestampError extends IllegalArgumentException implements Serializable
- 
Exception Class org.elasticsearch.cluster.metadata.ProcessClusterEventTimeoutExceptionclass ProcessClusterEventTimeoutException extends ElasticsearchException implements Serializable
 
- 
- 
Package org.elasticsearch.cluster.routing- 
Exception Class org.elasticsearch.cluster.routing.IllegalShardRoutingStateExceptionclass IllegalShardRoutingStateException extends RoutingException implements Serializable- 
Serialized Fields- 
shardShardRouting shard 
 
- 
 
- 
- 
Exception Class org.elasticsearch.cluster.routing.RoutingExceptionclass RoutingException extends ElasticsearchException implements Serializable
 
- 
- 
Package org.elasticsearch.common.breaker- 
Exception Class org.elasticsearch.common.breaker.CircuitBreakingExceptionclass CircuitBreakingException extends ElasticsearchException implements Serializable- 
Serialized Fields- 
byteLimitlong byteLimit 
- 
bytesWantedlong bytesWanted 
- 
durabilityCircuitBreaker.Durability durability 
 
- 
 
- 
 
- 
- 
Package org.elasticsearch.common.logging- 
Class org.elasticsearch.common.logging.ESLogMessageclass ESLogMessage extends org.apache.logging.log4j.message.MapMessage<ESLogMessage,Object> implements Serializable 
 
- 
- 
Package org.elasticsearch.common.network- 
Class org.elasticsearch.common.network.ThreadWatchdog.ActivityTrackerclass ActivityTracker extends AtomicLong implements Serializable- 
Serialized Fields- 
lastObservedValuelong lastObservedValue 
- 
trackedThreadThread trackedThread 
 
- 
 
- 
 
- 
- 
Package org.elasticsearch.common.settings- 
Exception Class org.elasticsearch.common.settings.NoClassSettingsExceptionclass NoClassSettingsException extends SettingsException implements Serializable
- 
Exception Class org.elasticsearch.common.settings.SettingsExceptionclass SettingsException extends ElasticsearchException implements Serializable
 
- 
- 
Package org.elasticsearch.common.util- 
Exception Class org.elasticsearch.common.util.CancellableThreads.ExecutionCancelledExceptionclass ExecutionCancelledException extends ElasticsearchException implements Serializable
 
- 
- 
Package org.elasticsearch.common.util.concurrent- 
Class org.elasticsearch.common.util.concurrent.AdjustableSemaphoreclass AdjustableSemaphore extends Semaphore implements Serializable- 
Serialized Fields- 
maxPermitsint maxPermits 
- 
maxPermitsMutexObject maxPermitsMutex 
 
- 
 
- 
- 
Exception Class org.elasticsearch.common.util.concurrent.EsRejectedExecutionExceptionclass EsRejectedExecutionException extends RejectedExecutionException implements Serializable- 
Serialized Fields- 
isExecutorShutdownboolean isExecutorShutdown 
 
- 
 
- 
- 
Exception Class org.elasticsearch.common.util.concurrent.UncategorizedExecutionExceptionclass UncategorizedExecutionException extends ElasticsearchException implements Serializable
 
- 
- 
Package org.elasticsearch.env- 
Exception Class org.elasticsearch.env.ShardLockObtainFailedExceptionclass ShardLockObtainFailedException extends ElasticsearchException implements Serializable
 
- 
- 
Package org.elasticsearch.gateway- 
Exception Class org.elasticsearch.gateway.CorruptStateExceptionclass CorruptStateException extends ElasticsearchCorruptionException implements Serializable
- 
Exception Class org.elasticsearch.gateway.WriteStateExceptionclass WriteStateException extends IOException implements Serializable- 
Serialized Fields- 
dirtyboolean dirty 
 
- 
 
- 
 
- 
- 
Package org.elasticsearch.http- 
Exception Class org.elasticsearch.http.BindHttpExceptionclass BindHttpException extends HttpException implements Serializable
- 
Exception Class org.elasticsearch.http.HttpExceptionclass HttpException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.http.HttpHeadersValidationExceptionclass HttpHeadersValidationException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.http.HttpReadTimeoutExceptionclass HttpReadTimeoutException extends RuntimeException implements Serializable
 
- 
- 
Package org.elasticsearch.index- 
Exception Class org.elasticsearch.index.IndexNotFoundExceptionclass IndexNotFoundException extends ResourceNotFoundException implements Serializable
 
- 
- 
Package org.elasticsearch.index.engine- 
Exception Class org.elasticsearch.index.engine.DocumentMissingExceptionclass DocumentMissingException extends EngineException implements Serializable
- 
Exception Class org.elasticsearch.index.engine.DocumentSourceMissingExceptionclass DocumentSourceMissingException extends EngineException implements Serializable
- 
Exception Class org.elasticsearch.index.engine.EngineCreationFailureExceptionclass EngineCreationFailureException extends EngineException implements Serializable
- 
Exception Class org.elasticsearch.index.engine.EngineExceptionclass EngineException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.index.engine.FlushFailedEngineExceptionclass FlushFailedEngineException extends EngineException implements Serializable
- 
Exception Class org.elasticsearch.index.engine.MissingHistoryOperationsExceptionclass MissingHistoryOperationsException extends IllegalStateException implements Serializable
- 
Exception Class org.elasticsearch.index.engine.RecoveryEngineExceptionclass RecoveryEngineException extends EngineException implements Serializable- 
Serialized Fields- 
phaseint phase 
 
- 
 
- 
- 
Exception Class org.elasticsearch.index.engine.RefreshFailedEngineExceptionclass RefreshFailedEngineException extends EngineException implements Serializable
- 
Exception Class org.elasticsearch.index.engine.VersionConflictEngineExceptionclass VersionConflictEngineException extends EngineException implements Serializable
 
- 
- 
Package org.elasticsearch.index.mapper- 
Exception Class org.elasticsearch.index.mapper.DocumentParsingExceptionclass DocumentParsingException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.index.mapper.MapperExceptionclass MapperException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.index.mapper.MapperParsingExceptionclass MapperParsingException extends MapperException implements Serializable
- 
Exception Class org.elasticsearch.index.mapper.StrictDynamicMappingExceptionclass StrictDynamicMappingException extends DocumentParsingException implements Serializable
 
- 
- 
Package org.elasticsearch.index.query- 
Exception Class org.elasticsearch.index.query.QueryShardExceptionclass QueryShardException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.index.query.QueryValidationExceptionclass QueryValidationException extends ValidationException implements Serializable
 
- 
- 
Package org.elasticsearch.index.seqno- 
Exception Class org.elasticsearch.index.seqno.RetentionLeaseAlreadyExistsExceptionclass RetentionLeaseAlreadyExistsException extends ResourceAlreadyExistsException implements Serializable
- 
Exception Class org.elasticsearch.index.seqno.RetentionLeaseInvalidRetainingSeqNoExceptionclass RetentionLeaseInvalidRetainingSeqNoException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.index.seqno.RetentionLeaseNotFoundExceptionclass RetentionLeaseNotFoundException extends ResourceNotFoundException implements Serializable
 
- 
- 
Package org.elasticsearch.index.shard- 
Exception Class org.elasticsearch.index.shard.IllegalIndexShardStateExceptionclass IllegalIndexShardStateException extends ElasticsearchException implements Serializable- 
Serialized Fields- 
currentStateIndexShardState currentState 
 
- 
 
- 
- 
Exception Class org.elasticsearch.index.shard.IndexShardClosedExceptionclass IndexShardClosedException extends IllegalIndexShardStateException implements Serializable
- 
Exception Class org.elasticsearch.index.shard.IndexShardNotRecoveringExceptionclass IndexShardNotRecoveringException extends IllegalIndexShardStateException implements Serializable
- 
Exception Class org.elasticsearch.index.shard.IndexShardNotStartedExceptionclass IndexShardNotStartedException extends IllegalIndexShardStateException implements Serializable
- 
Exception Class org.elasticsearch.index.shard.IndexShardRecoveringExceptionclass IndexShardRecoveringException extends IllegalIndexShardStateException implements Serializable
- 
Exception Class org.elasticsearch.index.shard.IndexShardRecoveryExceptionclass IndexShardRecoveryException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.index.shard.IndexShardRelocatedExceptionclass IndexShardRelocatedException extends IllegalIndexShardStateException implements Serializable
- 
Exception Class org.elasticsearch.index.shard.IndexShardStartedExceptionclass IndexShardStartedException extends IllegalIndexShardStateException implements Serializable
- 
Exception Class org.elasticsearch.index.shard.ShardNotFoundExceptionclass ShardNotFoundException extends ResourceNotFoundException implements Serializable
- 
Exception Class org.elasticsearch.index.shard.ShardNotInPrimaryModeExceptionclass ShardNotInPrimaryModeException extends IllegalIndexShardStateException implements Serializable
 
- 
- 
Package org.elasticsearch.index.store- 
Exception Class org.elasticsearch.index.store.ImmutableDirectoryExceptionclass ImmutableDirectoryException extends IllegalArgumentException implements Serializable
 
- 
- 
Package org.elasticsearch.index.translog- 
Exception Class org.elasticsearch.index.translog.TranslogCorruptedExceptionclass TranslogCorruptedException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.index.translog.TranslogExceptionclass TranslogException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.index.translog.TruncatedTranslogExceptionclass TruncatedTranslogException extends TranslogCorruptedException implements Serializable
 
- 
- 
Package org.elasticsearch.indices- 
Exception Class org.elasticsearch.indices.AliasFilterParsingExceptionclass AliasFilterParsingException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.indices.AutoscalingMissedIndicesUpdateExceptionclass AutoscalingMissedIndicesUpdateException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.indices.FailureIndexNotSupportedExceptionclass FailureIndexNotSupportedException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.indices.IndexClosedExceptionclass IndexClosedException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.indices.IndexCreationExceptionclass IndexCreationException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.indices.IndexPrimaryShardNotAllocatedExceptionclass IndexPrimaryShardNotAllocatedException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.indices.IndexTemplateMissingExceptionclass IndexTemplateMissingException extends ElasticsearchException implements Serializable- 
Serialized Fields- 
nameString name 
 
- 
 
- 
- 
Exception Class org.elasticsearch.indices.InvalidAliasNameExceptionclass InvalidAliasNameException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.indices.InvalidIndexNameExceptionclass InvalidIndexNameException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.indices.InvalidIndexTemplateExceptionclass InvalidIndexTemplateException extends ElasticsearchException implements Serializable- 
Serialized Fields- 
nameString name 
 
- 
 
- 
- 
Exception Class org.elasticsearch.indices.InvalidTypeNameExceptionclass InvalidTypeNameException extends MapperException implements Serializable
- 
Exception Class org.elasticsearch.indices.TypeMissingExceptionclass TypeMissingException extends ElasticsearchException implements Serializable
 
- 
- 
Package org.elasticsearch.indices.recovery- 
Exception Class org.elasticsearch.indices.recovery.DelayRecoveryExceptionclass DelayRecoveryException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.indices.recovery.PeerRecoveryNotFoundclass PeerRecoveryNotFound extends ResourceNotFoundException implements Serializable
- 
Exception Class org.elasticsearch.indices.recovery.RecoverFilesRecoveryExceptionclass RecoverFilesRecoveryException extends ElasticsearchException implements Serializable- 
Serialized Fields- 
numberOfFilesint numberOfFiles 
- 
totalFilesSizeByteSizeValue totalFilesSize 
 
- 
 
- 
- 
Exception Class org.elasticsearch.indices.recovery.RecoveryCommitTooNewExceptionclass RecoveryCommitTooNewException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.indices.recovery.RecoveryFailedExceptionclass RecoveryFailedException extends ElasticsearchException implements Serializable
 
- 
- 
Package org.elasticsearch.ingest- 
Exception Class org.elasticsearch.ingest.GraphStructureExceptionclass GraphStructureException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.ingest.IngestPipelineExceptionclass IngestPipelineException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.ingest.IngestProcessorExceptionclass IngestProcessorException extends ElasticsearchException implements Serializable
 
- 
- 
Package org.elasticsearch.injection.guice- 
Exception Class org.elasticsearch.injection.guice.ConfigurationExceptionclass ConfigurationException extends RuntimeException implements Serializable
- 
Exception Class org.elasticsearch.injection.guice.CreationExceptionclass CreationException extends RuntimeException implements Serializable- 
Serialized Fields- 
messagesCollection<Message> messages 
 
- 
 
- 
- 
Exception Class org.elasticsearch.injection.guice.ProvisionExceptionclass ProvisionException extends RuntimeException implements Serializable
 
- 
- 
Package org.elasticsearch.node- 
Exception Class org.elasticsearch.node.NodeClosedExceptionclass NodeClosedException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.node.NodeValidationExceptionclass NodeValidationException extends Exception implements Serializable
 
- 
- 
Package org.elasticsearch.repositories- 
Exception Class org.elasticsearch.repositories.RepositoryConflictExceptionclass RepositoryConflictException extends RepositoryException implements Serializable
- 
Exception Class org.elasticsearch.repositories.RepositoryExceptionclass RepositoryException extends ElasticsearchException implements Serializable- 
Serialized Fields- 
repositoryString repository 
 
- 
 
- 
- 
Exception Class org.elasticsearch.repositories.RepositoryMissingExceptionclass RepositoryMissingException extends RepositoryException implements Serializable
- 
Exception Class org.elasticsearch.repositories.RepositoryVerificationExceptionclass RepositoryVerificationException extends RepositoryException implements Serializable
 
- 
- 
Package org.elasticsearch.repositories.blobstore- 
Exception Class org.elasticsearch.repositories.blobstore.RequestedRangeNotSatisfiedExceptionclass RequestedRangeNotSatisfiedException extends IOException implements Serializable- 
Serialized Fields- 
lengthlong length 
- 
positionlong position 
- 
resourceString resource 
 
- 
 
- 
 
- 
- 
Package org.elasticsearch.rest- 
Exception Class org.elasticsearch.rest.ApiNotAvailableExceptionclass ApiNotAvailableException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.rest.RestRequest.BadParameterExceptionclass BadParameterException extends RuntimeException implements Serializable
- 
Exception Class org.elasticsearch.rest.RestRequest.MediaTypeHeaderExceptionclass MediaTypeHeaderException extends RuntimeException implements Serializable
 
- 
- 
Package org.elasticsearch.script- 
Class org.elasticsearch.script.ClassPermissionclass ClassPermission extends BasicPermission implements Serializable
- 
Exception Class org.elasticsearch.script.GeneralScriptExceptionclass GeneralScriptException extends ElasticsearchException implements Serializable
- 
Class org.elasticsearch.script.ScoreAccessorclass ScoreAccessor extends Number implements Serializable- 
Serialized Fields- 
scorerorg.apache.lucene.search.Scorable scorer 
 
- 
 
- 
- 
Exception Class org.elasticsearch.script.ScriptExceptionclass ScriptException extends ElasticsearchException implements Serializable- 
Serialized Fields- 
langString lang 
- 
posScriptException.Position pos 
- 
scriptString script 
- 
scriptStackList<String> scriptStack 
 
- 
 
- 
 
- 
- 
Package org.elasticsearch.search- 
Exception Class org.elasticsearch.search.SearchContextMissingExceptionclass SearchContextMissingException extends ElasticsearchException implements Serializable- 
Serialized Fields- 
contextIdShardSearchContextId contextId 
 
- 
 
- 
- 
Exception Class org.elasticsearch.search.SearchExceptionclass SearchException extends ElasticsearchException implements Serializable- 
Serialized Fields- 
shardTargetSearchShardTarget shardTarget 
 
- 
 
- 
- 
Exception Class org.elasticsearch.search.TooManyScrollContextsExceptionclass TooManyScrollContextsException extends ElasticsearchException implements Serializable
 
- 
- 
Package org.elasticsearch.search.aggregations- 
Exception Class org.elasticsearch.search.aggregations.AggregationExecutionExceptionclass AggregationExecutionException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.search.aggregations.AggregationExecutionException.InvalidPathclass InvalidPath extends AggregationExecutionException implements Serializable
- 
Exception Class org.elasticsearch.search.aggregations.AggregationInitializationExceptionclass AggregationInitializationException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.search.aggregations.InvalidAggregationPathExceptionclass InvalidAggregationPathException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.search.aggregations.MultiBucketConsumerService.TooManyBucketsExceptionclass TooManyBucketsException extends AggregationExecutionException implements Serializable- 
Serialized Fields- 
maxBucketsint maxBuckets 
 
- 
 
- 
- 
Exception Class org.elasticsearch.search.aggregations.UnsupportedAggregationOnDownsampledIndexclass UnsupportedAggregationOnDownsampledIndex extends AggregationExecutionException implements Serializable
 
- 
- 
Package org.elasticsearch.search.aggregations.metrics- 
Class org.elasticsearch.search.aggregations.metrics.EmptyDoubleHdrHistogramclass EmptyDoubleHdrHistogram extends org.HdrHistogram.DoubleHistogram implements Serializable
 
- 
- 
Package org.elasticsearch.search.fetch- 
Exception Class org.elasticsearch.search.fetch.FetchPhaseExecutionExceptionclass FetchPhaseExecutionException extends SearchException implements Serializable
 
- 
- 
Package org.elasticsearch.snapshots- 
Exception Class org.elasticsearch.snapshots.AbortedSnapshotExceptionclass AbortedSnapshotException extends RuntimeException implements Serializable
- 
Exception Class org.elasticsearch.snapshots.ConcurrentSnapshotExecutionExceptionclass ConcurrentSnapshotExecutionException extends SnapshotException implements Serializable
- 
Exception Class org.elasticsearch.snapshots.InvalidSnapshotNameExceptionclass InvalidSnapshotNameException extends SnapshotException implements Serializable
- 
Exception Class org.elasticsearch.snapshots.PausedSnapshotExceptionclass PausedSnapshotException extends RuntimeException implements Serializable
- 
Exception Class org.elasticsearch.snapshots.SnapshotExceptionclass SnapshotException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.snapshots.SnapshotInProgressExceptionclass SnapshotInProgressException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.snapshots.SnapshotMissingExceptionclass SnapshotMissingException extends SnapshotException implements Serializable
- 
Exception Class org.elasticsearch.snapshots.SnapshotNameAlreadyInUseExceptionclass SnapshotNameAlreadyInUseException extends InvalidSnapshotNameException implements Serializable
- 
Exception Class org.elasticsearch.snapshots.SnapshotRestoreExceptionclass SnapshotRestoreException extends SnapshotException implements Serializable
- 
Exception Class org.elasticsearch.snapshots.SnapshotShardFailureclass SnapshotShardFailure extends ShardOperationFailedException implements Serializable
 
- 
- 
Package org.elasticsearch.tasks- 
Exception Class org.elasticsearch.tasks.TaskCancelledExceptionclass TaskCancelledException extends ElasticsearchException implements Serializable
 
- 
- 
Package org.elasticsearch.transport- 
Exception Class org.elasticsearch.transport.ActionNotFoundTransportExceptionclass ActionNotFoundTransportException extends TransportException implements Serializable- 
Serialized Fields- 
actionString action 
 
- 
 
- 
- 
Exception Class org.elasticsearch.transport.ActionTransportExceptionclass ActionTransportException extends TransportException implements Serializable
- 
Exception Class org.elasticsearch.transport.BindTransportExceptionclass BindTransportException extends TransportException implements Serializable
- 
Exception Class org.elasticsearch.transport.ConnectTransportExceptionclass ConnectTransportException extends ActionTransportException implements Serializable
- 
Exception Class org.elasticsearch.transport.HeaderValidationExceptionclass HeaderValidationException extends RuntimeException implements Serializable
- 
Exception Class org.elasticsearch.transport.NodeDisconnectedExceptionclass NodeDisconnectedException extends ConnectTransportException implements Serializable
- 
Exception Class org.elasticsearch.transport.NodeNotConnectedExceptionclass NodeNotConnectedException extends ConnectTransportException implements Serializable
- 
Exception Class org.elasticsearch.transport.NoSeedNodeLeftExceptionclass NoSeedNodeLeftException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.transport.NoSuchRemoteClusterExceptionclass NoSuchRemoteClusterException extends ResourceNotFoundException implements Serializable
- 
Exception Class org.elasticsearch.transport.NotSerializableTransportExceptionclass NotSerializableTransportException extends TransportException implements Serializable
- 
Exception Class org.elasticsearch.transport.ReceiveTimeoutTransportExceptionclass ReceiveTimeoutTransportException extends ActionTransportException implements Serializable
- 
Exception Class org.elasticsearch.transport.RemoteTransportExceptionclass RemoteTransportException extends ActionTransportException implements Serializable
- 
Exception Class org.elasticsearch.transport.ResponseHandlerFailureTransportExceptionclass ResponseHandlerFailureTransportException extends TransportException implements Serializable
- 
Exception Class org.elasticsearch.transport.SendRequestTransportExceptionclass SendRequestTransportException extends ActionTransportException implements Serializable
- 
Exception Class org.elasticsearch.transport.TcpTransport.HttpRequestOnTransportExceptionclass HttpRequestOnTransportException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.transport.TransportExceptionclass TransportException extends ElasticsearchException implements Serializable
- 
Exception Class org.elasticsearch.transport.TransportNotReadyExceptionclass TransportNotReadyException extends RuntimeException implements Serializable
- 
Exception Class org.elasticsearch.transport.TransportSerializationExceptionclass TransportSerializationException extends TransportException implements Serializable
 
-