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
HFile and HFile
BlockCache . |
org.apache.hadoop.hbase.ipc | |
org.apache.hadoop.hbase.protobuf |
Holds classes generated from protobuf
src/main/protobuf definition 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 |
InvalidFamilyOperationException
Thrown if a request is table schema modification is requested but
made for an invalid family name.
|
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 |
TableExistsException
Thrown when a table exists but should not
|
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 can not 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 |
---|---|
class |
DoNotRetryRegionException
Similar to RegionException, but disables retries.
|
class |
NoServerForRegionException
Thrown when no region server can be found for a region
|
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 |
ScannerTimeoutException
Thrown 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 |
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 |
FailedSanityCheckException
Exception thrown if a mutation fails sanity checks.
|
class |
LockTimeoutException
Thrown when there is a timeout when trying to acquire a lock
|
class |
MergeRegionException
Thrown when something is wrong in trying to merge two regions.
|
class |
OperationConflictException
The exception that is thrown if there's duplicate execution of non-idempotent operation.
|
class |
OutOfOrderScannerNextException
Thrown by a RegionServer while doing next() calls on a ResultScanner.
|
class |
UnknownProtocolException
An error requesting an RPC protocol that the server is not serving.
|
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 |
EmptyServiceNameException |
class |
FatalConnectionException
Thrown when server finds fatal issue w/ connection setup: e.g.
|
class |
UnknownServiceException |
class |
UnsupportedCellCodecException |
class |
UnsupportedCompressionCodecException |
class |
WrongVersionException |
Modifier and Type | Method and Description |
---|---|
static String |
ProtobufUtil.getRegionEncodedName(HBaseProtos.RegionSpecifier regionSpecifier)
Find the HRegion encoded name based on a region specifier
|
Modifier and Type | Class and Description |
---|---|
class |
InvalidQuotaSettingsException
Generic quota exceeded exception for invalid settings
|
class |
QuotaExceededException
Generic quota exceeded exception
|
class |
ThrottlingException
Describe the throttling result.
|
Modifier and Type | Class and Description |
---|---|
class |
LeaseException
Reports a problem with a lease
|
class |
NoSuchColumnFamilyException
Thrown if request for nonexistent column family.
|
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.
|