Serialized Form
-
Package org.elasticsearch.action
-
Exception Class org.elasticsearch.action.ActionRequestValidationException
class ActionRequestValidationException extends ValidationException implements Serializable -
Exception Class org.elasticsearch.action.FailedNodeException
class FailedNodeException extends ElasticsearchException implements Serializable-
Serialized Fields
-
nodeId
String nodeId
-
-
-
Exception Class org.elasticsearch.action.NoShardAvailableActionException
class NoShardAvailableActionException extends ElasticsearchException implements Serializable-
Serialized Fields
-
onShardFailureWrapper
boolean onShardFailureWrapper
-
-
-
Exception Class org.elasticsearch.action.NoSuchNodeException
class NoSuchNodeException extends FailedNodeException implements Serializable -
Exception Class org.elasticsearch.action.PrimaryMissingActionException
class PrimaryMissingActionException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.action.RoutingMissingException
class RoutingMissingException extends ElasticsearchException implements Serializable-
Serialized Fields
-
id
String id
-
-
-
Exception Class org.elasticsearch.action.ShardOperationFailedException
class ShardOperationFailedException extends Exception implements Serializable-
Serialized Fields
-
cause
Throwable cause
-
index
String index
-
reason
String reason
-
shardId
int shardId
-
status
RestStatus status
-
-
-
Exception Class org.elasticsearch.action.TimestampParsingException
class TimestampParsingException extends ElasticsearchException implements Serializable-
Serialized Fields
-
timestamp
String timestamp
-
-
-
-
Package org.elasticsearch.action.support
-
Exception Class org.elasticsearch.action.support.DefaultShardOperationFailedException
class DefaultShardOperationFailedException extends ShardOperationFailedException implements Serializable
-
-
Package org.elasticsearch.action.support.replication
-
Exception Class org.elasticsearch.action.support.replication.ReplicationOperation.RetryOnPrimaryException
class RetryOnPrimaryException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure
class Failure extends ShardOperationFailedException implements Serializable -
Exception Class org.elasticsearch.action.support.replication.TransportReplicationAction.RetryOnReplicaException
class RetryOnReplicaException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.bootstrap
-
Exception Class org.elasticsearch.bootstrap.StartupException
class StartupException extends Exception implements Serializable
-
-
Package org.elasticsearch.cli
-
Exception Class org.elasticsearch.cli.UserException
class UserException extends Exception implements Serializable-
Serialized Fields
-
exitCode
int exitCode
-
-
-
-
Package org.elasticsearch.client
-
Exception Class org.elasticsearch.client.ResponseException
class ResponseException extends IOException implements Serializable-
Serialized Fields
-
response
Response response
-
-
-
Exception Class org.elasticsearch.client.WarningFailureException
class WarningFailureException extends RuntimeException implements Serializable-
Serialized Fields
-
response
Response response
-
-
-
-
Package org.elasticsearch.cluster
-
Exception Class org.elasticsearch.cluster.IncompatibleClusterStateVersionException
class IncompatibleClusterStateVersionException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.cluster.NotMasterException
class NotMasterException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.cluster.coordination
-
Exception Class org.elasticsearch.cluster.coordination.CoordinationStateRejectedException
class CoordinationStateRejectedException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.cluster.coordination.FailedToCommitClusterStateException
class FailedToCommitClusterStateException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.cluster.coordination.LinearizabilityChecker.LinearizabilityCheckAborted
class LinearizabilityCheckAborted extends Exception implements Serializable -
Exception Class org.elasticsearch.cluster.coordination.NodeHealthCheckFailureException
class NodeHealthCheckFailureException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.cluster.metadata
-
Exception Class org.elasticsearch.cluster.metadata.DataStream.TimestampError
class TimestampError extends IllegalArgumentException implements Serializable -
Exception Class org.elasticsearch.cluster.metadata.ProcessClusterEventTimeoutException
class ProcessClusterEventTimeoutException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.cluster.routing
-
Exception Class org.elasticsearch.cluster.routing.IllegalShardRoutingStateException
class IllegalShardRoutingStateException extends RoutingException implements Serializable-
Serialized Fields
-
shard
ShardRouting shard
-
-
-
Exception Class org.elasticsearch.cluster.routing.RoutingException
class RoutingException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.common.breaker
-
Exception Class org.elasticsearch.common.breaker.CircuitBreakingException
class CircuitBreakingException extends ElasticsearchException implements Serializable-
Serialized Fields
-
byteLimit
long byteLimit
-
bytesWanted
long bytesWanted
-
durability
CircuitBreaker.Durability durability
-
-
-
-
Package org.elasticsearch.common.logging
-
Class org.elasticsearch.common.logging.ESLogMessage
class ESLogMessage extends org.apache.logging.log4j.message.MapMessage<ESLogMessage,Object> implements Serializable
-
-
Package org.elasticsearch.common.network
-
Class org.elasticsearch.common.network.ThreadWatchdog.ActivityTracker
class ActivityTracker extends AtomicLong implements Serializable-
Serialized Fields
-
lastObservedValue
long lastObservedValue
-
trackedThread
Thread trackedThread
-
-
-
-
Package org.elasticsearch.common.settings
-
Exception Class org.elasticsearch.common.settings.NoClassSettingsException
class NoClassSettingsException extends SettingsException implements Serializable -
Exception Class org.elasticsearch.common.settings.SettingsException
class SettingsException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.common.util
-
Exception Class org.elasticsearch.common.util.CancellableThreads.ExecutionCancelledException
class ExecutionCancelledException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.common.util.concurrent
-
Class org.elasticsearch.common.util.concurrent.AdjustableSemaphore
class AdjustableSemaphore extends Semaphore implements Serializable-
Serialized Fields
-
maxPermits
int maxPermits
-
maxPermitsMutex
Object maxPermitsMutex
-
-
-
Exception Class org.elasticsearch.common.util.concurrent.EsRejectedExecutionException
class EsRejectedExecutionException extends RejectedExecutionException implements Serializable-
Serialized Fields
-
isExecutorShutdown
boolean isExecutorShutdown
-
-
-
Exception Class org.elasticsearch.common.util.concurrent.UncategorizedExecutionException
class UncategorizedExecutionException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.env
-
Exception Class org.elasticsearch.env.ShardLockObtainFailedException
class ShardLockObtainFailedException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.gateway
-
Exception Class org.elasticsearch.gateway.CorruptStateException
class CorruptStateException extends ElasticsearchCorruptionException implements Serializable -
Exception Class org.elasticsearch.gateway.WriteStateException
class WriteStateException extends IOException implements Serializable-
Serialized Fields
-
dirty
boolean dirty
-
-
-
-
Package org.elasticsearch.http
-
Exception Class org.elasticsearch.http.BindHttpException
class BindHttpException extends HttpException implements Serializable -
Exception Class org.elasticsearch.http.HttpException
class HttpException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.http.HttpHeadersValidationException
class HttpHeadersValidationException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.http.HttpReadTimeoutException
class HttpReadTimeoutException extends RuntimeException implements Serializable
-
-
Package org.elasticsearch.index
-
Exception Class org.elasticsearch.index.IndexNotFoundException
class IndexNotFoundException extends ResourceNotFoundException implements Serializable
-
-
Package org.elasticsearch.index.engine
-
Exception Class org.elasticsearch.index.engine.DocumentMissingException
class DocumentMissingException extends EngineException implements Serializable -
Exception Class org.elasticsearch.index.engine.DocumentSourceMissingException
class DocumentSourceMissingException extends EngineException implements Serializable -
Exception Class org.elasticsearch.index.engine.EngineCreationFailureException
class EngineCreationFailureException extends EngineException implements Serializable -
Exception Class org.elasticsearch.index.engine.EngineException
class EngineException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.index.engine.FlushFailedEngineException
class FlushFailedEngineException extends EngineException implements Serializable -
Exception Class org.elasticsearch.index.engine.MissingHistoryOperationsException
class MissingHistoryOperationsException extends IllegalStateException implements Serializable -
Exception Class org.elasticsearch.index.engine.RecoveryEngineException
class RecoveryEngineException extends EngineException implements Serializable-
Serialized Fields
-
phase
int phase
-
-
-
Exception Class org.elasticsearch.index.engine.RefreshFailedEngineException
class RefreshFailedEngineException extends EngineException implements Serializable -
Exception Class org.elasticsearch.index.engine.VersionConflictEngineException
class VersionConflictEngineException extends EngineException implements Serializable
-
-
Package org.elasticsearch.index.mapper
-
Exception Class org.elasticsearch.index.mapper.DocumentParsingException
class DocumentParsingException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.index.mapper.MapperException
class MapperException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.index.mapper.MapperParsingException
class MapperParsingException extends MapperException implements Serializable -
Exception Class org.elasticsearch.index.mapper.StrictDynamicMappingException
class StrictDynamicMappingException extends DocumentParsingException implements Serializable
-
-
Package org.elasticsearch.index.query
-
Exception Class org.elasticsearch.index.query.QueryShardException
class QueryShardException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.index.query.QueryValidationException
class QueryValidationException extends ValidationException implements Serializable
-
-
Package org.elasticsearch.index.seqno
-
Exception Class org.elasticsearch.index.seqno.RetentionLeaseAlreadyExistsException
class RetentionLeaseAlreadyExistsException extends ResourceAlreadyExistsException implements Serializable -
Exception Class org.elasticsearch.index.seqno.RetentionLeaseInvalidRetainingSeqNoException
class RetentionLeaseInvalidRetainingSeqNoException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.index.seqno.RetentionLeaseNotFoundException
class RetentionLeaseNotFoundException extends ResourceNotFoundException implements Serializable
-
-
Package org.elasticsearch.index.shard
-
Exception Class org.elasticsearch.index.shard.IllegalIndexShardStateException
class IllegalIndexShardStateException extends ElasticsearchException implements Serializable-
Serialized Fields
-
currentState
IndexShardState currentState
-
-
-
Exception Class org.elasticsearch.index.shard.IndexShardClosedException
class IndexShardClosedException extends IllegalIndexShardStateException implements Serializable -
Exception Class org.elasticsearch.index.shard.IndexShardNotRecoveringException
class IndexShardNotRecoveringException extends IllegalIndexShardStateException implements Serializable -
Exception Class org.elasticsearch.index.shard.IndexShardNotStartedException
class IndexShardNotStartedException extends IllegalIndexShardStateException implements Serializable -
Exception Class org.elasticsearch.index.shard.IndexShardRecoveringException
class IndexShardRecoveringException extends IllegalIndexShardStateException implements Serializable -
Exception Class org.elasticsearch.index.shard.IndexShardRecoveryException
class IndexShardRecoveryException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.index.shard.IndexShardRelocatedException
class IndexShardRelocatedException extends IllegalIndexShardStateException implements Serializable -
Exception Class org.elasticsearch.index.shard.IndexShardStartedException
class IndexShardStartedException extends IllegalIndexShardStateException implements Serializable -
Exception Class org.elasticsearch.index.shard.ShardNotFoundException
class ShardNotFoundException extends ResourceNotFoundException implements Serializable -
Exception Class org.elasticsearch.index.shard.ShardNotInPrimaryModeException
class ShardNotInPrimaryModeException extends IllegalIndexShardStateException implements Serializable
-
-
Package org.elasticsearch.index.store
-
Exception Class org.elasticsearch.index.store.ImmutableDirectoryException
class ImmutableDirectoryException extends IllegalArgumentException implements Serializable
-
-
Package org.elasticsearch.index.translog
-
Exception Class org.elasticsearch.index.translog.TranslogCorruptedException
class TranslogCorruptedException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.index.translog.TranslogException
class TranslogException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.index.translog.TruncatedTranslogException
class TruncatedTranslogException extends TranslogCorruptedException implements Serializable
-
-
Package org.elasticsearch.indices
-
Exception Class org.elasticsearch.indices.AliasFilterParsingException
class AliasFilterParsingException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.indices.AutoscalingMissedIndicesUpdateException
class AutoscalingMissedIndicesUpdateException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.indices.FailureIndexNotSupportedException
class FailureIndexNotSupportedException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.indices.IndexClosedException
class IndexClosedException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.indices.IndexCreationException
class IndexCreationException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.indices.IndexPrimaryShardNotAllocatedException
class IndexPrimaryShardNotAllocatedException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.indices.IndexTemplateMissingException
class IndexTemplateMissingException extends ElasticsearchException implements Serializable-
Serialized Fields
-
name
String name
-
-
-
Exception Class org.elasticsearch.indices.InvalidAliasNameException
class InvalidAliasNameException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.indices.InvalidIndexNameException
class InvalidIndexNameException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.indices.InvalidIndexTemplateException
class InvalidIndexTemplateException extends ElasticsearchException implements Serializable-
Serialized Fields
-
name
String name
-
-
-
Exception Class org.elasticsearch.indices.InvalidTypeNameException
class InvalidTypeNameException extends MapperException implements Serializable -
Exception Class org.elasticsearch.indices.TypeMissingException
class TypeMissingException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.indices.recovery
-
Exception Class org.elasticsearch.indices.recovery.DelayRecoveryException
class DelayRecoveryException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.indices.recovery.PeerRecoveryNotFound
class PeerRecoveryNotFound extends ResourceNotFoundException implements Serializable -
Exception Class org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
class RecoverFilesRecoveryException extends ElasticsearchException implements Serializable-
Serialized Fields
-
numberOfFiles
int numberOfFiles
-
totalFilesSize
ByteSizeValue totalFilesSize
-
-
-
Exception Class org.elasticsearch.indices.recovery.RecoveryCommitTooNewException
class RecoveryCommitTooNewException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.indices.recovery.RecoveryFailedException
class RecoveryFailedException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.ingest
-
Exception Class org.elasticsearch.ingest.GraphStructureException
class GraphStructureException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.ingest.IngestPipelineException
class IngestPipelineException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.ingest.IngestProcessorException
class IngestProcessorException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.injection.guice
-
Exception Class org.elasticsearch.injection.guice.ConfigurationException
class ConfigurationException extends RuntimeException implements Serializable -
Exception Class org.elasticsearch.injection.guice.CreationException
class CreationException extends RuntimeException implements Serializable-
Serialized Fields
-
messages
Collection<Message> messages
-
-
-
Exception Class org.elasticsearch.injection.guice.ProvisionException
class ProvisionException extends RuntimeException implements Serializable
-
-
Package org.elasticsearch.node
-
Exception Class org.elasticsearch.node.NodeClosedException
class NodeClosedException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.node.NodeValidationException
class NodeValidationException extends Exception implements Serializable
-
-
Package org.elasticsearch.repositories
-
Exception Class org.elasticsearch.repositories.RepositoryConflictException
class RepositoryConflictException extends RepositoryException implements Serializable -
Exception Class org.elasticsearch.repositories.RepositoryException
class RepositoryException extends ElasticsearchException implements Serializable-
Serialized Fields
-
repository
String repository
-
-
-
Exception Class org.elasticsearch.repositories.RepositoryMissingException
class RepositoryMissingException extends RepositoryException implements Serializable -
Exception Class org.elasticsearch.repositories.RepositoryVerificationException
class RepositoryVerificationException extends RepositoryException implements Serializable
-
-
Package org.elasticsearch.repositories.blobstore
-
Exception Class org.elasticsearch.repositories.blobstore.RequestedRangeNotSatisfiedException
class RequestedRangeNotSatisfiedException extends IOException implements Serializable-
Serialized Fields
-
length
long length
-
position
long position
-
resource
String resource
-
-
-
-
Package org.elasticsearch.rest
-
Exception Class org.elasticsearch.rest.ApiNotAvailableException
class ApiNotAvailableException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.rest.RestRequest.BadParameterException
class BadParameterException extends RuntimeException implements Serializable -
Exception Class org.elasticsearch.rest.RestRequest.MediaTypeHeaderException
class MediaTypeHeaderException extends RuntimeException implements Serializable
-
-
Package org.elasticsearch.script
-
Class org.elasticsearch.script.ClassPermission
class ClassPermission extends BasicPermission implements Serializable -
Exception Class org.elasticsearch.script.GeneralScriptException
class GeneralScriptException extends ElasticsearchException implements Serializable -
Class org.elasticsearch.script.ScoreAccessor
class ScoreAccessor extends Number implements Serializable-
Serialized Fields
-
scorer
org.apache.lucene.search.Scorable scorer
-
-
-
Exception Class org.elasticsearch.script.ScriptException
class ScriptException extends ElasticsearchException implements Serializable-
Serialized Fields
-
lang
String lang
-
pos
ScriptException.Position pos
-
script
String script
-
scriptStack
List<String> scriptStack
-
-
-
-
Package org.elasticsearch.search
-
Exception Class org.elasticsearch.search.SearchContextMissingException
class SearchContextMissingException extends ElasticsearchException implements Serializable-
Serialized Fields
-
contextId
ShardSearchContextId contextId
-
-
-
Exception Class org.elasticsearch.search.SearchException
class SearchException extends ElasticsearchException implements Serializable-
Serialized Fields
-
shardTarget
SearchShardTarget shardTarget
-
-
-
Exception Class org.elasticsearch.search.TooManyScrollContextsException
class TooManyScrollContextsException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.search.aggregations
-
Exception Class org.elasticsearch.search.aggregations.AggregationExecutionException
class AggregationExecutionException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.search.aggregations.AggregationExecutionException.InvalidPath
class InvalidPath extends AggregationExecutionException implements Serializable -
Exception Class org.elasticsearch.search.aggregations.AggregationInitializationException
class AggregationInitializationException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.search.aggregations.InvalidAggregationPathException
class InvalidAggregationPathException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.search.aggregations.MultiBucketConsumerService.TooManyBucketsException
class TooManyBucketsException extends AggregationExecutionException implements Serializable-
Serialized Fields
-
maxBuckets
int maxBuckets
-
-
-
Exception Class org.elasticsearch.search.aggregations.UnsupportedAggregationOnDownsampledIndex
class UnsupportedAggregationOnDownsampledIndex extends AggregationExecutionException implements Serializable
-
-
Package org.elasticsearch.search.aggregations.metrics
-
Class org.elasticsearch.search.aggregations.metrics.EmptyDoubleHdrHistogram
class EmptyDoubleHdrHistogram extends org.HdrHistogram.DoubleHistogram implements Serializable
-
-
Package org.elasticsearch.search.fetch
-
Exception Class org.elasticsearch.search.fetch.FetchPhaseExecutionException
class FetchPhaseExecutionException extends SearchException implements Serializable
-
-
Package org.elasticsearch.snapshots
-
Exception Class org.elasticsearch.snapshots.AbortedSnapshotException
class AbortedSnapshotException extends RuntimeException implements Serializable -
Exception Class org.elasticsearch.snapshots.ConcurrentSnapshotExecutionException
class ConcurrentSnapshotExecutionException extends SnapshotException implements Serializable -
Exception Class org.elasticsearch.snapshots.InvalidSnapshotNameException
class InvalidSnapshotNameException extends SnapshotException implements Serializable -
Exception Class org.elasticsearch.snapshots.PausedSnapshotException
class PausedSnapshotException extends RuntimeException implements Serializable -
Exception Class org.elasticsearch.snapshots.SnapshotException
class SnapshotException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.snapshots.SnapshotInProgressException
class SnapshotInProgressException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.snapshots.SnapshotMissingException
class SnapshotMissingException extends SnapshotException implements Serializable -
Exception Class org.elasticsearch.snapshots.SnapshotNameAlreadyInUseException
class SnapshotNameAlreadyInUseException extends InvalidSnapshotNameException implements Serializable -
Exception Class org.elasticsearch.snapshots.SnapshotRestoreException
class SnapshotRestoreException extends SnapshotException implements Serializable -
Exception Class org.elasticsearch.snapshots.SnapshotShardFailure
class SnapshotShardFailure extends ShardOperationFailedException implements Serializable
-
-
Package org.elasticsearch.tasks
-
Exception Class org.elasticsearch.tasks.TaskCancelledException
class TaskCancelledException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.transport
-
Exception Class org.elasticsearch.transport.ActionNotFoundTransportException
class ActionNotFoundTransportException extends TransportException implements Serializable-
Serialized Fields
-
action
String action
-
-
-
Exception Class org.elasticsearch.transport.ActionTransportException
class ActionTransportException extends TransportException implements Serializable -
Exception Class org.elasticsearch.transport.BindTransportException
class BindTransportException extends TransportException implements Serializable -
Exception Class org.elasticsearch.transport.ConnectTransportException
class ConnectTransportException extends ActionTransportException implements Serializable -
Exception Class org.elasticsearch.transport.HeaderValidationException
class HeaderValidationException extends RuntimeException implements Serializable -
Exception Class org.elasticsearch.transport.NodeDisconnectedException
class NodeDisconnectedException extends ConnectTransportException implements Serializable -
Exception Class org.elasticsearch.transport.NodeNotConnectedException
class NodeNotConnectedException extends ConnectTransportException implements Serializable -
Exception Class org.elasticsearch.transport.NoSeedNodeLeftException
class NoSeedNodeLeftException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.transport.NoSuchRemoteClusterException
class NoSuchRemoteClusterException extends ResourceNotFoundException implements Serializable -
Exception Class org.elasticsearch.transport.NotSerializableTransportException
class NotSerializableTransportException extends TransportException implements Serializable -
Exception Class org.elasticsearch.transport.ReceiveTimeoutTransportException
class ReceiveTimeoutTransportException extends ActionTransportException implements Serializable -
Exception Class org.elasticsearch.transport.RemoteTransportException
class RemoteTransportException extends ActionTransportException implements Serializable -
Exception Class org.elasticsearch.transport.ResponseHandlerFailureTransportException
class ResponseHandlerFailureTransportException extends TransportException implements Serializable -
Exception Class org.elasticsearch.transport.SendRequestTransportException
class SendRequestTransportException extends ActionTransportException implements Serializable -
Exception Class org.elasticsearch.transport.TcpTransport.HttpRequestOnTransportException
class HttpRequestOnTransportException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.transport.TransportException
class TransportException extends ElasticsearchException implements Serializable -
Exception Class org.elasticsearch.transport.TransportNotReadyException
class TransportNotReadyException extends RuntimeException implements Serializable -
Exception Class org.elasticsearch.transport.TransportSerializationException
class TransportSerializationException extends TransportException implements Serializable
-