Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.client.backoff | |
org.apache.hadoop.hbase.exceptions | |
org.apache.hadoop.hbase.ipc | |
org.apache.hadoop.hbase.protobuf |
Holds classes generated from protobuf
src/main/protobuf definition files. |
org.apache.hadoop.hbase.quotas | |
org.apache.hadoop.hbase.security | |
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.security.visibility | |
org.apache.hadoop.hbase.shaded.protobuf | |
org.apache.hadoop.hbase.snapshot | |
org.apache.hadoop.hbase.zookeeper |
Class and Description |
---|
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.
|
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 |
MobCompactPartitionPolicy
Enum describing the mob compact partition policy types.
|
Mutation |
Put
Used to perform Put operations for a single row.
|
RawAsyncTable
A low level asynchronous table.
|
Result |
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... |
TableDescriptorBuilder.ModifyableTableDescriptor
TODO: make this private after removing the HTableDescriptor
|
TableState
Represents table state.
|
TableState.State |
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.
|
AsyncAdmin
The asynchronous administrative API for HBase.
|
AsyncAdminBuilder
For creating
AsyncAdmin . |
AsyncAdminRequestRetryingCaller.Callable |
AsyncConnection
The asynchronous version of Connection.
|
AsyncHBaseAdmin
The implementation of AsyncAdmin.
|
AsyncMasterRequestRpcRetryingCaller.Callable |
AsyncProcessTask
Contains the attributes of a task which will be executed
by
AsyncProcess . |
AsyncProcessTask.Builder |
AsyncProcessTask.SubmittedRows
The number of processed rows.
|
AsyncRpcRetryingCaller |
AsyncServerRequestRpcRetryingCaller.Callable |
AsyncTable
The asynchronous table for normal users.
|
AsyncTableBase
The base interface for asynchronous version of Table.
|
AsyncTableBuilder
For creating
AsyncTable or RawAsyncTable . |
AsyncTableRegionLocator
The asynchronous version of RegionLocator.
|
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 . |
BufferedMutatorParams
Parameters for instantiating a
BufferedMutator . |
ClientScanner
Implements the scanner interface for the HBase client.
|
ClientServiceCallable
A RegionServerCallable set to use the Client protocol.
|
ClientSimpleScanner
ClientSimpleScanner implements a sync scanner behaviour.
|
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 |
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.
|
Consistency
Consistency defines the expected consistency level for an operation.
|
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 |
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 |
HTableMultiplexer.HTableMultiplexerStatus
HTableMultiplexerStatus keeps track of the current status of the HTableMultiplexer.
|
Increment
Used to perform Increment operations on a single row.
|
IsolationLevel
Specify Isolation levels in Scan operations.
|
MasterSwitchType
Represents the master switch type
|
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.RegionStats |
MetricsConnection.RunnerStats |
MobCompactPartitionPolicy
Enum describing the mob compact partition policy types.
|
MultiAction
Container for Actions (i.e.
|
Mutation |
NonceGenerator
NonceGenerator interface.
|
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 |
RawAsyncHBaseAdmin
The implementation of AsyncAdmin.
|
RawAsyncTable
A low level asynchronous table.
|
RawAsyncTable.CoprocessorCallable
Delegate to a protobuf rpc call.
|
RawAsyncTable.CoprocessorCallback
The callback when we want to execute a coprocessor call on a range of regions.
|
RawScanResultConsumer
Receives
Result for an asynchronous scan. |
RawScanResultConsumer.ScanController
Used to suspend or stop a scan, or get a scan cursor if available.
|
RawScanResultConsumer.ScanResumer
Used to resume a scan.
|
RegionAdminServiceCallable
Similar to RegionServerCallable but for the AdminService interface.
|
RegionLoadStats
POJO representing region server load
|
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.
|
RequestController
An interface for client request scheduling algorithm.
|
RequestController.Checker
Picks up the valid data.
|
RequestController.ReturnCode |
Result |
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.
|
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.
|
ScanResultConsumer
Receives
Result for an asynchronous scan. |
ServerStatisticTracker
Tracks the statistics for multiple regions
|
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.
|
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 |
TableDescriptorBuilder.ModifyableTableDescriptor
TODO: make this private after removing the HTableDescriptor
|
TableState
Represents table state.
|
TableState.State |
Class and Description |
---|
RegionLoadStats
POJO representing region server load
|
Class and Description |
---|
DoNotRetryRegionException
Similar to RegionException, but disables retries.
|
Class and Description |
---|
MetricsConnection
This class is for maintaining the various connection statistics and publishing them through
the metrics interfaces.
|
Class and Description |
---|
Append
Performs Append operations on a single row.
|
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.
|
Mutation |
Put
Used to perform Put operations for a single row.
|
Result |
Scan
Used to perform Scan operations.
|
Scan.ReadType |
SnapshotType
POJO representing the snapshot type
|
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.
|
Result |
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 |
---|
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 |
---|
Action
A Get, Put, Increment, Append, or Delete associated with it's region.
|
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.
|
CompactionState
POJO representing the compaction state
|
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.
|
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
|
MultiResponse
A container for Result objects, grouped by regionName.
|
Put
Used to perform Put operations for a single row.
|
RegionLoadStats
POJO representing region server load
|
Result |
RowMutations
Performs multiple mutations atomically on a single row.
|
Scan
Used to perform Scan operations.
|
SingleResponse
Class for single action response
|
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 |
---|
SnapshotDescription
The POJO equivalent of HBaseProtos.SnapshotDescription
|
Class and Description |
---|
ClusterConnection
Internal methods on Connection that should not be used by user code.
|
Copyright © 2007–2017 The Apache Software Foundation. All rights reserved.