Class and Description |
---|
Admin
The administrative API for HBase.
|
AdvancedScanResultConsumer
This is the low level API for asynchronous scan.
|
AdvancedScanResultConsumer.ScanController
Used to suspend or stop a scan, or get a scan cursor if available.
|
AsyncTable
The interface for asynchronous version of Table.
|
BufferedMutator
Used to communicate with a single HBase table similar to
Table but meant for batched,
asynchronous puts. |
BufferedMutatorParams
Parameters for instantiating a
BufferedMutator . |
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
ColumnFamilyDescriptor
An ColumnFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
|
ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
An ModifyableFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
|
CompactionState
POJO representing the compaction state
|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and a
connection to zookeeper.
|
CoprocessorDescriptor
CoprocessorDescriptor contains the details about how to build a coprocessor.
|
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.
|
Hbck
Hbck fixup tool APIs.
|
MobCompactPartitionPolicy
Enum describing the mob compact partition policy types.
|
Mutation |
Put
Used to perform Put operations for a single row.
|
RegionInfo
Information about a region.
|
RegionLocator
Used to view region location information for a single HBase table.
|
RegionStatesCount |
Result |
Scan
Used to perform Scan operations.
|
ScanResultConsumerBase
The base interface for scan result consumer.
|
Table
Used to communicate with a single HBase table.
|
TableBuilder
For creating
Table instance. |
TableDescriptor
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... |
TableDescriptorBuilder.ModifyableTableDescriptor
TODO: make this private after removing the HTableDescriptor
|
TableState
Represents table state.
|
TableState.State |
Class and Description |
---|
RegionInfo
Information about a region.
|
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.
|
Class and Description |
---|
AbstractClientScanner
Helper class for custom client scanners.
|
AbstractResponse
This class is used to extend AP to process single action request, like delete, get etc.
|
AbstractResponse.ResponseType |
AbstractRpcBasedConnectionRegistry
Base class for rpc based connection registry implementation.
|
AbstractRpcBasedConnectionRegistry.Callable
For describing the actual asynchronous rpc call.
|
Action
A Get, Put, Increment, Append, or Delete associated with it's region.
|
Admin
The administrative API for HBase.
|
AdvancedScanResultConsumer
This is the low level API for asynchronous scan.
|
AdvancedScanResultConsumer.ScanController
Used to suspend or stop a scan, or get a scan cursor if available.
|
AdvancedScanResultConsumer.ScanResumer
Used to resume a scan.
|
Append
Performs Append operations on a single row.
|
AsyncAdmin
The asynchronous administrative API for HBase.
|
AsyncAdminBuilder
For creating
AsyncAdmin . |
AsyncAdminBuilderBase
Base class for all asynchronous admin builders.
|
AsyncAdminRequestRetryingCaller |
AsyncAdminRequestRetryingCaller.Callable |
AsyncBatchRpcRetryingCaller
Retry caller for batch.
|
AsyncBatchRpcRetryingCaller.RegionRequest |
AsyncBatchRpcRetryingCaller.ServerRequest |
AsyncBufferedMutator
Used to communicate with a single HBase table in batches.
|
AsyncBufferedMutatorBuilder
For creating
AsyncBufferedMutator . |
AsyncClientScanner.OpenScannerResponse |
AsyncConnection
The asynchronous version of Connection.
|
AsyncConnectionConfiguration
Timeout configs.
|
AsyncConnectionImpl
The implementation of AsyncConnection.
|
AsyncMasterRequestRpcRetryingCaller
Retry caller for a request call to master.
|
AsyncMasterRequestRpcRetryingCaller.Callable |
AsyncMetaRegionLocator
The asynchronous locator for meta region.
|
AsyncNonMetaRegionLocator
The asynchronous locator for regions other than meta.
|
AsyncNonMetaRegionLocator.LocateRequest |
AsyncNonMetaRegionLocator.RegionLocationsFutureResult |
AsyncNonMetaRegionLocator.TableCache |
AsyncProcess
This class allows a continuous flow of requests.
|
AsyncProcessTask
Contains the attributes of a task which will be executed by
AsyncProcess . |
AsyncProcessTask.Builder |
AsyncProcessTask.SubmittedRows
The number of processed rows.
|
AsyncRegionLocator
The asynchronous region locator.
|
AsyncRequestFuture
The context used to wait for results from one submit call.
|
AsyncRequestFutureImpl
The context, and return value, for a single submit/submitAll call.
|
AsyncRequestFutureImpl.ReplicaResultState
Sync point for calls to multiple replicas for the same user request (Get).
|
AsyncRequestFutureImpl.Retry |
AsyncRequestFutureImpl.SingleServerRequestRunnable
Runnable (that can be submitted to thread pool) that submits MultiAction to a single server.
|
AsyncRpcRetryingCaller |
AsyncRpcRetryingCallerFactory
Factory to create an AsyncRpcRetryCaller.
|
AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder |
AsyncRpcRetryingCallerFactory.BatchCallerBuilder |
AsyncRpcRetryingCallerFactory.BuilderBase |
AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder |
AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder |
AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder |
AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder |
AsyncScanSingleRegionRpcRetryingCaller
Retry caller for scanning a region.
|
AsyncScanSingleRegionRpcRetryingCaller.ScanControllerState |
AsyncScanSingleRegionRpcRetryingCaller.ScanResumerImpl |
AsyncScanSingleRegionRpcRetryingCaller.ScanResumerState |
AsyncServerRequestRpcRetryingCaller
Retry caller for a request call to region server.
|
AsyncServerRequestRpcRetryingCaller.Callable |
AsyncSingleRequestRpcRetryingCaller
Retry caller for a single request, such as get, put, delete, etc.
|
AsyncSingleRequestRpcRetryingCaller.Callable |
AsyncTable
The interface for asynchronous version of Table.
|
AsyncTable.CheckAndMutateBuilder
Deprecated.
Since 2.4.0, will be removed in 4.0.0. For internal test use only, do not use it
any more.
|
AsyncTable.CheckAndMutateWithFilterBuilder
Deprecated.
Since 2.4.0, will be removed in 4.0.0. For internal test use only, do not use it
any more.
|
AsyncTable.CoprocessorCallback
The callback when we want to execute a coprocessor call on a range of regions.
|
AsyncTable.CoprocessorServiceBuilder
Helper class for sending coprocessorService request that executes a coprocessor call on regions
which are covered by a range.
|
AsyncTableBuilder
For creating
AsyncTable . |
AsyncTableBuilderBase
Base class for all asynchronous table builders.
|
AsyncTableRegionLocator
The asynchronous version of RegionLocator.
|
AsyncTableResultScanner
The
ResultScanner implementation for RawAsyncTableImpl . |
Attributes |
BalancerDecision
History of balancer decisions taken for region movements.
|
BalancerDecision.Builder |
BalanceRequest
Encapsulates options for executing a run of the Balancer.
|
BalanceRequest.Builder
Builder for constructing a
BalanceRequest |
BalanceResponse
Response returned from a balancer invocation
|
BalanceResponse.Builder
Used in HMaster to build a
BalanceResponse for returning results of a balance
invocation to callers |
BalancerRejection
History of detail information that balancer movements was rejected
|
BalancerRejection.Builder |
BatchErrors |
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.QueueRowAccess |
BufferedMutatorParams
Parameters for instantiating a
BufferedMutator . |
Cancellable
This should be implemented by the Get/Scan implementations that talk to replica regions.
|
CancellableRegionServerCallable
This class is used to unify HTable calls with AsyncProcess Framework.
|
CatalogReplicaLoadBalanceSelector
A Catalog replica selector decides which catalog replica to go for read requests when it is
configured as CatalogReplicaMode.LoadBalance.
|
CatalogReplicaLoadBalanceSimpleSelector
CatalogReplicaLoadBalanceReplicaSimpleSelector implements a simple catalog replica load balancing
algorithm.
|
CatalogReplicaLoadBalanceSimpleSelector.StaleLocationCacheEntry
StaleLocationCacheEntry is the entry when a stale location is reported by an client.
|
CheckAndMutate
Used to perform CheckAndMutate operations.
|
CheckAndMutate.Builder
A builder class for building a CheckAndMutate object.
|
CheckAndMutateResult
Represents a result of a CheckAndMutate operation
|
ClientScanner
Implements the scanner interface for the HBase client.
|
ClientServiceCallable
A RegionServerCallable set to use the Client protocol.
|
ClientSideRegionScanner
A client scanner for a region opened for read-only on the client side.
|
ClientSimpleScanner
ClientSimpleScanner implements a sync scanner behaviour.
|
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.
|
ColumnFamilyDescriptor
An ColumnFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
|
ColumnFamilyDescriptorBuilder |
ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor
An ModifyableFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
|
CompactionState
POJO representing the compaction state
|
CompactType
Currently, there are only two compact types:
NORMAL means do store files compaction;
MOB means do mob files compaction. |
Connection
A cluster connection encapsulating lower level individual connections to actual servers and a
connection to zookeeper.
|
ConnectionConfiguration
Configuration parameters for the connection.
|
ConnectionImplementation
Main implementation of
Connection and ClusterConnection interfaces. |
ConnectionImplementation.LocalConnectionClosedException
Like
ConnectionClosedException but thrown from the checkClosed call which looks at the
local this.closed flag. |
ConnectionImplementation.MasterServiceState
State of the MasterService connection/setup.
|
ConnectionImplementation.ServerErrorTracker
The record of errors for servers.
|
ConnectionImplementation.ServerErrorTracker.ServerErrors
The record of errors for a server.
|
ConnectionRegistry
Registry for meta information needed for connection setup to a HBase cluster.
|
Consistency
Consistency defines the expected consistency level for an operation.
|
CoprocessorDescriptor
CoprocessorDescriptor contains the details about how to build a coprocessor.
|
CoprocessorDescriptorBuilder
Used to build the
CoprocessorDescriptor |
Cursor
Scan cursor to tell client where server is scanning
Scan.setNeedCursorResult(boolean)
Result.isCursor() Result.getCursor() |
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.ModifyTableFuture |
HBaseAdmin.ProcedureFuture
Future that waits on a procedure result.
|
HBaseAdmin.ProcedureFuture.WaitForStateCallable |
HBaseAdmin.TableFuture |
Hbck
Hbck fixup tool APIs.
|
HRegionLocator
An implementation of
RegionLocator . |
HTableMultiplexer
Deprecated.
since 2.2.0, will be removed in 3.0.0, without replacement. Please use
BufferedMutator for batching mutations. |
HTableMultiplexer.AtomicAverageCounter
Deprecated.
Helper to count the average over an interval until reset.
|
HTableMultiplexer.FlushWorker
Deprecated.
|
HTableMultiplexer.HTableMultiplexerStatus
Deprecated.
since 2.2.0, will be removed in 3.0.0, without replacement. Please use
BufferedMutator for batching mutations. |
HTableMultiplexer.PutStatus
Deprecated.
|
Increment
Used to perform Increment operations on a single row.
|
IsolationLevel
Specify Isolation levels in Scan operations.
|
LogEntry
Abstract response class representing online logs response from ring-buffer use-cases e.g
slow/large RPC logs, balancer decision logs
|
LogQueryFilter
Deprecated.
as of 2.4.0. Will be removed in 4.0.0.
|
LogQueryFilter.FilterByOperator
Deprecated.
|
LogQueryFilter.Type
Deprecated.
|
MasterKeepAliveConnection
A KeepAlive connection is not physically closed immediately after the close, but rather kept
alive for a few minutes.
|
MasterSwitchType
Represents the master switch type
|
MetaCache
A cache implementation for region locations from meta.
|
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 |
MobCompactPartitionPolicy
Enum describing the mob compact partition policy types.
|
MultiAction
Container for Actions (i.e.
|
MultiResponse
A container for Result objects, grouped by regionName.
|
MultiResponse.RegionResult |
MultiServerCallable
Callable that handles the
multi method call going against a single regionserver;
i.e. |
MutableRegionInfo
An implementation of RegionInfo that adds mutable methods so can build a RegionInfo instance.
|
Mutation |
NonceGenerator
NonceGenerator interface.
|
NormalizeTableFilterParams
A collection of criteria used for table selection.
|
NormalizeTableFilterParams.Builder
Used to instantiate an instance of
NormalizeTableFilterParams . |
OnlineLogRecord
Slow/Large Log payload for hbase-client, to be used by Admin API get_slow_responses and
get_large_responses
|
OnlineLogRecord.OnlineLogRecordBuilder |
Operation
Superclass for any type that maps to a potentially application-level query.
|
OperationWithAttributes |
PerClientRandomNonceGenerator
NonceGenerator implementation that uses client ID hash + random int as nonce group, and random
numbers as nonces.
|
Put
Used to perform Put operations for a single row.
|
Query
Base class for HBase read operations; e.g.
|
RawAsyncHBaseAdmin
The implementation of AsyncAdmin.
|
RawAsyncHBaseAdmin.AdminRpcCall |
RawAsyncHBaseAdmin.Converter |
RawAsyncHBaseAdmin.MasterRpcCall |
RawAsyncHBaseAdmin.NamespaceProcedureBiConsumer |
RawAsyncHBaseAdmin.ProcedureBiConsumer |
RawAsyncHBaseAdmin.TableProcedureBiConsumer |
RawAsyncTableImpl
The implementation of RawAsyncTable.
|
RawAsyncTableImpl.Converter |
RawAsyncTableImpl.CoprocessorServiceBuilderImpl |
RawAsyncTableImpl.NoncedConverter |
RawAsyncTableImpl.RpcCall |
RegionAdminServiceCallable
Similar to RegionServerCallable but for the AdminService interface.
|
RegionInfo
Information about a region.
|
RegionInfoBuilder |
RegionLoadStats
POJO representing region server load
|
RegionLocateType
Indicate which row you want to locate.
|
RegionLocator
Used to view region location information for a single HBase table.
|
RegionServerCallable
Implementations make a RPC call against a RegionService via a protobuf Service.
|
RegionStatesCount |
RegionStatesCount.RegionStatesCountBuilder |
RegistryEndpointsRefresher
Thread safe utility that keeps registry end points used by
ConnectionRegistry up to date. |
RegistryEndpointsRefresher.Refresher |
RequestController
An interface for client request scheduling algorithm.
|
RequestController.Checker
Picks up the valid data.
|
RequestController.ReturnCode |
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
Data structure 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. |
RetryingTimeTracker
Tracks the amount of time remaining for an operation.
|
ReversedScannerCallable
A reversed ScannerCallable which supports backward scanning.
|
Row
Has a row.
|
RowAccess
Provide a way to access the inner buffer.
|
RowMutations
Performs multiple mutations atomically on a single row.
|
RpcRetryingCaller |
RpcRetryingCallerFactory
Factory to create an
RpcRetryingCaller |
Scan
Used to perform Scan operations.
|
Scan.ReadType |
ScannerCallable
Scanner operations such as create, next, etc.
|
ScannerCallable.MoreResults |
ScannerCallableWithReplicas
This class has the logic for handling scanners for regions with and without replicas.
|
ScanResultCache
Used to separate the row constructing logic.
|
ScanResultConsumer
Receives
Result for an asynchronous scan. |
ScanResultConsumerBase
The base interface for scan result consumer.
|
ServerConnectionUtils.ShortCircuitingClusterConnection.ClientServiceBlockingInterfaceWrapper.Operation |
ServerStatisticTracker
Tracks the statistics for multiple regions
|
ServerType
Select server type i.e destination for RPC request associated with ring buffer.
|
ServiceCaller
Delegate to a protobuf rpc call.
|
SimpleRequestController.RowChecker
Provide a way to control the flow of rows iteration.
|
SingleResponse.Entry |
SnapshotDescription
The POJO equivalent of HBaseProtos.SnapshotDescription
|
SnapshotType
POJO representing the snapshot type
|
StatisticTrackable
Parent interface for an object to get updates about per-region statistics.
|
SyncCoprocessorRpcChannel
Base class which provides clients with an RPC connection to call coprocessor endpoint
Service s. |
Table
Used to communicate with a single HBase table.
|
Table.CheckAndMutateBuilder
Deprecated.
Since 2.4.0, will be removed in 4.0.0. For internal test use only, do not use it
any more.
|
Table.CheckAndMutateWithFilterBuilder
Deprecated.
Since 2.4.0, will be removed in 4.0.0. For internal test use only, do not use it
any more.
|
TableBuilder
For creating
Table instance. |
TableBuilderBase
Base class for all table builders.
|
TableDescriptor
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... |
TableDescriptorBuilder
Convenience class for composing an instance of
TableDescriptor . |
TableDescriptorBuilder.ModifyableTableDescriptor
TODO: make this private after removing the HTableDescriptor
|
TableDescriptorUtils.TableDescriptorDelta |
TableState
Represents table state.
|
TableState.State |
ZKConnectionRegistry.Converter |
Class and Description |
---|
RegionLoadStats
POJO representing region server load
|
Class and Description |
---|
AsyncConnection
The asynchronous version of Connection.
|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and a
connection to zookeeper.
|
Table
Used to communicate with a single HBase table.
|
Class and Description |
---|
NonceGenerator
NonceGenerator interface.
|
RegionInfo
Information about a region.
|
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.
|
Class and Description |
---|
AsyncConnectionImpl
The implementation of AsyncConnection.
|
CheckAndMutate
Used to perform CheckAndMutate operations.
|
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
Row
Has a row.
|
RowMutations
Performs multiple mutations atomically on a single row.
|
Scan
Used to perform Scan operations.
|
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.
|
TableDescriptor
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... |
Class and Description |
---|
Append
Performs Append operations on a single row.
|
BalanceRequest
Encapsulates options for executing a run of the Balancer.
|
BalanceResponse
Response returned from a balancer invocation
|
CheckAndMutate
Used to perform CheckAndMutate operations.
|
CheckAndMutateResult
Represents a result of a CheckAndMutate operation
|
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.
|
MasterSwitchType
Represents the master switch type
|
Mutation |
Put
Used to perform Put operations for a single row.
|
RegionInfo
Information about a region.
|
Result |
Row
Has a row.
|
Scan
Used to perform Scan operations.
|
SnapshotDescription
The POJO equivalent of HBaseProtos.SnapshotDescription
|
TableDescriptor
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... |
Class and Description |
---|
Delete
Used to perform Delete operations on a single row.
|
Get
Used to perform Get operations on a single row.
|
Increment
Used to perform Increment operations on a single row.
|
RegionInfo
Information about a region.
|
Result |
Scan
Used to perform Scan operations.
|
TableDescriptor
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... |
Class and Description |
---|
DoNotRetryRegionException
Similar to RegionException, but disables retries.
|
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.
|
RegionInfo
Information about a region.
|
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.
|
Class and Description |
---|
Admin
The administrative API for HBase.
|
Class and Description |
---|
RegionInfo
Information about a region.
|
Scan
Used to perform Scan operations.
|
Class and Description |
---|
ColumnFamilyDescriptor
An ColumnFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
|
Class and Description |
---|
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.
|
RegionInfo
Information about a region.
|
Class and Description |
---|
BufferedMutator
Used to communicate with a single HBase table similar to
Table but meant for batched,
asynchronous puts. |
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.
|
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 |
---|
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.
|
ColumnFamilyDescriptor
An ColumnFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
|
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 |
Mutation |
Put
Used to perform Put operations for a single row.
|
RegionInfo
Information about a region.
|
RegionLocator
Used to view region location information for a single HBase table.
|
Result |
Scan
Used to perform Scan operations.
|
Scan.ReadType |
Table
Used to communicate with a single HBase table.
|
TableDescriptor
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... |
Class and Description |
---|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and a
connection to zookeeper.
|
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 |
---|
BalanceRequest
Encapsulates options for executing a run of the Balancer.
|
BalanceResponse
Response returned from a balancer invocation
|
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
ColumnFamilyDescriptor
An ColumnFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
|
CompactionState
POJO representing the compaction state
|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and a
connection to zookeeper.
|
MasterSwitchType
Represents the master switch type
|
Mutation |
NormalizeTableFilterParams
A collection of criteria used for table selection.
|
PerClientRandomNonceGenerator
NonceGenerator implementation that uses client ID hash + random int as nonce group, and random
numbers as nonces.
|
RegionInfo
Information about a region.
|
Result |
SnapshotDescription
The POJO equivalent of HBaseProtos.SnapshotDescription
|
Table
Used to communicate with a single HBase table.
|
TableDescriptor
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... |
TableState
Represents table state.
|
TableState.State |
Class and Description |
---|
Delete
Used to perform Delete operations on a single row.
|
DoNotRetryRegionException
Similar to RegionException, but disables retries.
|
Mutation |
Put
Used to perform Put operations for a single row.
|
RegionInfo
Information about a region.
|
RegionStatesCount |
Result |
ResultScanner
Interface for client-side scanning.
|
Scan
Used to perform Scan operations.
|
Table
Used to communicate with a single HBase table.
|
TableDescriptor
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... |
Class and Description |
---|
RegionInfo
Information about a region.
|
TableDescriptor
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... |
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.
|
AsyncAdmin
The asynchronous administrative API for HBase.
|
AsyncConnection
The asynchronous version of Connection.
|
RegionInfo
Information about a region.
|
Result |
ResultScanner
Interface for client-side scanning.
|
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 |
---|
RegionInfo
Information about a region.
|
Result |
TableDescriptor
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... |
Class and Description |
---|
RegionInfo
Information about a region.
|
Class and Description |
---|
MasterSwitchType
Represents the master switch type
|
RegionInfo
Information about a region.
|
TableDescriptor
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... |
Class and Description |
---|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and a
connection to zookeeper.
|
DoNotRetryRegionException
Similar to RegionException, but disables retries.
|
RegionInfo
Information about a region.
|
Result |
TableDescriptor
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... |
Class and Description |
---|
Get
Used to perform Get operations on a single row.
|
RegionInfo
Information about a region.
|
Result |
ResultScanner
Interface for client-side scanning.
|
Scan
Used to perform Scan operations.
|
TableDescriptor
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... |
Class and Description |
---|
TableDescriptorBuilder
Convenience class for composing an instance of
TableDescriptor . |
Class and Description |
---|
RegionInfo
Information about a region.
|
TableDescriptor
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... |
Class and Description |
---|
Admin
The administrative API for HBase.
|
ColumnFamilyDescriptor
An ColumnFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
|
RegionInfo
Information about a region.
|
Scan
Used to perform Scan operations.
|
TableDescriptor
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... |
Class and Description |
---|
Result |
Class and Description |
---|
BalancerDecision
History of balancer decisions taken for region movements.
|
BalancerRejection
History of detail information that balancer movements was rejected
|
Class and Description |
---|
RegionInfo
Information about a region.
|
Class and Description |
---|
Mutation |
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.
|
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.
|
RegionInfo
Information about a region.
|
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 |
---|
Mutation |
Class and Description |
---|
Append
Performs Append operations on a single row.
|
Attributes |
CheckAndMutate
Used to perform CheckAndMutate operations.
|
CheckAndMutateResult
Represents a result of a CheckAndMutate operation
|
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
ColumnFamilyDescriptor
An ColumnFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
|
CompactionState
POJO representing the compaction state
|
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.
|
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
Base class for HBase read operations; e.g.
|
RegionInfo
Information about a region.
|
Result |
Row
Has a row.
|
RowMutations
Performs multiple mutations atomically on a single row.
|
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).
|
RpcRetryingCallerFactory
Factory to create an
RpcRetryingCaller |
Scan
Used to perform Scan operations.
|
Scan.ReadType |
TableDescriptor
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... |
Class and Description |
---|
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
RegionInfo
Information about a region.
|
RpcRetryingCallerFactory
Factory to create an
RpcRetryingCaller |
TableDescriptor
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... |
Class and Description |
---|
Scan
Used to perform Scan operations.
|
Class and Description |
---|
ColumnFamilyDescriptor
An ColumnFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
|
TableDescriptor
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... |
TableDescriptorBuilder
Convenience class for composing an instance of
TableDescriptor . |
Class and Description |
---|
RegionInfo
Information about a region.
|
Class and Description |
---|
AsyncConnection
The asynchronous version of Connection.
|
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.
|
RegionAdminServiceCallable
Similar to RegionServerCallable but for the AdminService interface.
|
RegionInfo
Information about a region.
|
RegionLocator
Used to view region location information for a single HBase table.
|
RetryingCallable
A Callable<T> that will be retried.
|
Row
Has a row.
|
RpcRetryingCallerFactory
Factory to create an
RpcRetryingCaller |
Table
Used to communicate with a single HBase table.
|
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 |
---|
Admin
The administrative API for HBase.
|
Scan
Used to perform Scan operations.
|
Class and Description |
---|
Admin
The administrative API for HBase.
|
BalanceRequest
Encapsulates options for executing a run of the Balancer.
|
BalanceResponse
Response returned from a balancer invocation
|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and a
connection to zookeeper.
|
Mutation |
RegionInfo
Information about a region.
|
SnapshotDescription
The POJO equivalent of HBaseProtos.SnapshotDescription
|
TableDescriptor
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... |
Class and Description |
---|
ColumnFamilyDescriptor
An ColumnFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
|
Class and Description |
---|
Admin
The administrative API for HBase.
|
Append
Performs Append operations on a single row.
|
BalanceRequest
Encapsulates options for executing a run of the Balancer.
|
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.
|
MasterSwitchType
Represents the master switch type
|
Mutation |
Put
Used to perform Put operations for a single row.
|
Query
Base class for HBase read operations; e.g.
|
RegionInfo
Information about a region.
|
Result |
Scan
Used to perform Scan operations.
|
SnapshotDescription
The POJO equivalent of HBaseProtos.SnapshotDescription
|
Table
Used to communicate with a single HBase table.
|
TableDescriptor
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... |
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 |
---|
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.
|
MasterSwitchType
Represents the master switch type
|
Mutation |
Result |
Scan
Used to perform Scan operations.
|
TableDescriptor
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... |
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 |
---|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and a
connection to zookeeper.
|
RegionInfo
Information about a region.
|
SnapshotDescription
The POJO equivalent of HBaseProtos.SnapshotDescription
|
SnapshotType
POJO representing the snapshot type
|
TableDescriptor
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... |
Class and Description |
---|
RegionInfo
Information about a region.
|
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.
|
ColumnFamilyDescriptor
An ColumnFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
|
Consistency
Consistency defines the expected consistency level for an operation.
|
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.
|
LogQueryFilter
Deprecated.
as of 2.4.0. Will be removed in 4.0.0.
|
LogQueryFilter.FilterByOperator
Deprecated.
|
LogQueryFilter.Type
Deprecated.
|
OnlineLogRecord
Slow/Large Log payload for hbase-client, to be used by Admin API get_slow_responses and
get_large_responses
|
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.
|
Scan.ReadType |
Table
Used to communicate with a single HBase table.
|
TableDescriptor
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... |
Class and Description |
---|
Admin
The administrative API for HBase.
|
Append
Performs Append operations on a single row.
|
BalanceRequest
Encapsulates options for executing a run of the Balancer.
|
BalanceResponse
Response returned from a balancer invocation
|
BufferedMutator
Used to communicate with a single HBase table similar to
Table but meant for batched,
asynchronous puts. |
BufferedMutatorParams
Parameters for instantiating a
BufferedMutator . |
CheckAndMutate
Used to perform CheckAndMutate operations.
|
CheckAndMutateResult
Represents a result of a CheckAndMutate operation
|
ColumnFamilyDescriptor
An ColumnFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
|
CompactionState
POJO representing the compaction state
|
CompactType
Currently, there are only two compact types:
NORMAL means do store files compaction;
MOB means do mob files compaction. |
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.
|
Increment
Used to perform Increment operations on a single row.
|
LogEntry
Abstract response class representing online logs response from ring-buffer use-cases e.g
slow/large RPC logs, balancer decision logs
|
LogQueryFilter
Deprecated.
as of 2.4.0. Will be removed in 4.0.0.
|
NormalizeTableFilterParams
A collection of criteria used for table selection.
|
OnlineLogRecord
Slow/Large Log payload for hbase-client, to be used by Admin API get_slow_responses and
get_large_responses
|
Put
Used to perform Put operations for a single row.
|
RegionInfo
Information about a region.
|
RegionLocator
Used to view region location information for a single HBase table.
|
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.
|
ServerType
Select server type i.e destination for RPC request associated with ring buffer.
|
SnapshotDescription
The POJO equivalent of HBaseProtos.SnapshotDescription
|
SnapshotType
POJO representing the snapshot type
|
Table
Used to communicate with a single HBase table.
|
Table.CheckAndMutateBuilder
Deprecated.
Since 2.4.0, will be removed in 4.0.0. For internal test use only, do not use it
any more.
|
Table.CheckAndMutateWithFilterBuilder
Deprecated.
Since 2.4.0, will be removed in 4.0.0. For internal test use only, do not use it
any more.
|
TableBuilder
For creating
Table instance. |
TableDescriptor
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... |
Class and Description |
---|
Admin
The administrative API for HBase.
|
ClientServiceCallable
A RegionServerCallable set to use the Client protocol.
|
ColumnFamilyDescriptor
An ColumnFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and a
connection to zookeeper.
|
Mutation |
RegionInfo
Information about a region.
|
RegionLocator
Used to view region location information for a single HBase table.
|
SecureBulkLoadClient
Client proxy for SecureBulkLoadProtocol
|
Table
Used to communicate with a single HBase table.
|
TableDescriptor
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... |
Class and Description |
---|
Admin
The administrative API for HBase.
|
Class and Description |
---|
Admin
The administrative API for HBase.
|
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
ColumnFamilyDescriptor
An ColumnFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and a
connection to zookeeper.
|
RegionInfo
Information about a region.
|
RegionLocator
Used to view region location information for a single HBase table.
|
RegionReplicaUtil
Utility methods which contain the logic for regions and replicas.
|
Result |
Row
Has a row.
|
Table
Used to communicate with a single HBase table.
|
TableDescriptor
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... |
TableDescriptorBuilder
Convenience class for composing an instance of
TableDescriptor . |
TableState
Represents table state.
|
TableState.State |
Class and Description |
---|
Admin
The administrative API for HBase.
|
ColumnFamilyDescriptor
An ColumnFamilyDescriptor contains information about a column family such as the number of
versions, compression settings, etc.
|
Connection
A cluster connection encapsulating lower level individual connections to actual servers and a
connection to zookeeper.
|
RegionInfo
Information about a region.
|
TableDescriptor
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... |
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 |
Mutation |
RegionInfo
Information about a region.
|
Class and Description |
---|
Admin
The administrative API for HBase.
|
Table
Used to communicate with a single HBase table.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.