程序包 | 说明 |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
Table of Contents
Overview
Example API Usage
Overview
To administer HBase, create and drop tables, list and alter tables,
use
Admin . |
org.apache.hadoop.hbase.coprocessor | |
org.apache.hadoop.hbase.exceptions | |
org.apache.hadoop.hbase.ipc | |
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.shaded.protobuf | |
org.apache.hadoop.hbase.snapshot |
限定符和类型 | 类和说明 |
---|---|
class |
ConcurrentTableModificationException
Thrown when a table has been modified concurrently
|
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 |
ReplicationPeerNotFoundException
Thrown when a replication peer can not be found
|
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.
|
限定符和类型 | 类和说明 |
---|---|
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).
|
限定符和类型 | 方法和说明 |
---|---|
Result |
RpcRetryingCallerWithReadReplicas.call(int operationTimeout)
Algo:
- we put the query into the execution pool
|
static RegionLocations |
RegionAdminServiceCallable.getRegionLocations(ClusterConnection connection,
TableName tableName,
byte[] row,
boolean useCache,
int replicaId) |
限定符和类型 | 类和说明 |
---|---|
class |
CoprocessorException
Thrown if a coprocessor encounters any exception.
|
限定符和类型 | 类和说明 |
---|---|
class |
FailedSanityCheckException
Exception thrown if a mutation fails sanity checks.
|
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 |
UnknownProtocolException
An error requesting an RPC protocol that the server is not serving.
|
限定符和类型 | 类和说明 |
---|---|
class |
BadAuthException |
class |
FatalConnectionException
Thrown when server finds fatal issue w/ connection setup: e.g. bad rpc version
or unsupported auth method.
|
class |
ServerTooBusyException
Throw this in RPC call if there are too many pending requests for one region server
|
class |
StoppedRpcClientException |
class |
UnsupportedCellCodecException |
class |
UnsupportedCompressionCodecException |
class |
UnsupportedCryptoException |
class |
WrongVersionException |
限定符和类型 | 类和说明 |
---|---|
class |
QuotaExceededException
Generic quota exceeded exception
|
class |
ThrottlingException
已过时。
replaced by
RpcThrottlingException since hbase-2.0.0. |
限定符和类型 | 类和说明 |
---|---|
class |
LeaseException
Reports a problem with a lease
|
class |
NoSuchColumnFamilyException
Thrown if request for nonexistent column family.
|
限定符和类型 | 类和说明 |
---|---|
class |
AccessDeniedException
Exception thrown by access-related methods.
|
限定符和类型 | 类和说明 |
---|---|
class |
InvalidLabelException |
class |
LabelAlreadyExistsException |
限定符和类型 | 方法和说明 |
---|---|
static String |
ProtobufUtil.getRegionEncodedName(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionSpecifier regionSpecifier)
Find the HRegion encoded name based on a region specifier
|
限定符和类型 | 类和说明 |
---|---|
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.
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.