| Modifier and Type | Class and Description | 
|---|---|
| class  | ConcurrentTableModificationExceptionThrown when a table has been modified concurrently | 
| class  | DoNotRetryIOExceptionSubclass if exception is not meant to be retried: e.g. | 
| class  | InvalidFamilyOperationExceptionThrown if a request is table schema modification is requested but
 made for an invalid family name. | 
| class  | MasterNotRunningExceptionThrown if the master is not running | 
| class  | NamespaceExistExceptionThrown when a namespace exists but should not | 
| class  | NamespaceNotFoundExceptionThrown when a namespace can not be located | 
| class  | NotAllMetaRegionsOnlineExceptionThrown when an operation requires the root and all meta regions to be online | 
| class  | PleaseHoldExceptionThis exception is thrown by the master when a region server was shut down and
 restarted so fast that the master still hasn't processed the server shutdown
 of the first instance, or when master is initializing and client call admin
 operations, or when an operation is performed on a region server that is still starting. | 
| class  | RegionExceptionThrown when something happens related to region handling. | 
| class  | ReplicationPeerNotFoundExceptionThrown when a replication peer can not be found | 
| class  | ServiceNotRunningException | 
| class  | TableExistsExceptionThrown when a table exists but should not. | 
| class  | TableInfoMissingExceptionFailed to find  .tableinfofile under the table directory. | 
| class  | TableNotDisabledExceptionThrown if a table should be offline but is not. | 
| class  | TableNotEnabledExceptionThrown if a table should be enabled but is not. | 
| class  | TableNotFoundExceptionThrown when a table cannot be located. | 
| class  | UnknownRegionExceptionThrown when we are asked to operate on a region we know nothing about. | 
| class  | UnknownScannerExceptionThrown if a region server is passed an unknown scanner ID. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DoNotRetryRegionExceptionSimilar to RegionException, but disables retries. | 
| class  | LockTimeoutException | 
| class  | NoServerForRegionExceptionThrown when no region server can be found for a region | 
| class  | RegionOfflineExceptionThrown when a table can not be located | 
| class  | RowTooBigExceptionGets or Scans throw this exception if running without in-row scan flag
 set and row size appears to exceed max configured size (configurable via
 hbase.table.max.rowsize). | 
| class  | WrongRowIOException | 
| Modifier and Type | Method and Description | 
|---|---|
| protected HRegionLocation | ScannerCallable. getLocationForReplica(RegionLocations locs) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CodecExceptionThrown when problems in the codec whether setup or context. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ConstraintExceptionException that a user defined constraint throws on failure of a
   Put. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CoprocessorExceptionThrown if a coprocessor encounters any exception. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ConnectionClosedExceptionThrown when the connection is closed | 
| class  | FailedSanityCheckExceptionException thrown if a mutation fails sanity checks. | 
| class  | MasterRegistryFetchExceptionException thrown when an master registry RPC fails in client. | 
| class  | MasterStoppedExceptionThrown when the master is stopped | 
| class  | MergeRegionExceptionThrown when something is wrong in trying to merge two regions. | 
| class  | OutOfOrderScannerNextExceptionThrown by a RegionServer while doing next() calls on a ResultScanner. | 
| class  | RequestTooBigExceptionThrown when the size of the rpc request received by the server is too large. | 
| class  | ScannerResetExceptionThrown when the server side has received an Exception, and asks the Client to reset the scanner
 state by closing the current region scanner, and reopening from the start of last seen row. | 
| class  | UnexpectedStateException | 
| class  | UnknownProtocolExceptionAn error requesting an RPC protocol that the server is not serving. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | FavoredNodeLoadBalancer. initialize() | 
| ServerName | FavoredNodeLoadBalancer. randomAssignment(RegionInfo regionInfo,
                List<ServerName> servers) | 
| Map<ServerName,List<RegionInfo>> | FavoredNodeLoadBalancer. roundRobinAssignment(List<RegionInfo> regions,
                    List<ServerName> servers) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CorruptHFileExceptionThis exception is thrown when attempts to read an HFile fail due to corruption or truncation
 issues. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BadAuthException | 
| class  | CallCancelledExceptionClient side call cancelled. | 
| class  | CallTimeoutExceptionClient-side call timeout | 
| class  | CellScannerButNoCodecExceptionThrown if a cellscanner but no codec to encode it with. | 
| class  | EmptyServiceNameException | 
| class  | FailedServerExceptionIndicates that we're trying to connect to a already known as dead server. | 
| class  | FallbackDisallowedExceptionIndicate that the rpc server tells client to fallback to simple auth but client is disabled to do
 so. | 
