Serialized Form
-
Package org.apache.hadoop.hbase
-
Exception org.apache.hadoop.hbase.CallDroppedException
class CallDroppedException extends HBaseServerException implements Serializable -
Exception org.apache.hadoop.hbase.CallQueueTooBigException
class CallQueueTooBigException extends CallDroppedException implements Serializable -
Class org.apache.hadoop.hbase.CellComparatorImpl
class CellComparatorImpl extends Object implements Serializable- serialVersionUID:
- 8186411895799094989L
-
Exception org.apache.hadoop.hbase.ClockOutOfSyncException
class ClockOutOfSyncException extends IOException implements Serializable -
Exception org.apache.hadoop.hbase.ConcurrentTableModificationException
class ConcurrentTableModificationException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 7453646730058600581L
-
Exception org.apache.hadoop.hbase.DoNotRetryIOException
class DoNotRetryIOException extends HBaseIOException implements Serializable- serialVersionUID:
- 1197446454511704139L
-
Exception org.apache.hadoop.hbase.DroppedSnapshotException
class DroppedSnapshotException extends IOException implements Serializable- serialVersionUID:
- -5463156580831677374L
-
Exception org.apache.hadoop.hbase.HBaseIOException
class HBaseIOException extends IOException implements Serializable- serialVersionUID:
- 1L
-
Exception org.apache.hadoop.hbase.HBaseServerException
class HBaseServerException extends HBaseIOException implements Serializable-
Serialized Fields
-
serverOverloaded
boolean serverOverloaded
-
-
-
Class org.apache.hadoop.hbase.InnerStoreCellComparator
class InnerStoreCellComparator extends CellComparatorImpl implements Serializable- serialVersionUID:
- 8186411895799094989L
-
Exception org.apache.hadoop.hbase.InvalidFamilyOperationException
class InvalidFamilyOperationException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 4194303L
-
Exception org.apache.hadoop.hbase.MasterNotRunningException
class MasterNotRunningException extends HBaseIOException implements Serializable- serialVersionUID:
- 8388607L
-
Class org.apache.hadoop.hbase.MetaCellComparator
class MetaCellComparator extends CellComparatorImpl implements Serializable -
Exception org.apache.hadoop.hbase.MultiActionResultTooLarge
class MultiActionResultTooLarge extends RetryImmediatelyException implements Serializable -
Exception org.apache.hadoop.hbase.NamespaceExistException
class NamespaceExistException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- -1582357514338825412L
-
Exception org.apache.hadoop.hbase.NamespaceNotFoundException
class NamespaceNotFoundException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- -6673607347330260324L
-
Exception org.apache.hadoop.hbase.NotAllMetaRegionsOnlineException
class NotAllMetaRegionsOnlineException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 6439786157874827523L
-
Exception org.apache.hadoop.hbase.NotServingRegionException
class NotServingRegionException extends IOException implements Serializable- serialVersionUID:
- 131071L
-
Exception org.apache.hadoop.hbase.PleaseHoldException
class PleaseHoldException extends HBaseIOException implements Serializable -
Exception org.apache.hadoop.hbase.PleaseRestartMasterException
class PleaseRestartMasterException extends HBaseIOException implements Serializable -
Exception org.apache.hadoop.hbase.RegionException
class RegionException extends HBaseIOException implements Serializable- serialVersionUID:
- 1473510258071111371L
-
Exception org.apache.hadoop.hbase.RegionTooBusyException
class RegionTooBusyException extends IOException implements Serializable- serialVersionUID:
- 1728345723728342L
-
Exception org.apache.hadoop.hbase.ReplicationPeerNotFoundException
class ReplicationPeerNotFoundException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 1L
-
Exception org.apache.hadoop.hbase.RetryImmediatelyException
class RetryImmediatelyException extends IOException implements Serializable -
Class org.apache.hadoop.hbase.ServerName
class ServerName extends Object implements Serializable- serialVersionUID:
- 1367463982557264981L
-
Serialized Fields
-
bytes
byte[] bytes
Cached versioned bytes of this ServerName instance.- See Also:
-
serverName
String serverName
-
startCode
long startCode
-
-
Exception org.apache.hadoop.hbase.ServiceNotRunningException
class ServiceNotRunningException extends HBaseIOException implements Serializable -
Class org.apache.hadoop.hbase.SslRMIClientSocketFactorySecure
class SslRMIClientSocketFactorySecure extends SslRMIClientSocketFactory implements Serializable -
Exception org.apache.hadoop.hbase.TableExistsException
class TableExistsException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 127L
-
Exception org.apache.hadoop.hbase.TableInfoMissingException
class TableInfoMissingException extends HBaseIOException implements Serializable -
Exception org.apache.hadoop.hbase.TableNotDisabledException
class TableNotDisabledException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 524287L
-
Exception org.apache.hadoop.hbase.TableNotEnabledException
class TableNotEnabledException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 262144L
-
Exception org.apache.hadoop.hbase.TableNotFoundException
class TableNotFoundException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 993179627856392526L
-
Exception org.apache.hadoop.hbase.UnknownRegionException
class UnknownRegionException extends DoNotRetryRegionException implements Serializable- serialVersionUID:
- 1968858760475205392L
-
Exception org.apache.hadoop.hbase.UnknownScannerException
class UnknownScannerException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 993179627856392526L
-
Exception org.apache.hadoop.hbase.YouAreDeadException
class YouAreDeadException extends IOException implements Serializable -
Exception org.apache.hadoop.hbase.ZooKeeperConnectionException
class ZooKeeperConnectionException extends IOException implements Serializable- serialVersionUID:
- 8388607L
-
-
Package org.apache.hadoop.hbase.backup
-
Exception org.apache.hadoop.hbase.backup.FailedArchiveException
class FailedArchiveException extends IOException implements Serializable-
Serialized Fields
-
failedFiles
Collection<org.apache.hadoop.fs.Path> failedFiles
-
-
-
-
Package org.apache.hadoop.hbase.backup.impl
-
Exception org.apache.hadoop.hbase.backup.impl.BackupException
class BackupException extends HBaseIOException implements Serializable-
Serialized Fields
-
info
BackupInfo info
-
-
-
Exception org.apache.hadoop.hbase.backup.impl.ColumnFamilyMismatchException
class ColumnFamilyMismatchException extends HBaseIOException implements Serializable -
Exception org.apache.hadoop.hbase.backup.impl.ExclusiveOperationException
class ExclusiveOperationException extends IOException implements Serializable
-
-
Package org.apache.hadoop.hbase.client
-
Exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
class DoNotRetryRegionException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 6907047686199321701L
-
Exception org.apache.hadoop.hbase.client.NoServerForRegionException
class NoServerForRegionException extends DoNotRetryRegionException implements Serializable- serialVersionUID:
- 2047L
-
Exception org.apache.hadoop.hbase.client.RegionOfflineException
class RegionOfflineException extends RegionException implements Serializable- serialVersionUID:
- 466008402L
-
Exception org.apache.hadoop.hbase.client.RetriesExhaustedException
class RetriesExhaustedException extends IOException implements Serializable- serialVersionUID:
- 1876775844L
-
Exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
class RetriesExhaustedWithDetailsException extends RetriesExhaustedException implements Serializable -
Exception org.apache.hadoop.hbase.client.RowTooBigException
class RowTooBigException extends DoNotRetryRegionException implements Serializable -
Exception org.apache.hadoop.hbase.client.WrongRowIOException
class WrongRowIOException extends HBaseIOException implements Serializable- serialVersionUID:
- -5849522209440123059L
-
-
Package org.apache.hadoop.hbase.codec
-
Exception org.apache.hadoop.hbase.codec.CodecException
class CodecException extends HBaseIOException implements Serializable
-
-
Package org.apache.hadoop.hbase.constraint
-
Exception org.apache.hadoop.hbase.constraint.ConstraintException
class ConstraintException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 1197446454511704140L
-
-
Package org.apache.hadoop.hbase.coprocessor
-
Exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
class CoprocessorException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 4357922136679804887L
-
-
Package org.apache.hadoop.hbase.errorhandling
-
Exception org.apache.hadoop.hbase.errorhandling.ForeignException
class ForeignException extends IOException implements Serializable-
Serialized Fields
-
source
String source
Name of the throwable's source such as a host or thread name. Must be non-null.
-
-
-
Exception org.apache.hadoop.hbase.errorhandling.TimeoutException
class TimeoutException extends Exception implements Serializable-
Serialized Fields
-
end
long end
-
expected
long expected
-
sourceName
String sourceName
-
start
long start
-
-
-
-
Package org.apache.hadoop.hbase.exceptions
-
Exception org.apache.hadoop.hbase.exceptions.ConnectionClosedException
class ConnectionClosedException extends HBaseIOException implements Serializable- serialVersionUID:
- -8938225073412971497L
-
Exception org.apache.hadoop.hbase.exceptions.ConnectionClosingException
class ConnectionClosingException extends IOException implements Serializable- serialVersionUID:
- -8980028569652624236L
-
Exception org.apache.hadoop.hbase.exceptions.DeserializationException
class DeserializationException extends HBaseException implements Serializable -
Exception org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
class FailedSanityCheckException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 1788783640409186240L
-
Exception org.apache.hadoop.hbase.exceptions.HBaseException
class HBaseException extends Exception implements Serializable -
Exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
class IllegalArgumentIOException extends IOException implements Serializable -
Exception org.apache.hadoop.hbase.exceptions.KeyManagerException
class KeyManagerException extends X509Exception implements Serializable -
Exception org.apache.hadoop.hbase.exceptions.MasterRegistryFetchException
class MasterRegistryFetchException extends HBaseIOException implements Serializable- serialVersionUID:
- 6992134872168185171L
-
Exception org.apache.hadoop.hbase.exceptions.MasterStoppedException
class MasterStoppedException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- -4284604435898100365L
-
Exception org.apache.hadoop.hbase.exceptions.MergeRegionException
class MergeRegionException extends DoNotRetryRegionException implements Serializable- serialVersionUID:
- 4970899110066124122L
-
Exception org.apache.hadoop.hbase.exceptions.OutOfOrderScannerNextException
class OutOfOrderScannerNextException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 4595751007554273567L
-
Exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
class PreemptiveFastFailException extends ConnectException implements Serializable- serialVersionUID:
- 7129103682617007177L
-
Serialized Fields
-
failureCount
long failureCount
Deprecated. -
guaranteedClientSideOnly
boolean guaranteedClientSideOnly
Deprecated. -
timeOfFirstFailureMilliSec
long timeOfFirstFailureMilliSec
Deprecated. -
timeOfLatestAttemptMilliSec
long timeOfLatestAttemptMilliSec
Deprecated.
-
-
Exception org.apache.hadoop.hbase.exceptions.RegionMovedException
class RegionMovedException extends NotServingRegionException implements Serializable- serialVersionUID:
- -7232903522310558396L
-
Serialized Fields
-
hostname
String hostname
-
locationSeqNum
long locationSeqNum
-
port
int port
-
startCode
long startCode
-
-
Exception org.apache.hadoop.hbase.exceptions.RegionOpeningException
class RegionOpeningException extends NotServingRegionException implements Serializable- serialVersionUID:
- -7232903522310558395L
-
Exception org.apache.hadoop.hbase.exceptions.RequestTooBigException
class RequestTooBigException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- -1593339239809586516L
-
Exception org.apache.hadoop.hbase.exceptions.ScannerResetException
class ScannerResetException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- -5649728171144849619L
-
Exception org.apache.hadoop.hbase.exceptions.SSLContextException
class SSLContextException extends X509Exception implements Serializable -
Exception org.apache.hadoop.hbase.exceptions.TimeoutIOException
class TimeoutIOException extends IOException implements Serializable -
Exception org.apache.hadoop.hbase.exceptions.TrustManagerException
class TrustManagerException extends X509Exception implements Serializable -
Exception org.apache.hadoop.hbase.exceptions.UnexpectedStateException
class UnexpectedStateException extends HBaseIOException implements Serializable- serialVersionUID:
- -6727953144066746071L
-
Exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
class UnknownProtocolException extends DoNotRetryIOException implements Serializable-
Serialized Fields
-
protocol
Class<?> protocol
-
-
-
Exception org.apache.hadoop.hbase.exceptions.X509Exception
class X509Exception extends HBaseException implements Serializable
-
-
Package org.apache.hadoop.hbase.filter
-
Exception org.apache.hadoop.hbase.filter.IncompatibleFilterException
class IncompatibleFilterException extends RuntimeException implements Serializable- serialVersionUID:
- 3236763276623198231L
-
Exception org.apache.hadoop.hbase.filter.InvalidRowFilterException
class InvalidRowFilterException extends RuntimeException implements Serializable- serialVersionUID:
- 2667894046345657865L
-
-
Package org.apache.hadoop.hbase.hbtop
-
Package org.apache.hadoop.hbase.http
-
Class org.apache.hadoop.hbase.http.AdminAuthorizedServlet
class AdminAuthorizedServlet extends org.apache.hbase.thirdparty.org.eclipse.jetty.servlet.DefaultServlet implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.hadoop.hbase.http.HttpServer.StackServlet
class StackServlet extends javax.servlet.http.HttpServlet implements Serializable- serialVersionUID:
- -6284183679759467039L
-
Class org.apache.hadoop.hbase.http.ProfileOutputServlet
class ProfileOutputServlet extends org.apache.hbase.thirdparty.org.eclipse.jetty.servlet.DefaultServlet implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.hadoop.hbase.http.ProfileServlet
class ProfileServlet extends javax.servlet.http.HttpServlet implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.hadoop.hbase.http.ProfileServlet.DisabledServlet
class DisabledServlet extends javax.servlet.http.HttpServlet implements Serializable- serialVersionUID:
- 1L
-
-
Package org.apache.hadoop.hbase.http.conf
-
Class org.apache.hadoop.hbase.http.conf.ConfServlet
class ConfServlet extends javax.servlet.http.HttpServlet implements Serializable- serialVersionUID:
- 1L
-
Exception org.apache.hadoop.hbase.http.conf.ConfServlet.BadFormatException
class BadFormatException extends Exception implements Serializable- serialVersionUID:
- 1L
-
-
Package org.apache.hadoop.hbase.http.jmx
-
Class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
class JMXJsonServlet extends javax.servlet.http.HttpServlet implements Serializable- serialVersionUID:
- 1L
-
-
Package org.apache.hadoop.hbase.http.log
-
Class org.apache.hadoop.hbase.http.log.LogLevel.Servlet
class Servlet extends javax.servlet.http.HttpServlet implements Serializable- serialVersionUID:
- 1L
-
-
Package org.apache.hadoop.hbase.http.prometheus
-
Class org.apache.hadoop.hbase.http.prometheus.PrometheusHadoopServlet
class PrometheusHadoopServlet extends javax.servlet.http.HttpServlet implements Serializable
-
-
Package org.apache.hadoop.hbase.io.asyncfs
-
Exception org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper.NameNodeException
class NameNodeException extends IOException implements Serializable- serialVersionUID:
- 3143237406477095390L
-
-
Package org.apache.hadoop.hbase.io.encoding
-
Exception org.apache.hadoop.hbase.io.encoding.EncoderBufferTooSmallException
class EncoderBufferTooSmallException extends RuntimeException implements Serializable- serialVersionUID:
- 4767495176134878737L
-
-
Package org.apache.hadoop.hbase.io.hfile
-
Class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
class BlockCacheKey extends Object implements Serializable- serialVersionUID:
- -5199992013113130534L
-
Exception org.apache.hadoop.hbase.io.hfile.CorruptHFileException
class CorruptHFileException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 1L
-
Exception org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.BlockIndexNotLoadedException
class BlockIndexNotLoadedException extends IllegalStateException implements Serializable -
Exception org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.NotSeekedException
class NotSeekedException extends IllegalStateException implements Serializable -
Exception org.apache.hadoop.hbase.io.hfile.InvalidHFileException
class InvalidHFileException extends IOException implements Serializable- serialVersionUID:
- 4660352028739861249L
-
-
Package org.apache.hadoop.hbase.io.hfile.bucket
-
Exception org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocatorException
class BucketAllocatorException extends IOException implements Serializable- serialVersionUID:
- 2479119906660788096L
-
Exception org.apache.hadoop.hbase.io.hfile.bucket.CacheFullException
class CacheFullException extends IOException implements Serializable- serialVersionUID:
- 3265127301824638920L
-
Serialized Fields
-
bucketIndex
int bucketIndex
-
requestedSize
int requestedSize
-
-
-
Package org.apache.hadoop.hbase.ipc
-
Exception org.apache.hadoop.hbase.ipc.BadAuthException
class BadAuthException extends FatalConnectionException implements Serializable -
Exception org.apache.hadoop.hbase.ipc.CallCancelledException
class CallCancelledException extends HBaseIOException implements Serializable- serialVersionUID:
- 309775809470318208L
-
Exception org.apache.hadoop.hbase.ipc.CallerDisconnectedException
class CallerDisconnectedException extends IOException implements Serializable- serialVersionUID:
- 1L
-
Exception org.apache.hadoop.hbase.ipc.CallTimeoutException
class CallTimeoutException extends HBaseIOException implements Serializable -
Exception org.apache.hadoop.hbase.ipc.CellScannerButNoCodecException
class CellScannerButNoCodecException extends HBaseIOException implements Serializable -
Exception org.apache.hadoop.hbase.ipc.DecommissionedHostRejectedException
class DecommissionedHostRejectedException extends HBaseIOException implements Serializable -
Exception org.apache.hadoop.hbase.ipc.EmptyServiceNameException
class EmptyServiceNameException extends FatalConnectionException implements Serializable -
Exception org.apache.hadoop.hbase.ipc.FailedServerException
class FailedServerException extends HBaseIOException implements Serializable -
Exception org.apache.hadoop.hbase.ipc.FallbackDisallowedException
class FallbackDisallowedException extends HBaseIOException implements Serializable- serialVersionUID:
- -6942845066279358253L
-
Exception org.apache.hadoop.hbase.ipc.FatalConnectionException
class FatalConnectionException extends DoNotRetryIOException implements Serializable -
Exception org.apache.hadoop.hbase.ipc.PluggableRpcQueueNotFound
class PluggableRpcQueueNotFound extends RuntimeException implements Serializable -
Exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
class RemoteWithExtrasException extends org.apache.hadoop.ipc.RemoteException implements Serializable-
Serialized Fields
-
doNotRetry
boolean doNotRetry
-
hostname
String hostname
-
port
int port
-
serverOverloaded
boolean serverOverloaded
-
-
-
Exception org.apache.hadoop.hbase.ipc.SecurityNotEnabledException
class SecurityNotEnabledException extends HBaseIOException implements Serializable- serialVersionUID:
- -3682812966232247662L
-
Exception org.apache.hadoop.hbase.ipc.ServerNotRunningYetException
class ServerNotRunningYetException extends IOException implements Serializable -
Exception org.apache.hadoop.hbase.ipc.ServerTooBusyException
class ServerTooBusyException extends DoNotRetryIOException implements Serializable -
Exception org.apache.hadoop.hbase.ipc.StoppedRpcClientException
class StoppedRpcClientException extends DoNotRetryIOException implements Serializable -
Exception org.apache.hadoop.hbase.ipc.UnknownServiceException
class UnknownServiceException extends FatalConnectionException implements Serializable -
Exception org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException
class UnsupportedCellCodecException extends FatalConnectionException implements Serializable -
Exception org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException
class UnsupportedCompressionCodecException extends FatalConnectionException implements Serializable -
Exception org.apache.hadoop.hbase.ipc.UnsupportedCryptoException
class UnsupportedCryptoException extends FatalConnectionException implements Serializable -
Exception org.apache.hadoop.hbase.ipc.WrongVersionException
class WrongVersionException extends FatalConnectionException implements Serializable
-
-
Package org.apache.hadoop.hbase.mapreduce
-
Exception org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.BadTsvLineException
class BadTsvLineException extends Exception implements Serializable- serialVersionUID:
- 1L
-
-
Package org.apache.hadoop.hbase.master
-
Exception org.apache.hadoop.hbase.master.NoSuchProcedureException
class NoSuchProcedureException extends HBaseIOException implements Serializable -
Class org.apache.hadoop.hbase.master.RegionPlan.RegionPlanComparator
class RegionPlanComparator extends Object implements Serializable- serialVersionUID:
- 4213207330485734853L
-
-
Package org.apache.hadoop.hbase.master.http
-
Class org.apache.hadoop.hbase.master.http.MasterDumpServlet
class MasterDumpServlet extends StateDumpServlet implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.hadoop.hbase.master.http.MasterRedirectServlet
class MasterRedirectServlet extends javax.servlet.http.HttpServlet implements Serializable- serialVersionUID:
- 2894774810058302473L
-
Serialized Fields
-
regionServerHostname
String regionServerHostname
-
regionServerInfoPort
int regionServerInfoPort
-
-
Class org.apache.hadoop.hbase.master.http.MasterStatusServlet
class MasterStatusServlet extends javax.servlet.http.HttpServlet implements Serializable- serialVersionUID:
- 1L
-
-
Package org.apache.hadoop.hbase.master.procedure
-
Exception org.apache.hadoop.hbase.master.procedure.ServerCrashException
class ServerCrashException extends HBaseIOException implements Serializable-
Serialized Fields
-
procId
long procId
-
serverName
ServerName serverName
-
-
-
-
Package org.apache.hadoop.hbase.monitoring
-
Class org.apache.hadoop.hbase.monitoring.StateDumpServlet
class StateDumpServlet extends javax.servlet.http.HttpServlet implements Serializable- serialVersionUID:
- 1L
-
-
Package org.apache.hadoop.hbase.procedure2
-
Exception org.apache.hadoop.hbase.procedure2.BadProcedureException
class BadProcedureException extends HBaseIOException implements Serializable -
Exception org.apache.hadoop.hbase.procedure2.FailedRemoteDispatchException
class FailedRemoteDispatchException extends HBaseIOException implements Serializable -
Exception org.apache.hadoop.hbase.procedure2.NoNodeDispatchException
class NoNodeDispatchException extends FailedRemoteDispatchException implements Serializable -
Exception org.apache.hadoop.hbase.procedure2.NoServerDispatchException
class NoServerDispatchException extends FailedRemoteDispatchException implements Serializable -
Exception org.apache.hadoop.hbase.procedure2.NullTargetServerDispatchException
class NullTargetServerDispatchException extends FailedRemoteDispatchException implements Serializable -
Exception org.apache.hadoop.hbase.procedure2.ProcedureAbortedException
class ProcedureAbortedException extends ProcedureException implements Serializable -
Class org.apache.hadoop.hbase.procedure2.ProcedureDeque
-
Exception org.apache.hadoop.hbase.procedure2.ProcedureException
class ProcedureException extends HBaseException implements Serializable -
Exception org.apache.hadoop.hbase.procedure2.ProcedureSuspendedException
class ProcedureSuspendedException extends ProcedureException implements Serializable- serialVersionUID:
- -8328419627678496269L
-
Exception org.apache.hadoop.hbase.procedure2.ProcedureYieldException
class ProcedureYieldException extends ProcedureException implements Serializable -
Exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
class RemoteProcedureException extends ProcedureException implements Serializable-
Serialized Fields
-
source
String source
Name of the throwable's source such as a host or thread name. Must be non-null.
-
-
-
-
Package org.apache.hadoop.hbase.procedure2.store.wal
-
Exception org.apache.hadoop.hbase.procedure2.store.wal.CorruptedWALProcedureStoreException
class CorruptedWALProcedureStoreException extends HBaseIOException implements Serializable- serialVersionUID:
- -3407300445435898074L
-
Exception org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat.InvalidWALDataException
class InvalidWALDataException extends IOException implements Serializable- serialVersionUID:
- 5471733223070202196L
-
-
Package org.apache.hadoop.hbase.quotas
-
Exception org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl.QuotaSnapshotSizeSerializationException
class QuotaSnapshotSizeSerializationException extends IOException implements Serializable- serialVersionUID:
- 1L
-
Exception org.apache.hadoop.hbase.quotas.QuotaExceededException
class QuotaExceededException extends DoNotRetryIOException implements Serializable -
Exception org.apache.hadoop.hbase.quotas.RpcThrottlingException
class RpcThrottlingException extends HBaseIOException implements Serializable-
Serialized Fields
-
type
RpcThrottlingException.Type type
-
waitInterval
long waitInterval
-
-
-
Exception org.apache.hadoop.hbase.quotas.SpaceLimitingException
class SpaceLimitingException extends QuotaExceededException implements Serializable- serialVersionUID:
- 2319438922387583600L
-
Serialized Fields
-
policyName
String policyName
-
-
-
Package org.apache.hadoop.hbase.regionserver
-
Exception org.apache.hadoop.hbase.regionserver.InvalidMutationDurabilityException
class InvalidMutationDurabilityException extends DoNotRetryIOException implements Serializable -
Exception org.apache.hadoop.hbase.regionserver.LeaseException
class LeaseException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 8179703995292418650L
-
Exception org.apache.hadoop.hbase.regionserver.LeaseManager.LeaseStillHeldException
class LeaseStillHeldException extends IOException implements Serializable-
Serialized Fields
-
leaseName
String leaseName
-
-
-
Exception org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyException
class NoSuchColumnFamilyException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- -6569952730832331274L
-
Exception org.apache.hadoop.hbase.regionserver.RegionServerAbortedException
class RegionServerAbortedException extends RegionServerStoppedException implements Serializable -
Exception org.apache.hadoop.hbase.regionserver.RegionServerRunningException
class RegionServerRunningException extends IOException implements Serializable- serialVersionUID:
- 2147483647L
-
Exception org.apache.hadoop.hbase.regionserver.RegionServerStoppedException
class RegionServerStoppedException extends IOException implements Serializable -
Exception org.apache.hadoop.hbase.regionserver.RowTooBigException
class RowTooBigException extends RowTooBigException implements Serializable -
Exception org.apache.hadoop.hbase.regionserver.SplitWALCallable.ErrorWALSplitException
class ErrorWALSplitException extends HBaseIOException implements Serializable -
Exception org.apache.hadoop.hbase.regionserver.SplitWALCallable.PreemptedWALSplitException
class PreemptedWALSplitException extends HBaseIOException implements Serializable -
Exception org.apache.hadoop.hbase.regionserver.SplitWALCallable.ResignedWALSplitException
class ResignedWALSplitException extends HBaseIOException implements Serializable -
Exception org.apache.hadoop.hbase.regionserver.WrongRegionException
class WrongRegionException extends IOException implements Serializable- serialVersionUID:
- 993179627856392526L
-
-
Package org.apache.hadoop.hbase.regionserver.http
-
Class org.apache.hadoop.hbase.regionserver.http.RSDumpServlet
class RSDumpServlet extends StateDumpServlet implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.hadoop.hbase.regionserver.http.RSStatusServlet
class RSStatusServlet extends javax.servlet.http.HttpServlet implements Serializable- serialVersionUID:
- 1L
-
-
Package org.apache.hadoop.hbase.regionserver.wal
-
Exception org.apache.hadoop.hbase.regionserver.wal.DamagedWALException
class DamagedWALException extends HBaseIOException implements Serializable -
Exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
class FailedLogCloseException extends IOException implements Serializable- serialVersionUID:
- 1759152841462990925L
-
Exception org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
class FailedSyncBeforeLogCloseException extends FailedLogCloseException implements Serializable- serialVersionUID:
- 1759152841462990925L
-
Exception org.apache.hadoop.hbase.regionserver.wal.WALClosedException
class WALClosedException extends IOException implements Serializable- serialVersionUID:
- -3183198896865290678L
-
Exception org.apache.hadoop.hbase.regionserver.wal.WALHeaderEOFException
class WALHeaderEOFException extends EOFException implements Serializable- serialVersionUID:
- -4544368452826740759L
-
Exception org.apache.hadoop.hbase.regionserver.wal.WALSyncTimeoutIOException
class WALSyncTimeoutIOException extends HBaseIOException implements Serializable- serialVersionUID:
- 5067699288291906985L
-
-
Package org.apache.hadoop.hbase.replication
-
Exception org.apache.hadoop.hbase.replication.ReplicationException
class ReplicationException extends HBaseException implements Serializable- serialVersionUID:
- -8885598603988198062L
-
-
Package org.apache.hadoop.hbase.replication.regionserver
-
Exception org.apache.hadoop.hbase.replication.regionserver.ReplicationRuntimeException
class ReplicationRuntimeException extends RuntimeException implements Serializable- serialVersionUID:
- 1L
-
Exception org.apache.hadoop.hbase.replication.regionserver.WALEntryFilterRetryableException
class WALEntryFilterRetryableException extends RuntimeException implements Serializable- serialVersionUID:
- 1L
-
-
Package org.apache.hadoop.hbase.rest
-
Class org.apache.hadoop.hbase.rest.RESTDumpServlet
class RESTDumpServlet extends StateDumpServlet implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.hadoop.hbase.rest.RESTServletContainer
class RESTServletContainer extends org.apache.hbase.thirdparty.org.glassfish.jersey.servlet.ServletContainer implements Serializable- serialVersionUID:
- -2474255003443394314L
-
-
Package org.apache.hadoop.hbase.rest.client
-
Exception org.apache.hadoop.hbase.rest.client.Client.ClientTrustStoreInitializationException
class ClientTrustStoreInitializationException extends RuntimeException implements Serializable
-
-
Package org.apache.hadoop.hbase.rest.model
-
Class org.apache.hadoop.hbase.rest.model.CellModel
class CellModel extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
column
byte[] column
-
timestamp
long timestamp
-
value
byte[] value
-
valueLength
int valueLength
-
valueOffset
int valueOffset
-
-
Class org.apache.hadoop.hbase.rest.model.CellSetModel
class CellSetModel extends Object implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
class ColumnSchemaModel extends Object implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
class NamespacesInstanceModel extends Object implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.hadoop.hbase.rest.model.NamespacesModel
class NamespacesModel extends Object implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.hadoop.hbase.rest.model.RowModel
class RowModel extends Object implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.hadoop.hbase.rest.model.ScannerModel
class ScannerModel extends Object implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
class StorageClusterStatusModel extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
averageLoad
double averageLoad
-
deadNodes
List<String> deadNodes
-
liveNodes
List<StorageClusterStatusModel.Node> liveNodes
-
regions
int regions
-
requests
long requests
-
-
Class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
class Node extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
heapSizeMB
int heapSizeMB
-
maxHeapSizeMB
int maxHeapSizeMB
-
name
String name
-
regions
List<StorageClusterStatusModel.Node.Region> regions
-
requests
long requests
-
startCode
long startCode
-
-
Class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
class Region extends Object implements Serializable- serialVersionUID:
- -1326683840086398193L
-
Serialized Fields
-
cpRequestsCount
long cpRequestsCount
-
currentCompactedKVs
long currentCompactedKVs
-
memstoreSizeMB
int memstoreSizeMB
-
name
byte[] name
-
readRequestsCount
long readRequestsCount
-
rootIndexSizeKB
int rootIndexSizeKB
-
storefileIndexSizeKB
long storefileIndexSizeKB
-
storefiles
int storefiles
-
storefileSizeMB
int storefileSizeMB
-
stores
int stores
-
totalCompactingKVs
long totalCompactingKVs
-
totalStaticBloomSizeKB
int totalStaticBloomSizeKB
-
totalStaticIndexSizeKB
int totalStaticIndexSizeKB
-
writeRequestsCount
long writeRequestsCount
-
-
Class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
class StorageClusterVersionModel extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
version
String version
-
-
Class org.apache.hadoop.hbase.rest.model.TableInfoModel
class TableInfoModel extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
name
String name
-
regions
List<TableRegionModel> regions
-
-
Class org.apache.hadoop.hbase.rest.model.TableListModel
class TableListModel extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
tables
List<TableModel> tables
-
-
Class org.apache.hadoop.hbase.rest.model.TableModel
class TableModel extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
name
String name
-
-
Class org.apache.hadoop.hbase.rest.model.TableRegionModel
class TableRegionModel extends Object implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.hadoop.hbase.rest.model.TableSchemaModel
class TableSchemaModel extends Object implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.hadoop.hbase.rest.model.VersionModel
class VersionModel extends Object implements Serializable- serialVersionUID:
- 1L
-
-
Package org.apache.hadoop.hbase.security
-
Exception org.apache.hadoop.hbase.security.AccessDeniedException
class AccessDeniedException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 1913879564363001780L
-
-
Package org.apache.hadoop.hbase.security.provider.example
-
Class org.apache.hadoop.hbase.security.provider.example.SaslPlainServer.SecurityProvider
class SecurityProvider extends Provider implements Serializable
-
-
Package org.apache.hadoop.hbase.security.visibility
-
Exception org.apache.hadoop.hbase.security.visibility.InvalidLabelException
class InvalidLabelException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 1L
-
Exception org.apache.hadoop.hbase.security.visibility.LabelAlreadyExistsException
class LabelAlreadyExistsException extends DoNotRetryIOException implements Serializable- serialVersionUID:
- 1L
-
Exception org.apache.hadoop.hbase.security.visibility.ParseException
class ParseException extends Exception implements Serializable- serialVersionUID:
- 1725986524206989173L
-
Exception org.apache.hadoop.hbase.security.visibility.VisibilityControllerNotReadyException
class VisibilityControllerNotReadyException extends IOException implements Serializable- serialVersionUID:
- 1725986525207989173L
-
-
Package org.apache.hadoop.hbase.snapshot
-
Exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
class CorruptedSnapshotException extends HBaseSnapshotException implements Serializable -
Exception org.apache.hadoop.hbase.snapshot.ExportSnapshotException
class ExportSnapshotException extends HBaseSnapshotException implements Serializable -
Exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
class HBaseSnapshotException extends DoNotRetryIOException implements Serializable-
Serialized Fields
-
description
SnapshotDescription description
-
-
-
Exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
class RestoreSnapshotException extends HBaseSnapshotException implements Serializable -
Exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
class SnapshotCreationException extends HBaseSnapshotException implements Serializable -
Exception org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
class SnapshotDoesNotExistException extends HBaseSnapshotException implements Serializable -
Exception org.apache.hadoop.hbase.snapshot.SnapshotExistsException
class SnapshotExistsException extends HBaseSnapshotException implements Serializable -
Exception org.apache.hadoop.hbase.snapshot.SnapshotTTLExpiredException
class SnapshotTTLExpiredException extends HBaseSnapshotException implements Serializable -
Exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
class TablePartiallyOpenException extends IOException implements Serializable- serialVersionUID:
- 3571982660065058361L
-
Exception org.apache.hadoop.hbase.snapshot.UnknownSnapshotException
class UnknownSnapshotException extends HBaseSnapshotException implements Serializable
-
-
Package org.apache.hadoop.hbase.thrift
-
Exception org.apache.hadoop.hbase.thrift.HttpAuthenticationException
class HttpAuthenticationException extends Exception implements Serializable- serialVersionUID:
- 0L
-
Exception org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.IOErrorWithCause
class IOErrorWithCause extends org.apache.hadoop.hbase.thrift.generated.IOError implements Serializable-
Serialized Fields
-
cause
Throwable cause
-
-
-
Class org.apache.hadoop.hbase.thrift.ThriftHttpServlet
class ThriftHttpServlet extends org.apache.thrift.server.TServlet implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
doAsEnabled
boolean doAsEnabled
-
securityEnabled
boolean securityEnabled
-
-
-
Package org.apache.hadoop.hbase.tool
-
Class org.apache.hadoop.hbase.tool.CanaryStatusServlet
class CanaryStatusServlet extends javax.servlet.http.HttpServlet implements Serializable
-
-
Package org.apache.hadoop.hbase.util
-
Exception org.apache.hadoop.hbase.util.CommonFSUtils.StreamLacksCapabilityException
class StreamLacksCapabilityException extends Exception implements Serializable -
Exception org.apache.hadoop.hbase.util.FileSystemVersionException
class FileSystemVersionException extends IOException implements Serializable- serialVersionUID:
- 1004053363L
-
Exception org.apache.hadoop.hbase.util.LeaseNotRecoveredException
class LeaseNotRecoveredException extends HBaseIOException implements Serializable -
Class org.apache.hadoop.hbase.util.Pair
class Pair extends Object implements Serializable- serialVersionUID:
- -3986244606585552569L
-
Exception org.apache.hadoop.hbase.util.ReadOnlyByteRangeException
class ReadOnlyByteRangeException extends UnsupportedOperationException implements Serializable -
Class org.apache.hadoop.hbase.util.StealJobQueue
- serialVersionUID:
- -6334572230936888291L
-
Serialized Fields
-
lock
Lock lock
-
stealFromQueue
BlockingQueue<T> stealFromQueue
-
-
-
Package org.apache.hadoop.hdfs
-
Exception org.apache.hadoop.hdfs.BlockMissingException
class BlockMissingException extends IOException implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
filename
String filename
-
offset
long offset
-
-
Exception org.apache.hadoop.hdfs.CannotObtainBlockLengthException
class CannotObtainBlockLengthException extends IOException implements Serializable- serialVersionUID:
- 1L
-
Exception org.apache.hadoop.hdfs.UnknownCipherSuiteException
class UnknownCipherSuiteException extends IOException implements Serializable -
Exception org.apache.hadoop.hdfs.UnknownCryptoProtocolVersionException
class UnknownCryptoProtocolVersionException extends IOException implements Serializable- serialVersionUID:
- 8957192L
-
-
Package org.apache.hadoop.metrics2
-
Exception org.apache.hadoop.metrics2.MetricsException
class MetricsException extends RuntimeException implements Serializable- serialVersionUID:
- 1L
-
-
Package org.apache.hadoop.metrics2.util
-
Class org.apache.hadoop.metrics2.util.Metrics2Util.TopN
class TopN extends PriorityQueue<org.apache.hadoop.metrics2.util.Metrics2Util.NameValuePair> implements Serializable- serialVersionUID:
- 5134028249611535803L
-
Serialized Fields
-
n
int n
-
total
long total
-
-