Class and Description |
---|
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
Delete
Used to perform Delete operations on a single row.
|
DoNotRetryRegionException
Similar to RegionException, but disables retries.
|
Durability
Enum describing the durability guarantees for tables and
Mutation s
Note that the items must be sorted in order of increasing durability |
Get
Used to perform Get operations on a single row.
|
HConnection
Deprecated.
in favor of
Connection and ConnectionFactory |
HTableInterface
Deprecated.
use
Table instead |
Mutation |
Put
Used to perform Put operations for a single row.
|
Result |
Scan
Used to perform Scan operations.
|
Table
Used to communicate with a single HBase table.
|
Class and Description |
---|
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
HConnection
Deprecated.
in favor of
Connection and ConnectionFactory |
Class and Description |
---|
AbstractClientScanner
Helper class for custom client scanners.
|
Action
A Get, Put, Increment, Append, or Delete associated with it's region.
|
Admin
The administrative API for HBase.
|
Append
Performs Append operations on a single row.
|
AsyncProcess
This class allows a continuous flow of requests.
|
AsyncProcess.AsyncRequestFuture
The context used to wait for results from one submit call.
|
AsyncProcess.AsyncRequestFutureImpl
The context, and return value, for a single submit/submitAll call.
|
AsyncProcess.BatchErrors |
AsyncProcess.ReplicaResultState
Sync point for calls to multiple replicas for the same user request (Get).
|
AsyncProcess.Retry
For manageError.
|
Attributes |
BufferedMutator
Used to communicate with a single HBase table similar to
Table but meant for
batched, asynchronous puts. |
BufferedMutator.ExceptionListener
Listens for asynchronous exceptions on a
BufferedMutator . |
BufferedMutatorImpl
Used to communicate with a single HBase table similar to
HTable
but meant for batched, potentially asynchronous puts. |
BufferedMutatorParams
Parameters for instantiating a
BufferedMutator . |
Cancellable
This should be implemented by the Get/Scan implementations that
talk to replica regions.
|
ClientScanner
Implements the scanner interface for the HBase client.
|
ClientSideRegionScanner
A client scanner for a region opened for read-only on the client side.
|
ClientSmallReversedScanner.SmallReversedScannerCallableFactory |
ClientSmallScanner.SmallScannerCallableFactory |
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
ClusterStatusListener
A class that receives the cluster status, and provide it as a set of service to the client.
|
ClusterStatusListener.DeadServerHandler
Class to be extended to manage a new dead server.
|
ClusterStatusListener.Listener
The interface to be implemented by a listener of a cluster status event.
|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
ConnectionConfiguration
Configuration parameters for the connection.
|
ConnectionFactory
A non-instantiable class that manages creation of
Connection s. |
ConnectionManager.HConnectionImplementation
Encapsulates connection to zookeeper and regionservers.
|
ConnectionManager.HConnectionImplementation.MasterServiceState
State of the MasterService connection/setup.
|
ConnectionManager.HConnectionImplementation.StubMaker
Makes a client-side stub for master services.
|
ConnectionManager.ServerErrorTracker
The record of errors for servers.
|
ConnectionManager.ServerErrorTracker.ServerErrors
The record of errors for a server.
|
Consistency
Consistency defines the expected consistency level for an operation.
|
Delete
Used to perform Delete operations on a single row.
|
DoNotRetryRegionException
Similar to RegionException, but disables retries.
|
Durability
Enum describing the durability guarantees for tables and
Mutation s
Note that the items must be sorted in order of increasing durability |
FailureInfo
Keeps track of repeated failures to any region server.
|
FastFailInterceptorContext |
Get
Used to perform Get operations on a single row.
|
HBaseAdmin
HBaseAdmin is no longer a client API.
|
HBaseAdmin.ProcedureFuture
Future that waits on a procedure result.
|
HBaseAdmin.ProcedureFuture.WaitForStateCallable |
HConnectable
This class makes it convenient for one to execute a command in the context
of a
HConnection instance based on the given Configuration . |
HConnection
Deprecated.
in favor of
Connection and ConnectionFactory |
HConnectionKey
Denotes a unique key to an
HConnection instance. |
HRegionLocator
An implementation of
RegionLocator . |
HTable
An implementation of
Table . |
HTableInterface
Deprecated.
use
Table instead |
HTableInterfaceFactory
Deprecated.
in favor of
ConnectionFactory and Connection . |
HTableMultiplexer
HTableMultiplexer provides a thread-safe non blocking PUT API across all the tables.
|
HTableMultiplexer.AtomicAverageCounter
Helper to count the average over an interval until reset.
|
HTableMultiplexer.FlushWorker |
HTableMultiplexer.HTableMultiplexerStatus
HTableMultiplexerStatus keeps track of the current status of the HTableMultiplexer.
|
HTableMultiplexer.PutStatus |
Increment
Used to perform Increment operations on a single row.
|
IsolationLevel
Specify Isolation levels in Scan operations.
|
MasterCallable
A RetryingCallable for master operations.
|
MasterKeepAliveConnection
A KeepAlive connection is not physically closed immediately after the close,
but rather kept alive for a few minutes.
|
MetaCache
A cache implementation for region locations from meta.
|
MetaScanner.DefaultMetaScannerVisitor
A MetaScannerVisitor that skips offline regions and split parents
|
MetaScanner.MetaScannerVisitor
Visitor class called to process each row of the hbase:meta table
|
MetaScanner.MetaScannerVisitorBase |
MetricsConnection
This class is for maintaining the various connection statistics and publishing them through
the metrics interfaces.
|
MetricsConnection.CallStats
A container class for collecting details about the RPC call as it percolates.
|
MetricsConnection.CallTracker |
MetricsConnection.NewMetric
A lambda for dispatching to the appropriate metric factory method
|
MetricsConnection.RegionStats |
MetricsConnection.RunnerStats |
MultiAction
Container for Actions (i.e.
|
MultiResponse
A container for Result objects, grouped by regionName.
|
MultiServerCallable
Callable that handles the
multi method call going against a single
regionserver; i.e. |
Mutation |
NonceGenerator
NonceGenerator interface.
|
Operation
Superclass for any type that maps to a potentially application-level query.
|
OperationWithAttributes |
Put
Used to perform Put operations for a single row.
|
Query |
RegionAdminServiceCallable
Similar to
RegionServerCallable but for the AdminService interface. |
RegionLocator
Used to view region location information for a single HBase table.
|
RegionServerCallable
Implementations call a RegionServer and implement
RetryingCallable.call(int) . |
Registry
Cluster registry.
|
Result |
ResultBoundedCompletionService
A completion service for the RpcRetryingCallerFactory.
|
ResultBoundedCompletionService.QueueingFuture |
ResultScanner
Interface for client-side scanning.
|
RetriesExhaustedException
Exception thrown by HTable methods when an attempt to do something (like
commit changes) fails after a bunch of retries.
|
RetriesExhaustedException.ThrowableWithExtraContext
Datastructure that allows adding more info around Throwable incident.
|
RetriesExhaustedWithDetailsException
This subclass of
RetriesExhaustedException
is thrown when we have more information about which rows were causing which
exceptions on what servers. |
RetryingCallable
A Callable<T> that will be retried.
|
RetryingCallerInterceptor
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.
|
RetryingCallerInterceptorContext
The context object used in the
RpcRetryingCaller to enable
RetryingCallerInterceptor to intercept calls. |
ReversedClientScanner
A reversed client scanner which support backward scanning
|
ReversedScannerCallable
A reversed ScannerCallable which supports backward scanning.
|
Row
Has a row.
|
RowMutations
Performs multiple mutations atomically on a single row.
|
RpcRetryingCaller
Runs an rpc'ing
RetryingCallable . |
RpcRetryingCallerFactory
Factory to create an
RpcRetryingCaller |
Scan
Used to perform Scan operations.
|
ScannerCallable
Scanner operations such as create, next, etc.
|
ScannerCallableWithReplicas
This class has the logic for handling scanners for regions with and without replicas.
|
ServerStatisticTracker
Tracks the statistics for multiple regions
|
Table
Used to communicate with a single HBase table.
|
ZooKeeperKeepAliveConnection
We inherit the current ZooKeeperWatcher implementation to change the semantic
of the close: the new close won't immediately close the connection but
will have a keep alive.
|
Class and Description |
---|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
Scan
Used to perform Scan operations.
|
Table
Used to communicate with a single HBase table.
|
Class and Description |
---|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
Class and Description |
---|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
Class and Description |
---|
Durability
Enum describing the durability guarantees for tables and
Mutation s
Note that the items must be sorted in order of increasing durability |
Put
Used to perform Put operations for a single row.
|
Class and Description |
---|
Append
Performs Append operations on a single row.
|
Delete
Used to perform Delete operations on a single row.
|
Durability
Enum describing the durability guarantees for tables and
Mutation s
Note that the items must be sorted in order of increasing durability |
Get
Used to perform Get operations on a single row.
|
HTableInterface
Deprecated.
use
Table instead |
Increment
Used to perform Increment operations on a single row.
|
Mutation |
Put
Used to perform Put operations for a single row.
|
Result |
Scan
Used to perform Scan operations.
|
Class and Description |
---|
Delete
Used to perform Delete operations on a single row.
|
Scan
Used to perform Scan operations.
|
Class and Description |
---|
DoNotRetryRegionException
Similar to RegionException, but disables retries.
|
Class and Description |
---|
Scan
Used to perform Scan operations.
|
Class and Description |
---|
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
MetricsConnection
This class is for maintaining the various connection statistics and publishing them through
the metrics interfaces.
|
MetricsConnection.CallStats
A container class for collecting details about the RPC call as it percolates.
|
RpcRetryingCallerFactory
Factory to create an
RpcRetryingCaller |
Class and Description |
---|
Put
Used to perform Put operations for a single row.
|
Result |
Class and Description |
---|
Admin
The administrative API for HBase.
|
BufferedMutator
Used to communicate with a single HBase table similar to
Table but meant for
batched, asynchronous puts. |
ClientSideRegionScanner
A client scanner for a region opened for read-only on the client side.
|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
Delete
Used to perform Delete operations on a single row.
|
Durability
Enum describing the durability guarantees for tables and
Mutation s
Note that the items must be sorted in order of increasing durability |
HConnection
Deprecated.
in favor of
Connection and ConnectionFactory |
HTable
An implementation of
Table . |
Mutation |
Put
Used to perform Put operations for a single row.
|
RegionLocator
Used to view region location information for a single HBase table.
|
Result |
ResultScanner
Interface for client-side scanning.
|
Scan
Used to perform Scan operations.
|
Table
Used to communicate with a single HBase table.
|
Class and Description |
---|
Result |
ResultScanner
Interface for client-side scanning.
|
Table
Used to communicate with a single HBase table.
|
Class and Description |
---|
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
Result |
Table
Used to communicate with a single HBase table.
|
Class and Description |
---|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
Put
Used to perform Put operations for a single row.
|
Class and Description |
---|
Admin
The administrative API for HBase.
|
Class and Description |
---|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
Delete
Used to perform Delete operations on a single row.
|
Get
Used to perform Get operations on a single row.
|
Mutation |
Put
Used to perform Put operations for a single row.
|
Result |
ResultScanner
Interface for client-side scanning.
|
Scan
Used to perform Scan operations.
|
Table
Used to communicate with a single HBase table.
|
Class and Description |
---|
Append
Performs Append operations on a single row.
|
Attributes |
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
Delete
Used to perform Delete operations on a single row.
|
Durability
Enum describing the durability guarantees for tables and
Mutation s
Note that the items must be sorted in order of increasing durability |
Get
Used to perform Get operations on a single row.
|
HConnection
Deprecated.
in favor of
Connection and ConnectionFactory |
Increment
Used to perform Increment operations on a single row.
|
IsolationLevel
Specify Isolation levels in Scan operations.
|
Mutation |
Operation
Superclass for any type that maps to a potentially application-level query.
|
OperationWithAttributes |
Put
Used to perform Put operations for a single row.
|
Query |
Result |
RowMutations
Performs multiple mutations atomically on a single row.
|
RpcRetryingCallerFactory
Factory to create an
RpcRetryingCaller |
Scan
Used to perform Scan operations.
|
Class and Description |
---|
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
RpcRetryingCallerFactory
Factory to create an
RpcRetryingCaller |
Class and Description |
---|
HConnection
Deprecated.
in favor of
Connection and ConnectionFactory |
RegionServerCallable
Implementations call a RegionServer and implement
RetryingCallable.call(int) . |
RetryingCallable
A Callable<T> that will be retried.
|
Class and Description |
---|
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
HConnection
Deprecated.
in favor of
Connection and ConnectionFactory |
RegionAdminServiceCallable
Similar to
RegionServerCallable but for the AdminService interface. |
RetryingCallable
A Callable<T> that will be retried.
|
Row
Has a row.
|
RpcRetryingCallerFactory
Factory to create an
RpcRetryingCaller |
Class and Description |
---|
Admin
The administrative API for HBase.
|
Result |
ResultScanner
Interface for client-side scanning.
|
Table
Used to communicate with a single HBase table.
|
Class and Description |
---|
Append
Performs Append operations on a single row.
|
Delete
Used to perform Delete operations on a single row.
|
Durability
Enum describing the durability guarantees for tables and
Mutation s
Note that the items must be sorted in order of increasing durability |
Get
Used to perform Get operations on a single row.
|
Increment
Used to perform Increment operations on a single row.
|
Put
Used to perform Put operations for a single row.
|
Result |
ResultScanner
Interface for client-side scanning.
|
Row
Has a row.
|
RowMutations
Performs multiple mutations atomically on a single row.
|
Scan
Used to perform Scan operations.
|
Table
Used to communicate with a single HBase table.
|
Class and Description |
---|
Admin
The administrative API for HBase.
|
Scan
Used to perform Scan operations.
|
Class and Description |
---|
Append
Performs Append operations on a single row.
|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
Delete
Used to perform Delete operations on a single row.
|
Durability
Enum describing the durability guarantees for tables and
Mutation s
Note that the items must be sorted in order of increasing durability |
Get
Used to perform Get operations on a single row.
|
Increment
Used to perform Increment operations on a single row.
|
Mutation |
Put
Used to perform Put operations for a single row.
|
Query |
Result |
Scan
Used to perform Scan operations.
|
Table
Used to communicate with a single HBase table.
|
Class and Description |
---|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
Class and Description |
---|
Append
Performs Append operations on a single row.
|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
Get
Used to perform Get operations on a single row.
|
Increment
Used to perform Increment operations on a single row.
|
Mutation |
Result |
Scan
Used to perform Scan operations.
|
Class and Description |
---|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
Class and Description |
---|
Admin
The administrative API for HBase.
|
OperationWithAttributes |
Result |
ResultScanner
Interface for client-side scanning.
|
Table
Used to communicate with a single HBase table.
|
Class and Description |
---|
Append
Performs Append operations on a single row.
|
Delete
Used to perform Delete operations on a single row.
|
Durability
Enum describing the durability guarantees for tables and
Mutation s
Note that the items must be sorted in order of increasing durability |
Get
Used to perform Get operations on a single row.
|
Increment
Used to perform Increment operations on a single row.
|
OperationWithAttributes |
Put
Used to perform Put operations for a single row.
|
RegionLocator
Used to view region location information for a single HBase table.
|
Result |
ResultScanner
Interface for client-side scanning.
|
RowMutations
Performs multiple mutations atomically on a single row.
|
Scan
Used to perform Scan operations.
|
Table
Used to communicate with a single HBase table.
|
Class and Description |
---|
Admin
The administrative API for HBase.
|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
Mutation |
Table
Used to communicate with a single HBase table.
|
Class and Description |
---|
Admin
The administrative API for HBase.
|
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
HConnection
Deprecated.
in favor of
Connection and ConnectionFactory |
HTable
An implementation of
Table . |
Put
Used to perform Put operations for a single row.
|
RegionLocator
Used to view region location information for a single HBase table.
|
RegionReplicaUtil
Utility methods which contain the logic for regions and replicas.
|
Result |
ResultScanner
Interface for client-side scanning.
|
Row
Has a row.
|
Table
Used to communicate with a single HBase table.
|
Class and Description |
---|
Durability
Enum describing the durability guarantees for tables and
Mutation s
Note that the items must be sorted in order of increasing durability |
HConnection
Deprecated.
in favor of
Connection and ConnectionFactory |
Mutation |
Class and Description |
---|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
|
HConnection
Deprecated.
in favor of
Connection and ConnectionFactory |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.