| class  | FatalConnectionExceptionThrown when server finds fatal issue w/ connection setup: e.g. | 
| class  | ServerTooBusyExceptionThrow this in RPC call if there are too many pending requests for one region server | 
| class  | StoppedRpcClientException | 
| class  | UnknownServiceException | 
| class  | UnsupportedCellCodecException | 
| class  | UnsupportedCompressionCodecException | 
| class  | UnsupportedCryptoException | 
| class  | WrongVersionException | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | NoSuchProcedureException | 
| Modifier and Type | Method and Description | 
|---|---|
| void | HMaster. decommissionRegionServers(List<ServerName> servers,
                         boolean offload)Mark region server(s) as decommissioned (previously called 'draining') to prevent additional
 regions from getting assigned to them. | 
| void | LoadBalancer. initialize()Initialize the load balancer. | 
| void | HMaster. move(byte[] encodedRegionName,
    byte[] destServerName) | 
| ServerName | LoadBalancer. randomAssignment(RegionInfo regionInfo,
                List<ServerName> servers)Get a random region server from the list | 
| Map<ServerName,List<RegionInfo>> | LoadBalancer. retainAssignment(Map<RegionInfo,ServerName> regions,
                List<ServerName> servers)Assign regions to the previously hosting region server | 
| Map<ServerName,List<RegionInfo>> | LoadBalancer. roundRobinAssignment(List<RegionInfo> regions,
                    List<ServerName> servers)Perform a Round Robin assignment of regions. | 
| Modifier and Type | Method and Description | 
|---|---|
| private void | AssignmentManager. acceptPlan(HashMap<RegionInfo,RegionStateNode> regions,
          Map<ServerName,List<RegionInfo>> plan) | 
| TransitRegionStateProcedure | AssignmentManager. createMoveRegionProcedure(RegionInfo regionInfo,
                         ServerName targetServer) | 
| Future<byte[]> | AssignmentManager. moveAsync(RegionPlan regionPlan) | 
| private void | AssignmentManager. preTransitCheck(RegionStateNode regionNode,
               RegionState.State[] expectedStates) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected BaseLoadBalancer.Cluster | BaseLoadBalancer. createCluster(List<ServerName> servers,
             Collection<RegionInfo> regions) | 
| void | BaseLoadBalancer. initialize() | 
| void | FavoredStochasticBalancer. initialize() | 
| ServerName | BaseLoadBalancer. randomAssignment(RegionInfo regionInfo,
                List<ServerName> servers)Used to assign a single region to a random server. | 
| ServerName | FavoredStochasticBalancer. randomAssignment(RegionInfo regionInfo,
                List<ServerName> servers) | 
| Map<ServerName,List<RegionInfo>> | BaseLoadBalancer. retainAssignment(Map<RegionInfo,ServerName> regions,
                List<ServerName> servers)Generates a bulk assignment startup plan, attempting to reuse the existing
 assignment information from META, but adjusting for the specified list of
 available/online servers available for assignment. | 
| Map<ServerName,List<RegionInfo>> | FavoredStochasticBalancer. retainAssignment(Map<RegionInfo,ServerName> regions,
                List<ServerName> servers) | 
| Map<ServerName,List<RegionInfo>> | BaseLoadBalancer. roundRobinAssignment(List<RegionInfo> regions,
                    List<ServerName> servers)Generates a bulk assignment plan to be used on cluster startup using a
 simple round-robin assignment. | 
| Map<ServerName,List<RegionInfo>> | FavoredStochasticBalancer. roundRobinAssignment(List<RegionInfo> regions,
                    List<ServerName> servers) | 
| private Pair<Map<ServerName,List<RegionInfo>>,List<RegionInfo>> | FavoredStochasticBalancer. segregateRegionsAndAssignRegionsWithFavoredNodes(Collection<RegionInfo> regions,
                                                List<ServerName> onlineServers) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ServerCrashExceptionPassed as Exception by  ServerCrashProcedurenotifying on-going RIT that server has failed. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | ModifyTableProcedure. preflightChecks(MasterProcedureEnv env,
               Boolean enabled) | 
| protected void | AbstractStateMachineTableProcedure. preflightChecks(MasterProcedureEnv env,
               Boolean enabled)Check that cluster is up and master is running. | 
| Constructor and Description | 
|---|
| DisableTableProcedure(MasterProcedureEnv env,
                     TableName tableName,
                     boolean skipTableStateCheck)Constructor | 
| DisableTableProcedure(MasterProcedureEnv env,
                     TableName tableName,
                     boolean skipTableStateCheck,
                     ProcedurePrepareLatch syncLatch)Constructor | 
| ModifyTableProcedure(MasterProcedureEnv env,
                    TableDescriptor htd) | 
| ModifyTableProcedure(MasterProcedureEnv env,
                    TableDescriptor htd,
                    ProcedurePrepareLatch latch) | 
