Uses of Package
org.apache.hadoop.hbase.client
Package
Description
Provides HBase Client
Restrict the domain of a data attribute, often times to fulfill business rules/requirements.
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.
The Region Normalizer subsystem is responsible for coaxing all the regions in a table toward
a "normal" size, according to their storefile size.
HBase REST
Provides an HBase Thrift
service.
Provides an HBase Thrift
service.
This package provides fully-functional exemplar Java code demonstrating
simple usage of the hbase-client API, for incorporation into a Maven
archetype with hbase-client dependency.
This package provides fully-functional exemplar Java code demonstrating
simple usage of the hbase-client API, for incorporation into a Maven
archetype with hbase-shaded-client dependency.
-
ClassDescriptionThe 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.The interface for asynchronous version of Table.Used to communicate with a single HBase table similar to
Table
but meant for batched, asynchronous puts.Parameters for instantiating aBufferedMutator
.Internal methods on Connection that should not be used by user code.An ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.An ModifyableFamilyDescriptor 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.CoprocessorDescriptor contains the details about how to build a coprocessor.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.Enum describing the mob compact partition policy types.Used to perform Put operations for a single row.Information about a region.Used to view region location information for a single HBase table.Used to perform Scan operations.The base interface for scan result consumer.Used to communicate with a single HBase table.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...TODO: make this private after removing the HTableDescriptorRepresents table state. -
ClassDescriptionA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Information about a region.
-
ClassDescriptionInternal methods on Connection that should not be used by user code.A cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.
-
ClassDescriptionThe administrative API for HBase.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 Get operations on a single row.Used to perform Put operations for a single row.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... -
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.
-
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... -
ClassDescriptionHelper class for custom client scanners.This class is used to extend AP to process single action request, like delete, get etc.Base class for rpc based connection registry implementation.For describing the actual asynchronous rpc call.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
.Base class for all asynchronous admin builders.Retry caller for batch.Used to communicate with a single HBase table in batches.For creatingAsyncBufferedMutator
.The asynchronous version of Connection.Timeout configs.The implementation of AsyncConnection.Retry caller for a request call to master.The asynchronous locator for meta region.The asynchronous locator for regions other than meta.This class allows a continuous flow of requests.Contains the attributes of a task which will be executed byAsyncProcess
.The number of processed rows.Cache of RegionLocations for use byAsyncNonMetaRegionLocator
.The asynchronous region locator.The context used to wait for results from one submit call.The context, and return value, for a single submit/submitAll call.Sync point for calls to multiple replicas for the same user request (Get).Runnable (that can be submitted to thread pool) that submits MultiAction to a single server.Factory to create an AsyncRpcRetryCaller.Retry caller for scanning a region.Retry caller for a request call to region server.Retry caller for a single request, such as get, put, delete, etc.The interface for asynchronous version of Table.Deprecated.Since 2.4.0, will be removed in 4.0.0.Deprecated.Since 2.4.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.For creatingAsyncTable
.Base class for all asynchronous table builders.The asynchronous version of RegionLocator.TheResultScanner
implementation forRawAsyncTableImpl
.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
.This should be implemented by the Get/Scan implementations that talk to replica regions.This class is used to unify HTable calls with AsyncProcess Framework.A Catalog replica selector decides which catalog replica to go for read requests when it is configured as CatalogReplicaMode.LoadBalance.CatalogReplicaLoadBalanceReplicaSimpleSelector implements a simple catalog replica load balancing algorithm.StaleLocationCacheEntry is the entry when a stale location is reported by an client.Used to perform CheckAndMutate operations.A builder class for building a CheckAndMutate object.Represents a result of a CheckAndMutate operationImplements the scanner interface for the HBase client.A RegionServerCallable set to use the Client protocol.A client scanner for a region opened for read-only on the client side.ClientSimpleScanner implements a sync scanner behaviour.Internal methods on Connection that should not be used by user code.A class that receives the cluster status, and provide it as a set of service to the client.Class to be extended to manage a new dead server.The interface to be implemented by a listener of a cluster status event.An ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.An ModifyableFamilyDescriptor 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.Configuration parameters for the connection.Main implementation ofConnection
andClusterConnection
interfaces.LikeConnectionClosedException
but thrown from the checkClosed call which looks at the local this.closed flag.State of the MasterService connection/setup.The record of errors for servers.The record of errors for a server.Registry for meta information needed for connection setup to a HBase cluster.A class for creatingRpcClient
and related stubs used byAbstractRpcBasedConnectionRegistry
.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 durabilityKeeps track of repeated failures to any region server.Used to perform Get operations on a single row.HBaseAdmin is no longer a client API.Future that waits on a procedure result.Hbck fixup tool APIs.An implementation ofRegionLocator
.Deprecated.since 2.2.0, will be removed in 3.0.0, without replacement.Deprecated.Helper to count the average over an interval until reset.Deprecated.Deprecated.since 2.2.0, will be removed in 3.0.0, without replacement.Deprecated.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.A RetryingCallable for Master RPC operations.A KeepAlive connection is not physically closed immediately after the close, but rather kept alive for a few minutes.Represents the master switch typeA cache implementation for region locations from meta.This class is for maintaining the various connection statistics and publishing them through the metrics interfaces.A container class for collecting details about the RPC call as it percolates.A lambda for dispatching to the appropriate metric factory methodEnum describing the mob compact partition policy types.Container for Actions (i.e.A container for Result objects, grouped by regionName.Callable that handles themulti
method call going against a single regionserver; i.e.An implementation of RegionInfo that adds mutable methods so can build a RegionInfo instance.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.The implementation of AsyncAdmin.The implementation of RawAsyncTable.Similar to RegionServerCallable but for the AdminService interface.Information about a region.POJO representing region server loadIndicate which row you want to locate.Used to view region location information for a single HBase table.Implementations make a RPC call against a RegionService via a protobuf Service.Thread safe utility that keeps registry end points used byConnectionRegistry
up to date.An interface for client request scheduling algorithm.Picks up the valid data.A completion service for the RpcRetryingCallerFactory.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.A Callable<T> that will be retried.This class is designed to fit into the RetryingCaller class which forms the central piece of intelligence for the client side retries for most calls.The context object used in theRpcRetryingCaller
to enableRetryingCallerInterceptor
to intercept calls.Tracks the amount of time remaining for an operation.A reversed ScannerCallable which supports backward scanning.Has a row.Provide a way to access the inner buffer.Performs multiple mutations atomically on a single row.Factory to create anRpcRetryingCaller
Used to perform Scan operations.Scanner operations such as create, next, etc.This class has the logic for handling scanners for regions with and without replicas.Used to separate the row constructing logic.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.Provide a way to control the flow of rows iteration.The POJO equivalent of HBaseProtos.SnapshotDescriptionPOJO representing the snapshot typeParent interface for an object to get updates about per-region statistics.Base class which provides clients with an RPC connection to call coprocessor endpointService
s.Used to communicate with a single HBase table.Deprecated.Since 2.4.0, will be removed in 4.0.0.Deprecated.Since 2.4.0, will be removed in 4.0.0.For creatingTable
instance.Base class for all table builders.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
.TODO: make this private after removing the HTableDescriptorRepresents table state.Deprecated. -
-
ClassDescriptionThe asynchronous version of Connection.A cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.Used to communicate with a single HBase table.
-
-
ClassDescriptionThe administrative API for HBase.A cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.
-
ClassDescriptionThe implementation of AsyncConnection.Used to perform CheckAndMutate operations.Internal methods on Connection that should not be used by user code.Has a row.Performs multiple mutations atomically on a single row.Used to perform Scan operations.
-
ClassDescriptionEnum describing the durability guarantees for tables and
Mutation
s Note that the items must be sorted in order of increasing durabilityUsed to perform Put operations for a single row.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.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.Has a row.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... -
ClassDescriptionUsed to perform Delete operations on a single row.Used to perform Get operations on a single row.Used to perform Increment operations on a single row.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... -
-
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.
-
ClassDescriptionTableDescriptor 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 cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.
-
-
-
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.A container class for collecting details about the RPC call as it percolates.Information about a region.
-
ClassDescriptionUsed to communicate with a single HBase table similar to
Table
but meant for batched, asynchronous puts.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.Used to view region location information for a single HBase table.Interface for client-side scanning.Used to perform Scan operations.Used to communicate with a single HBase table. -
ClassDescriptionThe administrative API for HBase.Used to communicate with a single HBase table similar to
Table
but meant for batched, asynchronous puts.A client scanner for a region opened for read-only on the client side.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.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 Put operations for a single row.Information about a region.Used to view region location information for a single HBase table.Interface for client-side scanning.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... -
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.Interface for client-side scanning.Used to perform Scan operations.Used to communicate with a single HBase table.
-
ClassDescriptionEncapsulates options for executing a run of the Balancer.Response returned from a balancer invocationInternal methods on Connection that should not be used by user code.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.Represents the master switch typeA collection of criteria used for table selection.NonceGenerator implementation that uses client ID hash + random int as nonce group, and random numbers as nonces.Information about a region.The POJO equivalent of HBaseProtos.SnapshotDescriptionUsed 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...Represents table state. -
ClassDescriptionUsed to perform Delete operations on a single row.Similar to RegionException, but disables retries.Used to perform Put operations for a single row.Information about a region.Interface for client-side scanning.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... -
ClassDescriptionInformation 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.
-
ClassDescriptionThe administrative API for HBase.The asynchronous administrative API for HBase.The asynchronous version of Connection.Information about a region.Interface for client-side scanning.Used to perform Scan operations.
-
ClassDescriptionA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.
-
-
ClassDescriptionInformation about a region.
-
-
ClassDescriptionRepresents the master switch typeInformation 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.Similar to RegionException, but disables retries.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... -
ClassDescriptionUsed to perform Get operations on a single row.Information about a region.Interface for client-side scanning.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... -
-
ClassDescriptionInformation 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... -
-
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.Used to perform Put operations for a single row.
-
ClassDescriptionA cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.
-
-
-
ClassDescriptionThe administrative API for HBase.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 Get operations on a single row.Used to perform Put operations for a single row.Information about a region.Interface for client-side scanning.Used to perform Scan operations.Used to communicate with a single HBase table.
-
-
ClassDescriptionPerforms Append operations on a single row.Used to perform CheckAndMutate operations.Represents a result of a CheckAndMutate operationInternal methods on Connection that should not be used by user code.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.Used to perform Delete operations on a single row.Similar to RegionException, but disables retries.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.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.Has a row.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).Factory to create anRpcRetryingCaller
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... -
ClassDescriptionInternal methods on Connection that should not be used by user code.Information about a region.Factory to create an
RpcRetryingCaller
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 version of Connection.Internal methods on Connection that should not be used by user code.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.Similar to RegionServerCallable but for the AdminService interface.Information about a region.Used to view region location information for a single HBase table.A Callable<T> that will be retried.Has a row.Factory to create an
RpcRetryingCaller
Used to communicate with a single HBase table. -
-
-
ClassDescriptionThe administrative API for HBase.Encapsulates 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.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... -
ClassDescriptionAn ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.
-
ClassDescriptionThe administrative API for HBase.Performs Append operations on a single row.Encapsulates options for executing a run of the Balancer.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.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.Base class for HBase read operations; e.g.Information about a region.Used to perform Scan operations.The POJO equivalent of HBaseProtos.SnapshotDescriptionUsed 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.
-
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.Represents the master switch typeUsed 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... -
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.
-
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.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... -
-
ClassDescriptionThe administrative API for HBase.Performs Append operations on a single row.Used to perform Increment operations on a single row.Interface for client-side scanning.Used to communicate with a single HBase table.
-
ClassDescriptionPerforms Append operations on a single row.An ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.Consistency defines the expected consistency level for an operation.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.Deprecated.as of 2.4.0.Deprecated.Deprecated.Slow/Large Log payload for hbase-client, to be used by Admin API get_slow_responses and get_large_responsesUsed to perform Put operations for a single row.Used to view region location information for a single HBase table.Interface for client-side scanning.Performs multiple mutations atomically on a single row.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.Performs Append operations on a single row.Encapsulates options for executing a run of the Balancer.Response returned from a balancer invocationUsed to communicate with a single HBase table similar to
Table
but meant for batched, asynchronous puts.Parameters for instantiating aBufferedMutator
.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 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.Used to perform Delete operations on a single row.Used 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 logsDeprecated.as of 2.4.0.A collection of criteria used for table selection.Slow/Large Log payload for hbase-client, to be used by Admin API get_slow_responses and get_large_responsesUsed to perform Put operations for a single row.Information about a region.Used to view region location information for a single HBase table.Interface for client-side scanning.Has a row.Performs multiple mutations atomically on a single row.Used to perform Scan operations.Select server type i.e destination for RPC request associated with ring buffer.The POJO equivalent of HBaseProtos.SnapshotDescriptionPOJO representing the snapshot typeUsed to communicate with a single HBase table.Deprecated.Since 2.4.0, will be removed in 4.0.0.Deprecated.Since 2.4.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... -
ClassDescriptionThe administrative API for HBase.A RegionServerCallable set to use the Client protocol.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.Information about a region.Used to view region location information for a single HBase table.Client proxy for SecureBulkLoadProtocolUsed 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.Internal methods on Connection that should not be used by user code.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.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.Has a row.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. -
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.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... -
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. -
-