| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.coprocessor | |
| org.apache.hadoop.hbase.exceptions | |
| org.apache.hadoop.hbase.ipc | |
| org.apache.hadoop.hbase.protobuf | Holds classes generated from protobuf
 src/main/protobufdefinition files. | 
| org.apache.hadoop.hbase.quotas | |
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.security | |
| org.apache.hadoop.hbase.security.visibility | |
| org.apache.hadoop.hbase.snapshot | 
| Modifier and Type | Class and Description | 
|---|---|
| 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  | 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 can not 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). | 
| class  | ScannerTimeoutExceptionThrown when a scanner has timed out. | 
| Modifier and Type | Method and Description | 
|---|---|
| Result | RpcRetryingCallerWithReadReplicas. call()
 Algo:
 - we put the query into the execution pool. | 
| static RegionLocations | RegionAdminServiceCallable. getRegionLocations(ClusterConnection connection,
                  TableName tableName,
                  byte[] row,
                  boolean useCache,
                  int replicaId) | 
| 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  | LockTimeoutExceptionThrown when there is a timeout when trying to acquire a lock | 
| class  | MergeRegionExceptionThrown when something is wrong in trying to merge two regions. | 
| class  | OperationConflictExceptionThe exception that is thrown if there's duplicate execution of non-idempotent operation. | 
| class  | OutOfOrderScannerNextExceptionThrown by a RegionServer while doing next() calls on a ResultScanner. | 
| class  | UnknownProtocolExceptionAn error requesting an RPC protocol that the server is not serving. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BadAuthException | 
| class  | FatalConnectionExceptionThrown when server finds fatal issue w/ connection setup: e.g. | 
| class  | UnsupportedCellCodecException | 
| class  | UnsupportedCompressionCodecException | 
| class  | WrongVersionException | 
| Modifier and Type | Method and Description | 
|---|---|
| static String | ProtobufUtil. getRegionEncodedName(org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier regionSpecifier)Find the HRegion encoded name based on a region specifier | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | InvalidQuotaSettingsExceptionGeneric quota exceeded exception for invalid settings | 
| class  | QuotaExceededExceptionGeneric quota exceeded exception | 
| class  | ThrottlingExceptionDescribe the throttling result. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | LeaseExceptionReports a problem with a lease | 
| class  | NoSuchColumnFamilyExceptionThrown if request for nonexistent column family. | 
| 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–2016 The Apache Software Foundation. All rights reserved.