Interface | Description |
---|---|
Abortable |
Interface to support the aborting of a given server or client.
|
ClusterMetrics |
Metrics information on the HBase cluster.
|
Coprocessor |
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
RegionServerCoprocessor, and WALCoprocessor.
|
CoprocessorEnvironment<C extends Coprocessor> |
Coprocessor environment state.
|
MetaTableAccessor.CloseableVisitor |
Implementations 'visit' a catalog table row but with close() at the end.
|
MetaTableAccessor.Visitor |
Implementations 'visit' a catalog table row.
|
RegionMetrics |
Encapsulates per-region load metrics.
|
ServerMetrics |
This class is used for exporting current state of load on a RegionServer.
|
UserMetrics |
Encapsulates per-user load metrics.
|
UserMetrics.ClientMetrics |
Class | Description |
---|---|
AsyncMetaTableAccessor |
The asynchronous meta table accessor.
|
CacheEvictionStats | |
CacheEvictionStatsAggregator |
Used to merge CacheEvictionStats.
|
CacheEvictionStatsBuilder | |
ClusterId |
The identifier for this cluster.
|
ClusterMetricsBuilder | |
ClusterStatus | Deprecated
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
ClusterMetrics
instead. |
HColumnDescriptor | Deprecated |
HRegionInfo | Deprecated
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
HRegionLocation |
Data structure to hold RegionInfo and the address for the hosting HRegionServer.
|
HTableDescriptor | Deprecated
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
MetaTableAccessor |
Read/write operations on
hbase:meta region as well as assignment information stored
to hbase:meta . |
MetaTableAccessor.DefaultVisitorBase |
A Visitor that skips offline regions and split parents
|
MetaTableAccessor.ReplicationBarrierResult | |
MetaTableAccessor.TableVisitorBase |
A Visitor for a table.
|
RegionLoad | Deprecated
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
RegionMetrics
instead. |
RegionLocations |
Container for holding a list of
HRegionLocation 's that correspond to the same range. |
RegionMetricsBuilder | |
RSGroupTableAccessor |
Read rs group information from
hbase:rsgroup . |
ServerLoad | Deprecated
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
ServerMetrics
instead. |
ServerMetricsBuilder | |
Size |
It is used to represent the size with different units.
|
UserMetricsBuilder | |
UserMetricsBuilder.ClientMetricsImpl |
Enum | Description |
---|---|
CatalogReplicaMode |
There are two modes with catalog replica support.
|
ClusterMetrics.Option |
Kinds of ClusterMetrics
|
CompareOperator |
Generic set of comparison operators.
|
Coprocessor.State |
Lifecycle state of a given coprocessor instance.
|
KeepDeletedCells |
Ways to keep cells marked for delete around.
|
MemoryCompactionPolicy |
Enum describing all possible memory compaction policies
|
MetaTableAccessor.QueryType | |
Size.Unit |
Exception | Description |
---|---|
CallDroppedException |
Returned to the clients when their request was discarded due to server being overloaded.
|
CallQueueTooBigException | |
ClockOutOfSyncException |
This exception is thrown by the master when a region server clock skew is too high.
|
ConcurrentTableModificationException |
Thrown when a table has been modified concurrently
|
DoNotRetryIOException |
Subclass if exception is not meant to be retried: e.g.
|
DroppedSnapshotException |
Thrown during flush if the possibility snapshot content was not properly persisted into store
files.
|
FailedCloseWALAfterInitializedErrorException |
Throw when failed cleanup unsuccessful initialized wal
|
InvalidFamilyOperationException |
Thrown if a request is table schema modification is requested but made for an invalid family
name.
|
MasterNotRunningException |
Thrown if the master is not running
|
MultiActionResultTooLarge |
Exception thrown when the result needs to be chunked on the server side.
|
NamespaceExistException |
Thrown when a namespace exists but should not
|
NamespaceNotFoundException |
Thrown when a namespace can not be located
|
NotAllMetaRegionsOnlineException |
Thrown when an operation requires the root and all meta regions to be online
|
NotServingRegionException |
Thrown by a region server if it is sent a request for a region it is not serving.
|
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.
|
PleaseRestartMasterException |
Thrown if the master requires restart.
|
RegionException |
Thrown when something happens related to region handling.
|
RegionTooBusyException |
Thrown by a region server if it will block and wait to serve a request.
|
ReplicationPeerNotFoundException |
Thrown when a replication peer can not be found
|
RetryImmediatelyException | |
TableExistsException |
Thrown when a table exists but should not.
|
TableInfoMissingException |
Failed to find
.tableinfo file under the table directory. |
TableNotDisabledException |
Thrown if a table should be offline but is not.
|
TableNotEnabledException |
Thrown if a table should be enabled but is not.
|
TableNotFoundException |
Thrown when a table cannot be located.
|
UnknownRegionException |
Thrown when we are asked to operate on a region we know nothing about.
|
UnknownScannerException |
Thrown if a region server is passed an unknown scanner ID.
|
ZooKeeperConnectionException |
Thrown if the client can't connect to ZooKeeper.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.