Modifier and Type | Class and Description |
---|---|
class |
CallDroppedException
Returned to the clients when their request was discarded due to server being overloaded.
|
class |
CallQueueTooBigException
Returned to clients when their request was dropped because the call queue was too big to accept a
new call.
|
class |
ConcurrentTableModificationException
Thrown when a table has been modified concurrently
|
class |
DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
|
class |
HBaseServerException
Base class for exceptions thrown by an HBase server.
|
class |
InvalidFamilyOperationException
Thrown if a request is table schema modification is requested but made for an invalid family
name.
|
class |
MasterNotRunningException
Thrown if the master is not running
|
class |
NamespaceExistException
Thrown when a namespace exists but should not
|
class |
NamespaceNotFoundException
Thrown when a namespace can not be located
|
class |
NotAllMetaRegionsOnlineException
Thrown when an operation requires the root and all meta regions to be online
|
class |
PleaseHoldException
This 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 |
PleaseRestartMasterException
Thrown if the master requires restart.
|
class |
RegionException
Thrown when something happens related to region handling.
|
class |
ReplicationPeerNotFoundException
Thrown when a replication peer can not be found
|
class |
ServiceNotRunningException |
class |
TableExistsException
Thrown when a table exists but should not.
|
class |
TableInfoMissingException
Failed to find
.tableinfo file under the table directory. |
class |
TableNotDisabledException
Thrown if a table should be offline but is not.
|
class |
TableNotEnabledException
Thrown if a table should be enabled but is not.
|
class |
TableNotFoundException
Thrown when a table cannot be located.
|
class |
UnknownRegionException
Thrown when we are asked to operate on a region we know nothing about.
|
class |
UnknownScannerException
Thrown if a region server is passed an unknown scanner ID.
|
Modifier and Type | Class and Description |
---|---|
private static class |
ConnectionImplementation.LocalConnectionClosedException
Like
ConnectionClosedException but thrown from the checkClosed call which looks at the
local this.closed flag. |
class |
DoNotRetryRegionException
Similar to RegionException, but disables retries.
|
class |
LockTimeoutException |
class |
NoServerForRegionException
Thrown when no region server can be found for a region
|
class |
RegionOfflineException
Thrown when a table can not be located
|
class |
RowTooBigException
Gets 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 |
CodecException
Thrown when problems in the codec whether setup or context.
|
Modifier and Type | Class and Description |
---|---|
class |
ConstraintException
Exception that a user defined constraint throws on failure of a
Put . |
Modifier and Type | Class and Description |
---|---|
class |
CoprocessorException
Thrown if a coprocessor encounters any exception.
|
Modifier and Type | Class and Description |
---|---|
class |
ConnectionClosedException
Thrown when the connection is closed
|
class |
FailedSanityCheckException
Exception thrown if a mutation fails sanity checks.
|
class |
MasterRegistryFetchException
Exception thrown when an master registry RPC fails in client.
|
class |
MasterStoppedException
Thrown when the master is stopped
|
class |
MergeRegionException
Thrown when something is wrong in trying to merge two regions.
|
class |
OutOfOrderScannerNextException
Thrown by a RegionServer while doing next() calls on a ResultScanner.
|
class |
RequestTooBigException
Thrown when the size of the rpc request received by the server is too large.
|
class |
ScannerResetException
Thrown 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 |
UnknownProtocolException
An error requesting an RPC protocol that the server is not serving.
|
Modifier and Type | Method and Description |
---|---|
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 |
CorruptHFileException
This 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 |
CallCancelledException
Client side call cancelled.
|
class |
CallTimeoutException
Client-side call timeout
|
class |
CellScannerButNoCodecException
Thrown if a cellscanner but no codec to encode it with.
|
class |
EmptyServiceNameException |
class |
FailedServerException
Indicates that we're trying to connect to a already known as dead server.
|
class |
FallbackDisallowedException
Indicate that the rpc server tells client to fallback to simple auth but client is disabled to do
so.
|
class |
FatalConnectionException
Thrown when server finds fatal issue w/ connection setup: e.g.
|
class |
ServerTooBusyException
Throw 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 nn * @return List of plans
|
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) |
Future<byte[]> |
AssignmentManager.balance(RegionPlan regionPlan) |
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 |
---|---|
private BalancerClusterState |
BaseLoadBalancer.createCluster(List<ServerName> servers,
Collection<RegionInfo> regions) |
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 |
ServerCrashException
Passed as Exception by
ServerCrashProcedure notifying 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 |
FailedRemoteDispatchException
Used internally signaling failed queue of a remote procedure operation.
|
class |
NoNodeDispatchException
Used internally signaling failed queue of a remote procedure operation.
|
class |
NoServerDispatchException
Used internally signaling failed queue of a remote procedure operation.
|
class |
NullTargetServerDispatchException
Used 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 |
CorruptedWALProcedureStoreException
Deprecated.
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 |
QuotaExceededException
Generic quota exceeded exception
|
class |
RpcThrottlingException
Describe the throttling result.
|
class |
SpaceLimitingException
An Exception that is thrown when a space quota is in violation.
|
class |
ThrottlingException
Deprecated.
replaced by
RpcThrottlingException since hbase-2.0.0. |
Modifier and Type | Class and Description |
---|---|
class |
LeaseException
Reports a problem with a lease
|
class |
NoSuchColumnFamilyException
Thrown if request for nonexistent column family.
|
static class |
SplitWALCallable.ErrorWALSplitException |
static class |
SplitWALCallable.PreemptedWALSplitException |
static class |
SplitWALCallable.ResignedWALSplitException |
Constructor and Description |
---|
ModifyColumnFamilyStoreFileTrackerProcedure(MasterProcedureEnv env,
TableName tableName,
byte[] family,
String dstSFT) |
ModifyStoreFileTrackerProcedure(MasterProcedureEnv env,
TableName tableName,
String dstSFT) |
ModifyTableStoreFileTrackerProcedure(MasterProcedureEnv env,
TableName tableName,
String dstSFT) |
Modifier and Type | Class and Description |
---|---|
class |
DamagedWALException
Thrown 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 |
AccessDeniedException
Exception thrown by access-related methods.
|
Modifier and Type | Class and Description |
---|---|
class |
InvalidLabelException |
class |
LabelAlreadyExistsException |
Modifier and Type | Class and Description |
---|---|
class |
CorruptedSnapshotException
Exception thrown when the found snapshot info from the filesystem is not valid.
|
class |
ExportSnapshotException
Thrown when a snapshot could not be exported due to an error during the operation.
|
class |
HBaseSnapshotException
General exception base class for when a snapshot fails.
|
class |
RestoreSnapshotException
Thrown when a snapshot could not be restored due to a server-side error when restoring it.
|
class |
SnapshotCreationException
Thrown when a snapshot could not be created due to a server-side error when taking the snapshot.
|
class |
SnapshotDoesNotExistException
Thrown when the server is looking for a snapshot, but can't find the snapshot on the filesystem.
|
class |
SnapshotExistsException
Thrown when a snapshot exists, but should not.
|
class |
UnknownSnapshotException
Exception thrown when we get a request for a snapshot we don't recognize.
|
Modifier and Type | Class and Description |
---|---|
class |
LeaseNotRecoveredException
Thrown when the lease was expected to be recovered, but the file can't be opened.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.