Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.exceptions | |
org.apache.hadoop.hbase.mapred |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.mapreduce |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.snapshot |
Class and Description |
---|
ColumnFamilyDescriptor
An ColumnFamilyDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
CompactionState
POJO representing the compaction state
|
CoprocessorDescriptor
CoprocessorDescriptor contains the details about how to build a coprocessor.
|
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.
|
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.
|
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 . |
AsyncBufferedMutator
Used to communicate with a single HBase table in batches.
|
AsyncBufferedMutatorBuilder
For creating
AsyncBufferedMutator . |
AsyncConnection
The asynchronous version of Connection.
|
AsyncTable
The interface for asynchronous version of Table.
|
AsyncTable.CoprocessorCallback
The callback when we want to execute a coprocessor call on a range of regions.
|
AsyncTableBuilder
For creating
AsyncTable . |
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 . |
CheckAndMutate
Used to perform CheckAndMutate operations.
|
CheckAndMutate.Builder
A builder class for building a CheckAndMutate object.
|
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.
|
ColumnFamilyDescriptorBuilder |
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.
|
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 |
Get
Used to perform Get operations on a single row.
|
HTableMultiplexer.HTableMultiplexerStatus
Deprecated.
since 2.2.0, will be removed in 3.0.0, without replacement. Please use
BufferedMutator for batching mutations. |
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.
|
MasterSwitchType
Represents the master switch type
|
MobCompactPartitionPolicy
Enum describing the mob compact partition policy types.
|
Mutation |
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
|
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.
|
RegionLoadStats
POJO representing region server load
|
RegionLocator
Used to view region location information for a single HBase table.
|
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.
|
RetriesExhaustedWithDetailsException
This subclass of
RetriesExhaustedException
is thrown when we have more information about which rows were causing which
exceptions on what servers. |
Row
Has a row.
|
RowMutations
Performs multiple mutations atomically on a single row.
|
Scan
Used to perform Scan operations.
|
Scan.ReadType |
ScanResultConsumer
Receives
Result for an asynchronous scan. |
ScanResultConsumerBase
The base interface for scan result consumer.
|
ServerType
Select server type i.e destination for RPC request associated with ring buffer.
|
ServiceCaller
Delegate to a protobuf rpc call.
|
SnapshotDescription
The POJO equivalent of HBaseProtos.SnapshotDescription
|
SnapshotType
POJO representing the snapshot type
|
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
Convenience class for composing an instance of
TableDescriptor . |
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.
|
Result |
Scan
Used to perform Scan operations.
|
Table
Used to communicate with a single HBase table.
|
Class and Description |
---|
Admin
The administrative API for HBase.
|
Mutation |
Put
Used to perform Put operations for a single row.
|
RegionLocator
Used to view region location information for a single HBase 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... |
Class and Description |
---|
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).
|
Class and Description |
---|
SnapshotDescription
The POJO equivalent of HBaseProtos.SnapshotDescription
|
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.