| ModifyTableProcedure(MasterProcedureEnv env,
                    TableDescriptor newTableDescriptor,
                    ProcedurePrepareLatch latch,
                    TableDescriptor oldTableDescriptor,
                    boolean shouldCheckDescriptor) | 
| RestoreSnapshotProcedure(MasterProcedureEnv env,
                        TableDescriptor tableDescriptor,
                        org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot) | 
| RestoreSnapshotProcedure(MasterProcedureEnv env,
                        TableDescriptor tableDescriptor,
                        org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
                        boolean restoreAcl)Constructor | 
| TruncateTableProcedure(MasterProcedureEnv env,
                      TableName tableName,
                      boolean preserveSplits) | 
| TruncateTableProcedure(MasterProcedureEnv env,
                      TableName tableName,
                      boolean preserveSplits,
                      ProcedurePrepareLatch latch) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BadProcedureException | 
| class  | FailedRemoteDispatchExceptionUsed internally signaling failed queue of a remote procedure
 operation. | 
| class  | NoNodeDispatchExceptionUsed internally signaling failed queue of a remote procedure operation. | 
| class  | NoServerDispatchExceptionUsed internally signaling failed queue of a remote procedure operation. | 
| class  | NullTargetServerDispatchExceptionUsed internally signaling failed queue of a remote procedure operation. | 
| Modifier and Type | Method and Description | 
|---|---|
| private void | RegionProcedureStore. checkUnsupportedProcedure(Map<Class<?>,List<Procedure<?>>> procsByType)In HBASE-20811, we have introduced a new TRSP to assign/unassign/move regions, and it is
 incompatible with the old AssignProcedure/UnassignProcedure/MoveRegionProcedure. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CorruptedWALProcedureStoreExceptionDeprecated. 
 Since 2.3.0, will be removed in 4.0.0. Keep here only for rolling upgrading, now we
             use the new region based procedure store. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | QuotaExceededExceptionGeneric quota exceeded exception | 
| class  | RpcThrottlingExceptionDescribe the throttling result. | 
| class  | SpaceLimitingExceptionAn Exception that is thrown when a space quota is in violation. | 
| class  | ThrottlingExceptionDeprecated. 
 replaced by  RpcThrottlingExceptionsince hbase-2.0.0. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | LeaseExceptionReports a problem with a lease | 
| class  | NoSuchColumnFamilyExceptionThrown if request for nonexistent column family. | 
| static class  | SplitWALCallable.ErrorWALSplitException | 
| static class  | SplitWALCallable.PreemptedWALSplitException | 
| static class  | SplitWALCallable.ResignedWALSplitException | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DamagedWALExceptionThrown when a failed append or sync on a WAL. | 
| Modifier and Type | Method and Description | 
|---|---|
| private List<Pair<List<RegionInfo>,List<ServerName>>> | RSGroupBasedLoadBalancer. generateGroupAssignments(List<RegionInfo> regions,
                        List<ServerName> servers) | 
| void | RSGroupBasedLoadBalancer. initialize() | 
| ServerName | RSGroupBasedLoadBalancer. randomAssignment(RegionInfo region,
                List<ServerName> servers) | 
| Map<ServerName,List<RegionInfo>> | RSGroupBasedLoadBalancer. retainAssignment(Map<RegionInfo,ServerName> regions,
                List<ServerName> servers) | 
| Map<ServerName,List<RegionInfo>> | RSGroupBasedLoadBalancer. roundRobinAssignment(List<RegionInfo> regions,
                    List<ServerName> servers) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AccessDeniedExceptionException thrown by access-related methods. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | InvalidLabelException | 
| class  | LabelAlreadyExistsException | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CorruptedSnapshotExceptionException thrown when the found snapshot info from the filesystem is not valid. | 
| class  | ExportSnapshotExceptionThrown when a snapshot could not be exported due to an error during the operation. | 
| class  | HBaseSnapshotExceptionGeneral exception base class for when a snapshot fails. | 
| class  | RestoreSnapshotExceptionThrown when a snapshot could not be restored due to a server-side error when restoring it. | 
| class  | SnapshotCreationExceptionThrown when a snapshot could not be created due to a server-side error when
 taking the snapshot. | 
| class  | SnapshotDoesNotExistExceptionThrown when the server is looking for a snapshot, but can't find the snapshot on the filesystem. | 
| class  | SnapshotExistsExceptionThrown when a snapshot exists, but should not. | 
| class  | UnknownSnapshotExceptionException thrown when we get a request for a snapshot we don't recognize. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | LeaseNotRecoveredExceptionThrown when the lease was expected to be recovered,
 but the file can't be opened. | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.