Serialized Form

  • Package org.elasticsearch.action.support

    • Exception org.elasticsearch.action.support.DefaultShardOperationFailedException

      class DefaultShardOperationFailedException extends org.elasticsearch.action.ShardOperationFailedException implements Serializable
  • Package org.elasticsearch.action.support.replication

    • Exception org.elasticsearch.action.support.replication.ReplicationOperation.RetryOnPrimaryException

      class RetryOnPrimaryException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.action.support.replication.ReplicationResponse.ShardInfo.Failure

      class Failure extends org.elasticsearch.action.ShardOperationFailedException implements Serializable
      • Serialized Fields

        • nodeId
          String nodeId
        • primary
          boolean primary
        • shardId
          org.elasticsearch.index.shard.ShardId shardId
    • Exception org.elasticsearch.action.support.replication.TransportReplicationAction.RetryOnReplicaException

      class RetryOnReplicaException extends org.elasticsearch.ElasticsearchException implements Serializable
  • Package org.elasticsearch.bootstrap

    • Class org.elasticsearch.bootstrap.JNAKernel32Library.SizeT

      class SizeT extends com.sun.jna.IntegerType implements Serializable
  • Package org.elasticsearch.cli

    • Exception org.elasticsearch.cli.UserException

      class UserException extends Exception implements Serializable
      • Serialized Fields

        • exitCode
          int exitCode
  • Package org.elasticsearch.client

    • Exception org.elasticsearch.client.ResponseException

      class ResponseException extends IOException implements Serializable
      • Serialized Fields

        • response
          org.elasticsearch.client.Response response
    • Exception org.elasticsearch.client.WarningFailureException

      class WarningFailureException extends RuntimeException implements Serializable
      • Serialized Fields

        • response
          org.elasticsearch.client.Response response
  • Package org.elasticsearch.cluster

    • Exception org.elasticsearch.cluster.IncompatibleClusterStateVersionException

      class IncompatibleClusterStateVersionException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.cluster.NotMasterException

      class NotMasterException extends org.elasticsearch.ElasticsearchException implements Serializable
  • Package org.elasticsearch.cluster.coordination

    • Exception org.elasticsearch.cluster.coordination.CoordinationStateRejectedException

      class CoordinationStateRejectedException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.cluster.coordination.FailedToCommitClusterStateException

      class FailedToCommitClusterStateException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.cluster.coordination.NodeHealthCheckFailureException

      class NodeHealthCheckFailureException extends org.elasticsearch.ElasticsearchException implements Serializable
  • Package org.elasticsearch.cluster.metadata

    • Exception org.elasticsearch.cluster.metadata.ProcessClusterEventTimeoutException

      class ProcessClusterEventTimeoutException extends org.elasticsearch.ElasticsearchException implements Serializable
  • Package org.elasticsearch.cluster.routing

    • Exception org.elasticsearch.cluster.routing.IllegalShardRoutingStateException

      class IllegalShardRoutingStateException extends org.elasticsearch.cluster.routing.RoutingException implements Serializable
      • Serialized Fields

        • shard
          org.elasticsearch.cluster.routing.ShardRouting shard
    • Exception org.elasticsearch.cluster.routing.RoutingException

      class RoutingException extends org.elasticsearch.ElasticsearchException implements Serializable
  • Package org.elasticsearch.common.breaker

    • Exception org.elasticsearch.common.breaker.CircuitBreakingException

      class CircuitBreakingException extends org.elasticsearch.ElasticsearchException implements Serializable
      • Serialized Fields

        • byteLimit
          long byteLimit
        • bytesWanted
          long bytesWanted
        • durability
          org.elasticsearch.common.breaker.CircuitBreaker.Durability durability
  • Package org.elasticsearch.common.inject

    • Exception org.elasticsearch.common.inject.ConfigurationException

      class ConfigurationException extends RuntimeException implements Serializable
      • Serialized Fields

        • messages
          Set<org.elasticsearch.common.inject.spi.Message> messages
        • partialValue
          Object partialValue
    • Exception org.elasticsearch.common.inject.CreationException

      class CreationException extends RuntimeException implements Serializable
      • Serialized Fields

        • messages
          Collection<org.elasticsearch.common.inject.spi.Message> messages
    • Exception org.elasticsearch.common.inject.OutOfScopeException

      class OutOfScopeException extends RuntimeException implements Serializable
    • Exception org.elasticsearch.common.inject.ProvisionException

      class ProvisionException extends RuntimeException implements Serializable
      • Serialized Fields

        • messages
          Set<org.elasticsearch.common.inject.spi.Message> messages
  • Package org.elasticsearch.common.logging

    • Class org.elasticsearch.common.logging.ESLogMessage

      class ESLogMessage extends org.apache.logging.log4j.message.MapMessage<org.elasticsearch.common.logging.ESLogMessage,Object> implements Serializable
      • Serialized Fields

  • Package org.elasticsearch.common.settings

    • Exception org.elasticsearch.common.settings.NoClassSettingsException

      class NoClassSettingsException extends org.elasticsearch.common.settings.SettingsException implements Serializable
    • Exception org.elasticsearch.common.settings.SettingsException

      class SettingsException extends org.elasticsearch.ElasticsearchException implements Serializable
  • Package org.elasticsearch.common.util

    • Exception org.elasticsearch.common.util.CancellableThreads.ExecutionCancelledException

      class ExecutionCancelledException extends org.elasticsearch.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 org.elasticsearch.ElasticsearchException implements Serializable
  • Package org.elasticsearch.env

    • Exception org.elasticsearch.env.ShardLockObtainFailedException

      class ShardLockObtainFailedException extends org.elasticsearch.ElasticsearchException implements Serializable
  • Package org.elasticsearch.gateway

    • Exception org.elasticsearch.gateway.CorruptStateException

      class CorruptStateException extends org.elasticsearch.ElasticsearchCorruptionException implements Serializable
    • Exception org.elasticsearch.gateway.WriteStateException

      class WriteStateException extends IOException implements Serializable
      • Serialized Fields

        • dirty
          boolean dirty
  • Package org.elasticsearch.http

    • Exception org.elasticsearch.http.BindHttpException

      class BindHttpException extends org.elasticsearch.http.HttpException implements Serializable
    • Exception org.elasticsearch.http.HttpException

      class HttpException extends org.elasticsearch.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 org.elasticsearch.ResourceNotFoundException implements Serializable
  • Package org.elasticsearch.index.engine

    • Exception org.elasticsearch.index.engine.DocumentMissingException

      class DocumentMissingException extends org.elasticsearch.index.engine.EngineException implements Serializable
    • Exception org.elasticsearch.index.engine.DocumentSourceMissingException

      class DocumentSourceMissingException extends org.elasticsearch.index.engine.EngineException implements Serializable
    • Exception org.elasticsearch.index.engine.EngineCreationFailureException

      class EngineCreationFailureException extends org.elasticsearch.index.engine.EngineException implements Serializable
    • Exception org.elasticsearch.index.engine.EngineException

      class EngineException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.index.engine.FlushFailedEngineException

      class FlushFailedEngineException extends org.elasticsearch.index.engine.EngineException implements Serializable
    • Exception org.elasticsearch.index.engine.MissingHistoryOperationsException

      class MissingHistoryOperationsException extends IllegalStateException implements Serializable
    • Exception org.elasticsearch.index.engine.RecoveryEngineException

      class RecoveryEngineException extends org.elasticsearch.index.engine.EngineException implements Serializable
      • Serialized Fields

        • phase
          int phase
    • Exception org.elasticsearch.index.engine.RefreshFailedEngineException

      class RefreshFailedEngineException extends org.elasticsearch.index.engine.EngineException implements Serializable
    • Exception org.elasticsearch.index.engine.VersionConflictEngineException

      class VersionConflictEngineException extends org.elasticsearch.index.engine.EngineException implements Serializable
  • Package org.elasticsearch.index.mapper

    • Exception org.elasticsearch.index.mapper.MapperException

      class MapperException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.index.mapper.MapperParsingException

      class MapperParsingException extends org.elasticsearch.index.mapper.MapperException implements Serializable
    • Exception org.elasticsearch.index.mapper.StrictDynamicMappingException

      class StrictDynamicMappingException extends org.elasticsearch.index.mapper.MapperParsingException implements Serializable
  • Package org.elasticsearch.index.seqno

    • Exception org.elasticsearch.index.seqno.RetentionLeaseAlreadyExistsException

      class RetentionLeaseAlreadyExistsException extends org.elasticsearch.ResourceAlreadyExistsException implements Serializable
    • Exception org.elasticsearch.index.seqno.RetentionLeaseInvalidRetainingSeqNoException

      class RetentionLeaseInvalidRetainingSeqNoException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.index.seqno.RetentionLeaseNotFoundException

      class RetentionLeaseNotFoundException extends org.elasticsearch.ResourceNotFoundException implements Serializable
  • Package org.elasticsearch.index.shard

    • Exception org.elasticsearch.index.shard.IllegalIndexShardStateException

      class IllegalIndexShardStateException extends org.elasticsearch.ElasticsearchException implements Serializable
      • Serialized Fields

        • currentState
          org.elasticsearch.index.shard.IndexShardState currentState
    • Exception org.elasticsearch.index.shard.IndexShardClosedException

      class IndexShardClosedException extends org.elasticsearch.index.shard.IllegalIndexShardStateException implements Serializable
    • Exception org.elasticsearch.index.shard.IndexShardNotRecoveringException

      class IndexShardNotRecoveringException extends org.elasticsearch.index.shard.IllegalIndexShardStateException implements Serializable
    • Exception org.elasticsearch.index.shard.IndexShardNotStartedException

      class IndexShardNotStartedException extends org.elasticsearch.index.shard.IllegalIndexShardStateException implements Serializable
    • Exception org.elasticsearch.index.shard.IndexShardRecoveringException

      class IndexShardRecoveringException extends org.elasticsearch.index.shard.IllegalIndexShardStateException implements Serializable
    • Exception org.elasticsearch.index.shard.IndexShardRecoveryException

      class IndexShardRecoveryException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.index.shard.IndexShardRelocatedException

      class IndexShardRelocatedException extends org.elasticsearch.index.shard.IllegalIndexShardStateException implements Serializable
    • Exception org.elasticsearch.index.shard.IndexShardStartedException

      class IndexShardStartedException extends org.elasticsearch.index.shard.IllegalIndexShardStateException implements Serializable
    • Exception org.elasticsearch.index.shard.ShardNotFoundException

      class ShardNotFoundException extends org.elasticsearch.ResourceNotFoundException implements Serializable
    • Exception org.elasticsearch.index.shard.ShardNotInPrimaryModeException

      class ShardNotInPrimaryModeException extends org.elasticsearch.index.shard.IllegalIndexShardStateException implements Serializable
  • Package org.elasticsearch.index.store

  • Package org.elasticsearch.indices

    • Exception org.elasticsearch.indices.AliasFilterParsingException

      class AliasFilterParsingException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.indices.IndexClosedException

      class IndexClosedException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.indices.IndexCreationException

      class IndexCreationException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.indices.IndexPrimaryShardNotAllocatedException

      class IndexPrimaryShardNotAllocatedException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.indices.IndexTemplateMissingException

      class IndexTemplateMissingException extends org.elasticsearch.ElasticsearchException implements Serializable
      • Serialized Fields

    • Exception org.elasticsearch.indices.InvalidAliasNameException

      class InvalidAliasNameException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.indices.InvalidIndexNameException

      class InvalidIndexNameException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.indices.InvalidIndexTemplateException

      class InvalidIndexTemplateException extends org.elasticsearch.ElasticsearchException implements Serializable
      • Serialized Fields

    • Exception org.elasticsearch.indices.InvalidTypeNameException

      class InvalidTypeNameException extends org.elasticsearch.index.mapper.MapperException implements Serializable
    • Exception org.elasticsearch.indices.TypeMissingException

      class TypeMissingException extends org.elasticsearch.ElasticsearchException implements Serializable
  • Package org.elasticsearch.indices.recovery

    • Exception org.elasticsearch.indices.recovery.DelayRecoveryException

      class DelayRecoveryException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.indices.recovery.PeerRecoveryNotFound

      class PeerRecoveryNotFound extends org.elasticsearch.ResourceNotFoundException implements Serializable
    • Exception org.elasticsearch.indices.recovery.RecoverFilesRecoveryException

      class RecoverFilesRecoveryException extends org.elasticsearch.ElasticsearchException implements Serializable
      • Serialized Fields

        • numberOfFiles
          int numberOfFiles
        • totalFilesSize
          org.elasticsearch.common.unit.ByteSizeValue totalFilesSize
    • Exception org.elasticsearch.indices.recovery.RecoveryFailedException

      class RecoveryFailedException extends org.elasticsearch.ElasticsearchException implements Serializable
  • Package org.elasticsearch.ingest

    • Exception org.elasticsearch.ingest.IngestProcessorException

      class IngestProcessorException extends org.elasticsearch.ElasticsearchException implements Serializable
  • Package org.elasticsearch.node

    • Exception org.elasticsearch.node.NodeClosedException

      class NodeClosedException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.node.NodeValidationException

      class NodeValidationException extends Exception implements Serializable
  • Package org.elasticsearch.repositories

    • Exception org.elasticsearch.repositories.RepositoryConflictException

      class RepositoryConflictException extends org.elasticsearch.repositories.RepositoryException implements Serializable
      • Serialized Fields

        • backwardCompatibleMessage
          String backwardCompatibleMessage
    • Exception org.elasticsearch.repositories.RepositoryException

      class RepositoryException extends org.elasticsearch.ElasticsearchException implements Serializable
      • Serialized Fields

        • repository
          String repository
    • Exception org.elasticsearch.repositories.RepositoryMissingException

      class RepositoryMissingException extends org.elasticsearch.repositories.RepositoryException implements Serializable
    • Exception org.elasticsearch.repositories.RepositoryVerificationException

      class RepositoryVerificationException extends org.elasticsearch.repositories.RepositoryException implements Serializable
  • Package org.elasticsearch.script

    • Class org.elasticsearch.script.ClassPermission

      class ClassPermission extends BasicPermission implements Serializable
    • Exception org.elasticsearch.script.GeneralScriptException

      class GeneralScriptException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Class org.elasticsearch.script.ScoreAccessor

      class ScoreAccessor extends Number implements Serializable
      • Serialized Fields

        • scorer
          org.apache.lucene.search.Scorable scorer
    • Exception org.elasticsearch.script.ScriptException

      class ScriptException extends org.elasticsearch.ElasticsearchException implements Serializable
      • Serialized Fields

        • lang
          String lang
        • pos
          org.elasticsearch.script.ScriptException.Position pos
        • script
          String script
        • scriptStack
          List<String> scriptStack
  • Package org.elasticsearch.search

    • Exception org.elasticsearch.search.SearchContextMissingException

      class SearchContextMissingException extends org.elasticsearch.ElasticsearchException implements Serializable
      • Serialized Fields

        • contextId
          org.elasticsearch.search.internal.ShardSearchContextId contextId
    • Exception org.elasticsearch.search.SearchException

      class SearchException extends org.elasticsearch.ElasticsearchException implements Serializable
      • Serialized Fields

        • shardTarget
          org.elasticsearch.search.SearchShardTarget shardTarget
    • Exception org.elasticsearch.search.SearchParseException

      class SearchParseException extends org.elasticsearch.search.SearchException implements Serializable
      • Serialized Fields

        • columnNumber
          int columnNumber
        • lineNumber
          int lineNumber
  • Package org.elasticsearch.search.aggregations

    • Exception org.elasticsearch.search.aggregations.AggregationExecutionException

      class AggregationExecutionException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.search.aggregations.AggregationInitializationException

      class AggregationInitializationException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.search.aggregations.InvalidAggregationPathException

      class InvalidAggregationPathException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.search.aggregations.MultiBucketConsumerService.TooManyBucketsException

      class TooManyBucketsException extends org.elasticsearch.search.aggregations.AggregationExecutionException implements Serializable
      • Serialized Fields

        • maxBuckets
          int maxBuckets
  • Package org.elasticsearch.search.aggregations.metrics

    • Class org.elasticsearch.search.aggregations.metrics.TDigestState

      class TDigestState extends com.tdunning.math.stats.AVLTreeDigest implements Serializable
      • Serialized Fields

        • compression
          double compression
  • Package org.elasticsearch.snapshots

    • Exception org.elasticsearch.snapshots.AbortedSnapshotException

      class AbortedSnapshotException extends RuntimeException implements Serializable
    • Exception org.elasticsearch.snapshots.ConcurrentSnapshotExecutionException

      class ConcurrentSnapshotExecutionException extends org.elasticsearch.snapshots.SnapshotException implements Serializable
    • Exception org.elasticsearch.snapshots.InvalidSnapshotNameException

      class InvalidSnapshotNameException extends org.elasticsearch.snapshots.SnapshotException implements Serializable
    • Exception org.elasticsearch.snapshots.SnapshotCreationException

      class SnapshotCreationException extends org.elasticsearch.snapshots.SnapshotException implements Serializable
    • Exception org.elasticsearch.snapshots.SnapshotException

      class SnapshotException extends org.elasticsearch.ElasticsearchException implements Serializable
      • Serialized Fields

        • repositoryName
          String repositoryName
        • snapshotName
          String snapshotName
    • Exception org.elasticsearch.snapshots.SnapshotInProgressException

      class SnapshotInProgressException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.snapshots.SnapshotMissingException

      class SnapshotMissingException extends org.elasticsearch.snapshots.SnapshotException implements Serializable
    • Exception org.elasticsearch.snapshots.SnapshotRestoreException

      class SnapshotRestoreException extends org.elasticsearch.snapshots.SnapshotException implements Serializable
    • Exception org.elasticsearch.snapshots.SnapshotShardFailure

      class SnapshotShardFailure extends org.elasticsearch.action.ShardOperationFailedException implements Serializable
      • Serialized Fields

        • nodeId
          String nodeId
        • shardId
          org.elasticsearch.index.shard.ShardId shardId
  • Package org.elasticsearch.tasks

    • Exception org.elasticsearch.tasks.TaskCancelledException

      class TaskCancelledException extends org.elasticsearch.ElasticsearchException implements Serializable
  • Package org.elasticsearch.test.rest.yaml

  • Package org.elasticsearch.transport

    • Exception org.elasticsearch.transport.ActionNotFoundTransportException

      class ActionNotFoundTransportException extends org.elasticsearch.transport.TransportException implements Serializable
      • Serialized Fields

    • Exception org.elasticsearch.transport.ActionTransportException

      class ActionTransportException extends org.elasticsearch.transport.TransportException implements Serializable
    • Exception org.elasticsearch.transport.BindTransportException

      class BindTransportException extends org.elasticsearch.transport.TransportException implements Serializable
    • Exception org.elasticsearch.transport.ConnectTransportException

      class ConnectTransportException extends org.elasticsearch.transport.ActionTransportException implements Serializable
    • Exception org.elasticsearch.transport.NodeDisconnectedException

      class NodeDisconnectedException extends org.elasticsearch.transport.ConnectTransportException implements Serializable
    • Exception org.elasticsearch.transport.NodeNotConnectedException

      class NodeNotConnectedException extends org.elasticsearch.transport.ConnectTransportException implements Serializable
    • Exception org.elasticsearch.transport.NoSeedNodeLeftException

      class NoSeedNodeLeftException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.transport.NoSuchRemoteClusterException

      class NoSuchRemoteClusterException extends org.elasticsearch.ResourceNotFoundException implements Serializable
    • Exception org.elasticsearch.transport.NotSerializableTransportException

      class NotSerializableTransportException extends org.elasticsearch.transport.TransportException implements Serializable
    • Exception org.elasticsearch.transport.ReceiveTimeoutTransportException

      class ReceiveTimeoutTransportException extends org.elasticsearch.transport.ActionTransportException implements Serializable
    • Exception org.elasticsearch.transport.RemoteTransportException

      class RemoteTransportException extends org.elasticsearch.transport.ActionTransportException implements Serializable
    • Exception org.elasticsearch.transport.ResponseHandlerFailureTransportException

      class ResponseHandlerFailureTransportException extends org.elasticsearch.transport.TransportException implements Serializable
    • Exception org.elasticsearch.transport.SendRequestTransportException

      class SendRequestTransportException extends org.elasticsearch.transport.ActionTransportException implements Serializable
    • Exception org.elasticsearch.transport.TcpTransport.HttpRequestOnTransportException

      class HttpRequestOnTransportException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.transport.TransportException

      class TransportException extends org.elasticsearch.ElasticsearchException implements Serializable
    • Exception org.elasticsearch.transport.TransportNotReadyException

      class TransportNotReadyException extends RuntimeException implements Serializable
    • Exception org.elasticsearch.transport.TransportSerializationException

      class TransportSerializationException extends org.elasticsearch.transport.TransportException implements Serializable