| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.constraint | Restrict the domain of a data attribute, often times to fulfill business rules/requirements. | 
| org.apache.hadoop.hbase.coprocessor | Table of Contents | 
| org.apache.hadoop.hbase.exceptions | |
| org.apache.hadoop.hbase.io.hfile | Provides implementations of  HFileand HFileBlockCache. | 
| org.apache.hadoop.hbase.ipc | Tools to help define network clients and servers. | 
| org.apache.hadoop.hbase.master.replication | |
| org.apache.hadoop.hbase.quotas | |
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.rsgroup | |
| org.apache.hadoop.hbase.security | |
| org.apache.hadoop.hbase.security.visibility | |
| org.apache.hadoop.hbase.snapshot | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ConcurrentTableModificationExceptionThrown when a table has been modified concurrently | 
| class  | InvalidFamilyOperationExceptionThrown if a request is table schema modification is requested but
 made for an invalid family name. | 
| 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  | ReplicationPeerNotFoundExceptionThrown when a replication peer can not be found | 
| class  | TableExistsExceptionThrown when a table exists but should not. | 
| 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  | NoServerForRegionExceptionThrown when no region server can be found for a region | 
| 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). | 
| Modifier and Type | Method and Description | 
|---|---|
| private void | ClientScanner. handleScanError(DoNotRetryIOException e,
               org.apache.commons.lang3.mutable.MutableBoolean retryAfterOutOfOrderException,
               int retriesLeft) | 
| Modifier and Type | Method and Description | 
|---|---|
| Result | RpcRetryingCallerWithReadReplicas. call(int operationTimeout)
 Algo:
 - we put the query into the execution pool. | 
| private void | ConnectionImplementation. checkClosed() | 
| (package private) static RegionLocations | RpcRetryingCallerWithReadReplicas. getRegionLocations(boolean useCache,
                  int replicaId,
                  ClusterConnection cConnection,
                  TableName tableName,
                  byte[] row) | 
| static RegionLocations | RegionAdminServiceCallable. getRegionLocations(ClusterConnection connection,
                  TableName tableName,
                  byte[] row,
                  boolean useCache,
                  int replicaId) | 
| private void | ClientScanner. handleScanError(DoNotRetryIOException e,
               org.apache.commons.lang3.mutable.MutableBoolean retryAfterOutOfOrderException,
               int retriesLeft) | 
| (package private) static void | RpcRetryingCallerWithReadReplicas. throwEnrichedException(ExecutionException e,
                      int retries)Extract the real exception from the ExecutionException, and throws what makes more
 sense. | 
| (package private) static Throwable | RpcRetryingCallerImpl. translateException(Throwable t)Get the good or the remote exception if any, throws the DoNotRetryIOException. | 
| 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  | FailedSanityCheckExceptionException thrown if a mutation fails sanity checks. | 
| 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  | UnknownProtocolExceptionAn error requesting an RPC protocol that the server is not serving. | 
| 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  | EmptyServiceNameException | 
| 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 | Method and Description | 
|---|---|
| private void | ReplicationPeerManager. checkClusterId(String clusterKey) | 
| private void | ReplicationPeerManager. checkClusterKey(String clusterKey) | 
| private void | ReplicationPeerManager. checkConfiguredWALEntryFilters(ReplicationPeerConfig peerConfig) | 
| private void | ReplicationPeerManager. checkNamespacesAndTableCfsConfigConflict(Set<String> namespaces,
                                        Map<TableName,? extends Collection<String>> tableCfs)Set a namespace in the peer config means that all tables in this namespace will be replicated
 to the peer cluster. | 
| private void | ReplicationPeerManager. checkPeerConfig(ReplicationPeerConfig peerConfig) | 
| private ReplicationPeerDescription | ReplicationPeerManager. checkPeerExists(String peerId) | 
| private void | ReplicationPeerManager. checkQueuesDeleted(String peerId) | 
| (package private) void | ReplicationPeerManager. preAddPeer(String peerId,
          ReplicationPeerConfig peerConfig) | 
| (package private) void | ReplicationPeerManager. preDisablePeer(String peerId) | 
| (package private) void | ReplicationPeerManager. preEnablePeer(String peerId) | 
| (package private) ReplicationPeerConfig | ReplicationPeerManager. preRemovePeer(String peerId) | 
| (package private) ReplicationPeerDescription | ReplicationPeerManager. preUpdatePeerConfig(String peerId,
                   ReplicationPeerConfig peerConfig)Return the old peer description. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | QuotaExceededExceptionGeneric quota exceeded exception | 
| 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. | 
| Modifier and Type | Method and Description | 
|---|---|
| private void | HRegion. checkMutationType(Mutation mutation) | 
| private void | HRegion. checkRow(Row action,
        byte[] row) | 
| private static long | HRegion.MutationBatchOperation. getLongValue(Cell cell) | 
| Modifier and Type | Method and Description | 
|---|---|
| private RSGroupInfo | RSGroupInfoManagerImpl. getRSGroupInfo(String groupName) | 
| 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. | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.