Uses of Package
org.apache.hadoop.hbase.client
Package
Description
Provides HBase Client
Table of Contents
Provides implementations of
HFile
and HFile
BlockCache
.Tools to help define network clients and servers.
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Multi Cluster Replication
HBase REST
Provides an HBase Thrift
service.
-
ClassDescriptionThe administrative API for HBase.This is the low level API for asynchronous scan.The asynchronous connection for internal usage.The asynchronous version of Connection.The interface for asynchronous version of Table.An ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.POJO representing the compaction stateA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Define the necessary method for carrying
ClientMetaService
.Used to perform Delete operations on a single row.Similar to RegionException, but disables retries.Enum describing the durability guarantees for tables andMutation
s Note that the items must be sorted in order of increasing durabilityUsed to perform Get operations on a single row.Hbck fixup tool APIs.Used to perform Put operations for a single row.Information about a region.Used to view region location information for a single HBase table.Single row result of aGet
orScan
query.Used to perform Scan operations.Used to communicate with a single HBase table.TableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc...Convenience class for composing an instance ofTableDescriptor
.Represents table state. -
ClassDescriptionA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Information about a region.
-
ClassDescriptionHelper class for custom client scanners.A Get, Put, Increment, Append, or Delete associated with it's region.The administrative API for HBase.This is the low level API for asynchronous scan.Used to suspend or stop a scan, or get a scan cursor if available.Used to resume a scan.Performs Append operations on a single row.The asynchronous administrative API for HBase.For creating
AsyncAdmin
.Used to communicate with a single HBase table in batches.For creatingAsyncBufferedMutator
.The asynchronous connection for internal usage.The asynchronous version of Connection.The implementation of AsyncConnection.A simple wrapper of theAdminProtos.AdminService
for a region server, which returns aCompletableFuture
.The interface for asynchronous version of Table.Deprecated.Since 3.0.0, will be removed in 4.0.0.Deprecated.Since 3.0.0, will be removed in 4.0.0.The callback when we want to execute a coprocessor call on a range of regions.Helper class for sending coprocessorService request that executes a coprocessor call on regions which are covered by a range.Some coprocessors may support the idea of "partial results." If for some reason a coprocessor cannot return all results for a given region in a single response, the client side can be designed to recognize this and continuing requesting more results until they are completely accumulated in the client.For creatingAsyncTable
.The asynchronous version of RegionLocator.History of balancer decisions taken for region movements.Encapsulates options for executing a run of the Balancer.Builder for constructing aBalanceRequest
Response returned from a balancer invocationUsed in HMaster to build aBalanceResponse
for returning results of a balance invocation to callersHistory of detail information that balancer movements was rejectedUsed to communicate with a single HBase table similar toTable
but meant for batched, asynchronous puts.Listens for asynchronous exceptions on aBufferedMutator
.Parameters for instantiating aBufferedMutator
.Used to perform CheckAndMutate operations.A builder class for building a CheckAndMutate object.Represents a result of a CheckAndMutate operationAn ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.POJO representing the compaction stateCurrently, there are only two compact types:NORMAL
means do store files compaction;MOB
means do mob files compaction.A cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Registry for meta information needed for connection setup to a HBase cluster.Define the necessary method for carryingClientMetaService
.For creating differentConnectionRegistry
implementation.Consistency defines the expected consistency level for an operation.CoprocessorDescriptor contains the details about how to build a coprocessor.Used to build theCoprocessorDescriptor
Scan cursor to tell client where server is scanningScan.setNeedCursorResult(boolean)
Result.isCursor()
Result.getCursor()
Used to perform Delete operations on a single row.Similar to RegionException, but disables retries.Enum describing the durability guarantees for tables andMutation
s Note that the items must be sorted in order of increasing durabilityUsed to perform Get operations on a single row.Hbck fixup tool APIs.Used to perform Increment operations on a single row.Specify Isolation levels in Scan operations.Abstract response class representing online logs response from ring-buffer use-cases e.g slow/large RPC logs, balancer decision logsDeprecated.as of 2.4.0.Deprecated.Deprecated.Represents the master switch typeA container class for collecting details about the RPC call as it percolates.Enum describing the mob compact partition policy types.NonceGenerator interface.A collection of criteria used for table selection.Used to instantiate an instance ofNormalizeTableFilterParams
.Slow/Large Log payload for hbase-client, to be used by Admin API get_slow_responses and get_large_responsesSuperclass for any type that maps to a potentially application-level query.NonceGenerator implementation that uses client ID hash + random int as nonce group, and random numbers as nonces.Used to perform Put operations for a single row.Base class for HBase read operations; e.g.Information about a region.POJO representing region server loadUsed to view region location information for a single HBase table.An interface for client request scheduling algorithm.Picks up the valid data.Single row result of aGet
orScan
query.Interface for client-side scanning.Exception thrown by HTable methods when an attempt to do something (like commit changes) fails after a bunch of retries.Data structure that allows adding more info around Throwable incident.This subclass ofRetriesExhaustedException
is thrown when we have more information about which rows were causing which exceptions on what servers.Has a row.Performs multiple mutations atomically on a single row.Used to perform Scan operations.ReceivesResult
for an asynchronous scan.The base interface for scan result consumer.Tracks the statistics for multiple regionsSelect server type i.e destination for RPC request associated with ring buffer.Delegate to a protobuf rpc call.The POJO equivalent of HBaseProtos.SnapshotDescriptionPOJO representing the snapshot typeParent interface for an object to get updates about per-region statistics.Used to communicate with a single HBase table.Deprecated.Since 3.0.0, will be removed in 4.0.0.Deprecated.Since 3.0.0, will be removed in 4.0.0.For creatingTable
instance.TableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc...Convenience class for composing an instance ofTableDescriptor
.Represents table state.We intend to use the local version for service call shortcut(s), so we use an interface compatible with a typical service call, with 2 args, return type, and an exception type. -
-
ClassDescriptionA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Used to communicate with a single HBase table.
-
-
ClassDescriptionThe implementation of AsyncConnection.Has a row.Performs multiple mutations atomically on a single row.Used to perform Scan operations.
-
ClassDescriptionPerforms Append operations on a single row.Encapsulates options for executing a run of the Balancer.Response returned from a balancer invocationUsed to perform CheckAndMutate operations.Represents a result of a CheckAndMutate operationA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Used to perform Delete operations on a single row.Enum describing the durability guarantees for tables and
Mutation
s Note that the items must be sorted in order of increasing durabilityUsed to perform Get operations on a single row.Used to perform Increment operations on a single row.Represents the master switch typeUsed to perform Put operations for a single row.Information about a region.Single row result of aGet
orScan
query.Used to perform Scan operations.The POJO equivalent of HBaseProtos.SnapshotDescriptionTableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc... -
-
ClassDescriptionA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Information about a region.
-
-
-
ClassDescriptionAn ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.
-
ClassDescriptionThis class is for maintaining the various connection statistics and publishing them through the metrics interfaces.Information about a region.
-
ClassDescriptionA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Used to perform Put operations for a single row.Information about a region.Single row result of a
Get
orScan
query.Used to perform Scan operations.Used to communicate with a single HBase table.TableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc... -
ClassDescriptionThe administrative API for HBase.A client scanner for a region opened for read-only on the client side.A cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Used to perform Delete operations on a single row.Used to perform Put operations for a single row.Information about a region.Used to view region location information for a single HBase table.Single row result of a
Get
orScan
query.Used to perform Scan operations.Used to communicate with a single HBase table.TableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc... -
ClassDescriptionThe asynchronous connection for internal usage.Encapsulates options for executing a run of the Balancer.Response returned from a balancer invocationAn ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.POJO representing the compaction stateA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Define the necessary method for carrying
ClientMetaService
.Represents the master switch typeA collection of criteria used for table selection.Information about a region.The POJO equivalent of HBaseProtos.SnapshotDescriptionTableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc...Represents table state.We intend to use the local version for service call shortcut(s), so we use an interface compatible with a typical service call, with 2 args, return type, and an exception type. -
ClassDescriptionThe administrative API for HBase.An ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.Information about a region.Used to perform Scan operations.TableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,
hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc... -
-
ClassDescriptionHistory of balancer decisions taken for region movements.History of detail information that balancer movements was rejectedA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.
-
ClassDescriptionA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.
-
-
ClassDescriptionA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Used to perform Get operations on a single row.Information about a region.Single row result of a
Get
orScan
query.Used to perform Scan operations.TableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc... -
-
ClassDescriptionPerforms Append operations on a single row.The asynchronous connection for internal usage.Used to perform CheckAndMutate operations.Represents a result of a CheckAndMutate operationAn ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.POJO representing the compaction stateDefine the necessary method for carrying
ClientMetaService
.Used to perform Delete operations on a single row.Similar to RegionException, but disables retries.Used to perform Get operations on a single row.Used to perform Increment operations on a single row.Specify Isolation levels in Scan operations.Superclass for any type that maps to a potentially application-level query.Used to perform Put operations for a single row.Base class for HBase read operations; e.g.Information about a region.Single row result of aGet
orScan
query.Performs multiple mutations atomically on a single row.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).Used to perform Scan operations.TableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc... -
-
ClassDescriptionThe asynchronous connection for internal usage.Information about a region.TableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,
hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc... -
ClassDescriptionAn ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.TableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,
hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc...Convenience class for composing an instance ofTableDescriptor
. -
-
ClassDescriptionThe asynchronous connection for internal usage.A simple wrapper of the
AdminProtos.AdminService
for a region server, which returns aCompletableFuture
.A cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Used to perform Put operations for a single row.Information about a region.Single row result of aGet
orScan
query.TableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc... -
ClassDescriptionSingle row result of a
Get
orScan
query.Interface for client-side scanning. -
ClassDescriptionEncapsulates options for executing a run of the Balancer.Response returned from a balancer invocationA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Information about a region.TableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,
hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc... -
ClassDescriptionAn ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.
-
ClassDescriptionA Get, Put, Increment, Append, or Delete associated with it's region.Performs Append operations on a single row.Encapsulates options for executing a run of the Balancer.Response returned from a balancer invocationUsed to perform CheckAndMutate operations.Represents a result of a CheckAndMutate operationAn ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.POJO representing the compaction stateConsistency defines the expected consistency level for an operation.Scan cursor to tell client where server is scanning
Scan.setNeedCursorResult(boolean)
Result.isCursor()
Result.getCursor()
Used to perform Delete operations on a single row.Enum describing the durability guarantees for tables andMutation
s Note that the items must be sorted in order of increasing durabilityUsed to perform Get operations on a single row.Used to perform Increment operations on a single row.Abstract response class representing online logs response from ring-buffer use-cases e.g slow/large RPC logs, balancer decision logsRepresents the master switch typeA container for Result objects, grouped by regionName.A collection of criteria used for table selection.Used to perform Put operations for a single row.Information about a region.POJO representing region server loadSingle row result of aGet
orScan
query.Performs multiple mutations atomically on a single row.Used to perform Scan operations.Class for single action responseSlowLog params object that contains detailed info as params and region name : to be used for filter purposeThe POJO equivalent of HBaseProtos.SnapshotDescriptionPOJO representing the snapshot typeTableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc...Represents table state. -
ClassDescriptionA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.
-
ClassDescriptionA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Information about a region.The POJO equivalent of HBaseProtos.SnapshotDescriptionTableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,
hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc... -
-
ClassDescriptionThe administrative API for HBase.Performs Append operations on a single row.An ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.Used to perform Increment operations on a single row.Single row result of a
Get
orScan
query.Interface for client-side scanning.Used to communicate with a single HBase table. -
-
ClassDescriptionThe administrative API for HBase.An ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.A cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Enum describing the durability guarantees for tables and
Mutation
s Note that the items must be sorted in order of increasing durabilityUsed to perform Get operations on a single row.Used to perform Put operations for a single row.Information about a region.Used to view region location information for a single HBase table.Utility methods which contain the logic for regions and replicas.Single row result of aGet
orScan
query.Used to communicate with a single HBase table.TableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc... -
ClassDescriptionA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Information about a region.TableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table,
hbase:meta
, if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc... -
ClassDescriptionA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.
-
ClassDescriptionEnum describing the durability guarantees for tables and
Mutation
s Note that the items must be sorted in order of increasing durabilityInformation about a region.