Serialized Form
-
Package org.elasticsearch
-
Exception org.elasticsearch.ElasticsearchAuthenticationProcessingError
class ElasticsearchAuthenticationProcessingError extends ElasticsearchSecurityException implements Serializable -
Exception org.elasticsearch.ElasticsearchCorruptionException
class ElasticsearchCorruptionException extends IOException implements Serializable -
Exception org.elasticsearch.ElasticsearchException
class ElasticsearchException extends RuntimeException implements Serializable -
Exception org.elasticsearch.ElasticsearchGenerationException
class ElasticsearchGenerationException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.ElasticsearchParseException
class ElasticsearchParseException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.ElasticsearchRoleRestrictionException
class ElasticsearchRoleRestrictionException extends ElasticsearchSecurityException implements Serializable -
Exception org.elasticsearch.ElasticsearchSecurityException
class ElasticsearchSecurityException extends ElasticsearchStatusException implements Serializable -
Exception org.elasticsearch.ElasticsearchStatusException
class ElasticsearchStatusException extends ElasticsearchException implements Serializable-
Serialized Fields
-
status
RestStatus status
-
-
-
Exception org.elasticsearch.ElasticsearchTimeoutException
class ElasticsearchTimeoutException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.ResourceAlreadyExistsException
class ResourceAlreadyExistsException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.ResourceNotFoundException
class ResourceNotFoundException extends ElasticsearchException implements Serializable -
Class org.elasticsearch.SpecialPermission
class SpecialPermission extends BasicPermission implements Serializable
-
-
Package org.elasticsearch.action
-
Exception org.elasticsearch.action.ActionRequestValidationException
class ActionRequestValidationException extends ValidationException implements Serializable -
Exception org.elasticsearch.action.FailedNodeException
class FailedNodeException extends ElasticsearchException implements Serializable-
Serialized Fields
-
nodeId
String nodeId
-
-
-
Exception org.elasticsearch.action.NoShardAvailableActionException
class NoShardAvailableActionException extends ElasticsearchException implements Serializable-
Serialized Fields
-
onShardFailureWrapper
boolean onShardFailureWrapper
-
-
-
Exception org.elasticsearch.action.NoSuchNodeException
class NoSuchNodeException extends FailedNodeException implements Serializable -
Exception org.elasticsearch.action.PrimaryMissingActionException
class PrimaryMissingActionException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.action.RoutingMissingException
class RoutingMissingException extends ElasticsearchException implements Serializable-
Serialized Fields
-
id
String id
-
-
-
Exception 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 org.elasticsearch.action.TimestampParsingException
class TimestampParsingException extends ElasticsearchException implements Serializable-
Serialized Fields
-
timestamp
String timestamp
-
-
-
-
Package org.elasticsearch.action.admin.indices.close
-
Exception org.elasticsearch.action.admin.indices.close.CloseIndexResponse.ShardResult.Failure
class Failure extends DefaultShardOperationFailedException implements Serializable-
Serialized Fields
-
nodeId
String nodeId
-
-
-
-
Package org.elasticsearch.action.admin.indices.readonly
-
Exception org.elasticsearch.action.admin.indices.readonly.AddIndexBlockResponse.AddBlockShardResult.Failure
class Failure extends DefaultShardOperationFailedException implements Serializable-
Serialized Fields
-
nodeId
String nodeId
-
-
-
-
Package org.elasticsearch.action.admin.indices.shards
-
Exception org.elasticsearch.action.admin.indices.shards.IndicesShardStoresResponse.Failure
class Failure extends DefaultShardOperationFailedException implements Serializable-
Serialized Fields
-
nodeId
String nodeId
-
-
-
-
Package org.elasticsearch.action.search
-
Exception org.elasticsearch.action.search.ReduceSearchPhaseException
class ReduceSearchPhaseException extends SearchPhaseExecutionException implements Serializable -
Exception org.elasticsearch.action.search.SearchPhaseExecutionException
class SearchPhaseExecutionException extends ElasticsearchException implements Serializable-
Serialized Fields
-
phaseName
String phaseName
-
shardFailures
ShardSearchFailure[] shardFailures
-
-
-
Exception org.elasticsearch.action.search.ShardSearchFailure
class ShardSearchFailure extends ShardOperationFailedException implements Serializable-
Serialized Fields
-
shardTarget
SearchShardTarget shardTarget
-
-
-
Exception org.elasticsearch.action.search.VersionMismatchException
class VersionMismatchException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.action.support
-
Exception org.elasticsearch.action.support.DefaultShardOperationFailedException
class DefaultShardOperationFailedException extends ShardOperationFailedException implements Serializable
-
-
Package org.elasticsearch.action.support.broadcast
-
Exception org.elasticsearch.action.support.broadcast.BroadcastShardOperationFailedException
class BroadcastShardOperationFailedException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.action.support.replication
-
Exception org.elasticsearch.action.support.replication.ReplicationOperation.RetryOnPrimaryException
class RetryOnPrimaryException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure
class Failure extends ShardOperationFailedException implements Serializable -
Exception org.elasticsearch.action.support.replication.TransportReplicationAction.RetryOnReplicaException
class RetryOnReplicaException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.bootstrap
-
Class org.elasticsearch.bootstrap.JNAKernel32Library.SizeT
class SizeT extends com.sun.jna.IntegerType implements Serializable -
Exception org.elasticsearch.bootstrap.StartupException
class StartupException extends Exception implements Serializable
-
-
Package org.elasticsearch.client.internal.transport
-
Exception org.elasticsearch.client.internal.transport.NoNodeAvailableException
class NoNodeAvailableException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.cluster
-
Exception org.elasticsearch.cluster.IncompatibleClusterStateVersionException
class IncompatibleClusterStateVersionException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.cluster.NotMasterException
class NotMasterException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.cluster.action.shard
-
Exception org.elasticsearch.cluster.action.shard.ShardStateAction.NoLongerPrimaryShardException
class NoLongerPrimaryShardException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.cluster.block
-
Exception org.elasticsearch.cluster.block.ClusterBlockException
class ClusterBlockException extends ElasticsearchException implements Serializable-
Serialized Fields
-
blocks
Set<ClusterBlock> blocks
-
-
-
-
Package org.elasticsearch.cluster.coordination
-
Exception org.elasticsearch.cluster.coordination.CoordinationStateRejectedException
class CoordinationStateRejectedException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.cluster.coordination.FailedToCommitClusterStateException
class FailedToCommitClusterStateException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.cluster.coordination.NodeHealthCheckFailureException
class NodeHealthCheckFailureException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.cluster.desirednodes
-
Exception org.elasticsearch.cluster.desirednodes.VersionConflictException
class VersionConflictException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.cluster.metadata
-
Exception org.elasticsearch.cluster.metadata.ProcessClusterEventTimeoutException
class ProcessClusterEventTimeoutException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.cluster.routing
-
Exception org.elasticsearch.cluster.routing.IllegalShardRoutingStateException
class IllegalShardRoutingStateException extends RoutingException implements Serializable-
Serialized Fields
-
shard
ShardRouting shard
-
-
-
Exception org.elasticsearch.cluster.routing.RoutingException
class RoutingException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.common
-
Exception org.elasticsearch.common.ParsingException
class ParsingException extends ElasticsearchException implements Serializable-
Serialized Fields
-
columnNumber
int columnNumber
-
lineNumber
int lineNumber
-
-
-
Exception org.elasticsearch.common.ValidationException
class ValidationException extends IllegalArgumentException implements Serializable
-
-
Package org.elasticsearch.common.blobstore
-
Exception org.elasticsearch.common.blobstore.BlobStoreException
class BlobStoreException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.common.breaker
-
Exception 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.compress
-
Exception org.elasticsearch.common.compress.NotCompressedException
class NotCompressedException extends RuntimeException implements Serializable -
Exception org.elasticsearch.common.compress.NotXContentException
class NotXContentException extends RuntimeException implements Serializable
-
-
Package org.elasticsearch.common.inject
-
Exception org.elasticsearch.common.inject.ConfigurationException
class ConfigurationException extends RuntimeException implements Serializable -
Exception org.elasticsearch.common.inject.CreationException
class CreationException extends RuntimeException implements Serializable-
Serialized Fields
-
messages
Collection<Message> messages
-
-
-
Exception org.elasticsearch.common.inject.ProvisionException
class ProvisionException extends RuntimeException implements Serializable
-
-
Package org.elasticsearch.common.inject.internal
-
Exception org.elasticsearch.common.inject.internal.ErrorsException
class ErrorsException extends Exception implements Serializable-
Serialized Fields
-
errors
Errors errors
-
-
-
-
Package org.elasticsearch.common.io.stream
-
Exception org.elasticsearch.common.io.stream.NotSerializableExceptionWrapper
class NotSerializableExceptionWrapper extends ElasticsearchException implements Serializable-
Serialized Fields
-
name
String name
-
status
RestStatus status
-
-
-
-
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.settings
-
Exception org.elasticsearch.common.settings.NoClassSettingsException
class NoClassSettingsException extends SettingsException implements Serializable -
Exception org.elasticsearch.common.settings.SettingsException
class SettingsException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.common.util
-
Exception 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 org.elasticsearch.common.util.concurrent.EsRejectedExecutionException
class EsRejectedExecutionException extends RejectedExecutionException implements Serializable-
Serialized Fields
-
isExecutorShutdown
boolean isExecutorShutdown
-
-
-
Exception org.elasticsearch.common.util.concurrent.UncategorizedExecutionException
class UncategorizedExecutionException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.discovery
-
Exception org.elasticsearch.discovery.MasterNotDiscoveredException
class MasterNotDiscoveredException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.env
-
Exception org.elasticsearch.env.ShardLockObtainFailedException
class ShardLockObtainFailedException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.gateway
-
Exception org.elasticsearch.gateway.CorruptStateException
class CorruptStateException extends ElasticsearchCorruptionException implements Serializable -
Exception org.elasticsearch.gateway.WriteStateException
class WriteStateException extends IOException implements Serializable-
Serialized Fields
-
dirty
boolean dirty
-
-
-
-
Package org.elasticsearch.health.node.action
-
Exception org.elasticsearch.health.node.action.HealthNodeNotDiscoveredException
class HealthNodeNotDiscoveredException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.http
-
Exception org.elasticsearch.http.BindHttpException
class BindHttpException extends HttpException implements Serializable -
Exception org.elasticsearch.http.HttpException
class HttpException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.http.HttpHeadersValidationException
class HttpHeadersValidationException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.http.HttpReadTimeoutException
class HttpReadTimeoutException extends RuntimeException implements Serializable
-
-
Package org.elasticsearch.index
-
Exception org.elasticsearch.index.IndexNotFoundException
class IndexNotFoundException extends ResourceNotFoundException implements Serializable
-
-
Package org.elasticsearch.index.engine
-
Exception org.elasticsearch.index.engine.DocumentMissingException
class DocumentMissingException extends EngineException implements Serializable -
Exception org.elasticsearch.index.engine.DocumentSourceMissingException
class DocumentSourceMissingException extends EngineException implements Serializable -
Exception org.elasticsearch.index.engine.EngineCreationFailureException
class EngineCreationFailureException extends EngineException implements Serializable -
Exception org.elasticsearch.index.engine.EngineException
class EngineException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.index.engine.FlushFailedEngineException
class FlushFailedEngineException extends EngineException implements Serializable -
Exception org.elasticsearch.index.engine.MissingHistoryOperationsException
class MissingHistoryOperationsException extends IllegalStateException implements Serializable -
Exception org.elasticsearch.index.engine.RecoveryEngineException
class RecoveryEngineException extends EngineException implements Serializable-
Serialized Fields
-
phase
int phase
-
-
-
Exception org.elasticsearch.index.engine.RefreshFailedEngineException
class RefreshFailedEngineException extends EngineException implements Serializable -
Exception org.elasticsearch.index.engine.VersionConflictEngineException
class VersionConflictEngineException extends EngineException implements Serializable
-
-
Package org.elasticsearch.index.mapper
-
Exception org.elasticsearch.index.mapper.DocumentParsingException
class DocumentParsingException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.index.mapper.MapperException
class MapperException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.index.mapper.MapperParsingException
class MapperParsingException extends MapperException implements Serializable -
Exception org.elasticsearch.index.mapper.StrictDynamicMappingException
class StrictDynamicMappingException extends DocumentParsingException implements Serializable
-
-
Package org.elasticsearch.index.query
-
Exception org.elasticsearch.index.query.QueryShardException
class QueryShardException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.index.query.QueryValidationException
class QueryValidationException extends ValidationException implements Serializable
-
-
Package org.elasticsearch.index.seqno
-
Exception org.elasticsearch.index.seqno.RetentionLeaseAlreadyExistsException
class RetentionLeaseAlreadyExistsException extends ResourceAlreadyExistsException implements Serializable -
Exception org.elasticsearch.index.seqno.RetentionLeaseInvalidRetainingSeqNoException
class RetentionLeaseInvalidRetainingSeqNoException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.index.seqno.RetentionLeaseNotFoundException
class RetentionLeaseNotFoundException extends ResourceNotFoundException implements Serializable
-
-
Package org.elasticsearch.index.shard
-
Exception org.elasticsearch.index.shard.IllegalIndexShardStateException
class IllegalIndexShardStateException extends ElasticsearchException implements Serializable-
Serialized Fields
-
currentState
IndexShardState currentState
-
-
-
Exception org.elasticsearch.index.shard.IndexShardClosedException
class IndexShardClosedException extends IllegalIndexShardStateException implements Serializable -
Exception org.elasticsearch.index.shard.IndexShardNotRecoveringException
class IndexShardNotRecoveringException extends IllegalIndexShardStateException implements Serializable -
Exception org.elasticsearch.index.shard.IndexShardNotStartedException
class IndexShardNotStartedException extends IllegalIndexShardStateException implements Serializable -
Exception org.elasticsearch.index.shard.IndexShardRecoveringException
class IndexShardRecoveringException extends IllegalIndexShardStateException implements Serializable -
Exception org.elasticsearch.index.shard.IndexShardRecoveryException
class IndexShardRecoveryException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.index.shard.IndexShardRelocatedException
class IndexShardRelocatedException extends IllegalIndexShardStateException implements Serializable -
Exception org.elasticsearch.index.shard.IndexShardStartedException
class IndexShardStartedException extends IllegalIndexShardStateException implements Serializable -
Exception org.elasticsearch.index.shard.ShardNotFoundException
class ShardNotFoundException extends ResourceNotFoundException implements Serializable -
Exception org.elasticsearch.index.shard.ShardNotInPrimaryModeException
class ShardNotInPrimaryModeException extends IllegalIndexShardStateException implements Serializable
-
-
Package org.elasticsearch.index.snapshots
-
Exception org.elasticsearch.index.snapshots.IndexShardRestoreException
class IndexShardRestoreException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.index.snapshots.IndexShardRestoreFailedException
class IndexShardRestoreFailedException extends IndexShardRestoreException implements Serializable -
Exception org.elasticsearch.index.snapshots.IndexShardSnapshotException
class IndexShardSnapshotException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.index.snapshots.IndexShardSnapshotFailedException
class IndexShardSnapshotFailedException extends IndexShardSnapshotException implements Serializable
-
-
Package org.elasticsearch.index.store
-
Exception org.elasticsearch.index.store.ImmutableDirectoryException
class ImmutableDirectoryException extends IllegalArgumentException implements Serializable
-
-
Package org.elasticsearch.index.translog
-
Exception org.elasticsearch.index.translog.TranslogCorruptedException
class TranslogCorruptedException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.index.translog.TranslogException
class TranslogException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.index.translog.TruncatedTranslogException
class TruncatedTranslogException extends TranslogCorruptedException implements Serializable
-
-
Package org.elasticsearch.indices
-
Exception org.elasticsearch.indices.AliasFilterParsingException
class AliasFilterParsingException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.indices.AutoscalingMissedIndicesUpdateException
class AutoscalingMissedIndicesUpdateException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.indices.FailureIndexNotSupportedException
class FailureIndexNotSupportedException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.indices.IndexClosedException
class IndexClosedException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.indices.IndexCreationException
class IndexCreationException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.indices.IndexPrimaryShardNotAllocatedException
class IndexPrimaryShardNotAllocatedException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.indices.IndexTemplateMissingException
class IndexTemplateMissingException extends ElasticsearchException implements Serializable-
Serialized Fields
-
name
String name
-
-
-
Exception org.elasticsearch.indices.InvalidAliasNameException
class InvalidAliasNameException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.indices.InvalidIndexNameException
class InvalidIndexNameException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.indices.InvalidIndexTemplateException
class InvalidIndexTemplateException extends ElasticsearchException implements Serializable-
Serialized Fields
-
name
String name
-
-
-
Exception org.elasticsearch.indices.InvalidTypeNameException
class InvalidTypeNameException extends MapperException implements Serializable -
Exception org.elasticsearch.indices.TypeMissingException
class TypeMissingException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.indices.recovery
-
Exception org.elasticsearch.indices.recovery.DelayRecoveryException
class DelayRecoveryException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.indices.recovery.PeerRecoveryNotFound
class PeerRecoveryNotFound extends ResourceNotFoundException implements Serializable -
Exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException
class RecoverFilesRecoveryException extends ElasticsearchException implements Serializable-
Serialized Fields
-
numberOfFiles
int numberOfFiles
-
totalFilesSize
ByteSizeValue totalFilesSize
-
-
-
Exception org.elasticsearch.indices.recovery.RecoveryCommitTooNewException
class RecoveryCommitTooNewException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.indices.recovery.RecoveryFailedException
class RecoveryFailedException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.ingest
-
Exception org.elasticsearch.ingest.GraphStructureException
class GraphStructureException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.ingest.IngestProcessorException
class IngestProcessorException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.node
-
Exception org.elasticsearch.node.NodeClosedException
class NodeClosedException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.node.NodeValidationException
class NodeValidationException extends Exception implements Serializable
-
-
Package org.elasticsearch.persistent
-
Exception org.elasticsearch.persistent.NotPersistentTaskNodeException
class NotPersistentTaskNodeException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.persistent.PersistentTaskNodeNotAssignedException
class PersistentTaskNodeNotAssignedException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.repositories
-
Exception org.elasticsearch.repositories.RepositoryConflictException
class RepositoryConflictException extends RepositoryException implements Serializable-
Serialized Fields
-
backwardCompatibleMessage
String backwardCompatibleMessage
-
-
-
Exception org.elasticsearch.repositories.RepositoryException
class RepositoryException extends ElasticsearchException implements Serializable-
Serialized Fields
-
repository
String repository
-
-
-
Exception org.elasticsearch.repositories.RepositoryMissingException
class RepositoryMissingException extends RepositoryException implements Serializable -
Exception org.elasticsearch.repositories.RepositoryVerificationException
class RepositoryVerificationException extends RepositoryException implements Serializable
-
-
Package org.elasticsearch.repositories.blobstore
-
Exception 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 org.elasticsearch.rest.ApiNotAvailableException
class ApiNotAvailableException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.rest.RestRequest.BadParameterException
class BadParameterException extends RuntimeException implements Serializable -
Exception org.elasticsearch.rest.RestRequest.MediaTypeHeaderException
class MediaTypeHeaderException extends RuntimeException implements Serializable
-
-
Package org.elasticsearch.rest.action.admin.indices
-
Exception org.elasticsearch.rest.action.admin.indices.AliasesNotFoundException
class AliasesNotFoundException extends ResourceNotFoundException implements Serializable -
Exception org.elasticsearch.rest.action.admin.indices.RestUpgradeActionDeprecated.UpgradeActionDeprecatedException
class UpgradeActionDeprecatedException extends IllegalArgumentException implements Serializable-
Serialized Fields
-
method
RestRequest.Method method
-
path
String path
-
-
-
-
Package org.elasticsearch.script
-
Class org.elasticsearch.script.ClassPermission
class ClassPermission extends BasicPermission implements Serializable -
Exception org.elasticsearch.script.GeneralScriptException
class GeneralScriptException extends ElasticsearchException implements Serializable -
Exception 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 org.elasticsearch.search.SearchContextMissingException
class SearchContextMissingException extends ElasticsearchException implements Serializable-
Serialized Fields
-
contextId
ShardSearchContextId contextId
-
-
-
Exception org.elasticsearch.search.SearchException
class SearchException extends ElasticsearchException implements Serializable-
Serialized Fields
-
shardTarget
SearchShardTarget shardTarget
-
-
-
Exception org.elasticsearch.search.TooManyScrollContextsException
class TooManyScrollContextsException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.search.aggregations
-
Exception org.elasticsearch.search.aggregations.AggregationExecutionException
class AggregationExecutionException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.search.aggregations.AggregationExecutionException.InvalidPath
class InvalidPath extends AggregationExecutionException implements Serializable -
Exception org.elasticsearch.search.aggregations.AggregationInitializationException
class AggregationInitializationException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.search.aggregations.InvalidAggregationPathException
class InvalidAggregationPathException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.search.aggregations.MultiBucketConsumerService.TooManyBucketsException
class TooManyBucketsException extends AggregationExecutionException implements Serializable-
Serialized Fields
-
maxBuckets
int maxBuckets
-
-
-
Exception org.elasticsearch.search.aggregations.UnsupportedAggregationOnDownsampledIndex
class UnsupportedAggregationOnDownsampledIndex extends AggregationExecutionException implements Serializable
-
-
Package org.elasticsearch.search.aggregations.bucket.terms.heuristic
-
Class org.elasticsearch.search.aggregations.bucket.terms.heuristic.ScriptHeuristic.LongAccessor
class LongAccessor extends Number implements Serializable-
Serialized Fields
-
value
long value
-
-
-
-
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.builder
-
Exception org.elasticsearch.search.builder.SearchSourceBuilderException
class SearchSourceBuilderException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.search.dfs
-
Exception org.elasticsearch.search.dfs.DfsPhaseExecutionException
class DfsPhaseExecutionException extends SearchException implements Serializable
-
-
Package org.elasticsearch.search.fetch
-
Exception org.elasticsearch.search.fetch.FetchPhaseExecutionException
class FetchPhaseExecutionException extends SearchException implements Serializable
-
-
Package org.elasticsearch.search.query
-
Exception org.elasticsearch.search.query.QueryPhaseExecutionException
class QueryPhaseExecutionException extends SearchException implements Serializable -
Exception org.elasticsearch.search.query.SearchTimeoutException
class SearchTimeoutException extends SearchException implements Serializable
-
-
Package org.elasticsearch.snapshots
-
Exception org.elasticsearch.snapshots.AbortedSnapshotException
class AbortedSnapshotException extends RuntimeException implements Serializable -
Exception org.elasticsearch.snapshots.ConcurrentSnapshotExecutionException
class ConcurrentSnapshotExecutionException extends SnapshotException implements Serializable -
Exception org.elasticsearch.snapshots.InvalidSnapshotNameException
class InvalidSnapshotNameException extends SnapshotException implements Serializable -
Exception org.elasticsearch.snapshots.PausedSnapshotException
class PausedSnapshotException extends RuntimeException implements Serializable -
Exception org.elasticsearch.snapshots.SnapshotException
class SnapshotException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.snapshots.SnapshotInProgressException
class SnapshotInProgressException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.snapshots.SnapshotMissingException
class SnapshotMissingException extends SnapshotException implements Serializable -
Exception org.elasticsearch.snapshots.SnapshotNameAlreadyInUseException
class SnapshotNameAlreadyInUseException extends InvalidSnapshotNameException implements Serializable -
Exception org.elasticsearch.snapshots.SnapshotRestoreException
class SnapshotRestoreException extends SnapshotException implements Serializable -
Exception org.elasticsearch.snapshots.SnapshotShardFailure
class SnapshotShardFailure extends ShardOperationFailedException implements Serializable
-
-
Package org.elasticsearch.tasks
-
Exception org.elasticsearch.tasks.TaskCancelledException
class TaskCancelledException extends ElasticsearchException implements Serializable
-
-
Package org.elasticsearch.transport
-
Exception org.elasticsearch.transport.ActionNotFoundTransportException
class ActionNotFoundTransportException extends TransportException implements Serializable-
Serialized Fields
-
action
String action
-
-
-
Exception org.elasticsearch.transport.ActionTransportException
class ActionTransportException extends TransportException implements Serializable -
Exception org.elasticsearch.transport.BindTransportException
class BindTransportException extends TransportException implements Serializable -
Exception org.elasticsearch.transport.ConnectTransportException
class ConnectTransportException extends ActionTransportException implements Serializable -
Exception org.elasticsearch.transport.HeaderValidationException
class HeaderValidationException extends RuntimeException implements Serializable -
Exception org.elasticsearch.transport.NodeDisconnectedException
class NodeDisconnectedException extends ConnectTransportException implements Serializable -
Exception org.elasticsearch.transport.NodeNotConnectedException
class NodeNotConnectedException extends ConnectTransportException implements Serializable -
Exception org.elasticsearch.transport.NoSeedNodeLeftException
class NoSeedNodeLeftException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.transport.NoSuchRemoteClusterException
class NoSuchRemoteClusterException extends ResourceNotFoundException implements Serializable -
Exception org.elasticsearch.transport.NotSerializableTransportException
class NotSerializableTransportException extends TransportException implements Serializable -
Exception org.elasticsearch.transport.ReceiveTimeoutTransportException
class ReceiveTimeoutTransportException extends ActionTransportException implements Serializable -
Exception org.elasticsearch.transport.RemoteTransportException
class RemoteTransportException extends ActionTransportException implements Serializable -
Exception org.elasticsearch.transport.ResponseHandlerFailureTransportException
class ResponseHandlerFailureTransportException extends TransportException implements Serializable -
Exception org.elasticsearch.transport.SendRequestTransportException
class SendRequestTransportException extends ActionTransportException implements Serializable -
Exception org.elasticsearch.transport.TcpTransport.HttpRequestOnTransportException
class HttpRequestOnTransportException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.transport.TransportException
class TransportException extends ElasticsearchException implements Serializable -
Exception org.elasticsearch.transport.TransportNotReadyException
class TransportNotReadyException extends RuntimeException implements Serializable -
Exception org.elasticsearch.transport.TransportSerializationException
class TransportSerializationException extends TransportException implements Serializable
-