Modifier and Type | Interface and Description |
---|---|
interface |
Cell
The unit of storage in HBase consisting of the following fields:
|
class |
CellComparator
Compare two HBase cells.
|
class |
CellUtil
Utility methods helpful slinging
Cell instances. |
class |
ClusterStatus
Status information on the HBase cluster.
|
class |
HBaseInterfaceAudience
This class defines constants for different classes of hbase limited private apis
|
class |
HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
|
class |
HColumnDescriptor
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
|
class |
HRegionInfo
HRegion information.
|
class |
HRegionLocation
Data structure to hold HRegionInfo and the address for the hosting
HRegionServer.
|
class |
HTableDescriptor
HTableDescriptor contains the details about an HBase table such as the descriptors of
all the column families, is the table a catalog table,
-ROOT- or
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 |
InvalidFamilyOperationException
Thrown if a request is table schema modification is requested but
made for an invalid family name.
|
class |
LocalHBaseCluster
This class creates a single process HBase cluster.
|
class |
NamespaceDescriptor
Namespace POJO class.
|
class |
RegionLoad
Encapsulates per-region load metrics.
|
class |
RegionTooBusyException
Thrown by a region server if it will block and wait to serve a request.
|
class |
ServerLoad
This class is used for exporting current state of load on a RegionServer.
|
class |
ServerName
Instance of an HBase ServerName.
|
class |
TableInfoMissingException
Failed to find .tableinfo file under table dir
|
class |
TableName
Immutable POJO class for representing a table name.
|
class |
Tag
Tags are part of cells and helps to add metadata about the KVs.
|
class |
TagType |
class |
ZooKeeperConnectionException
Thrown if the client can't connect to zookeeper
|
Modifier and Type | Class and Description |
---|---|
class |
InterfaceAudience
Annotation to inform users of a package, class or method's intended audience.
|
class |
InterfaceStability
Annotation to inform users of how much to rely on a particular package,
class or method not changing over time.
|
Modifier and Type | Class and Description |
---|---|
class |
ClientSmallReversedScanner
Client scanner for small reversed scan.
|
class |
ClientSmallScanner
Client scanner for small scan.
|
class |
CoprocessorHConnection
Connection to an HTable from within a Coprocessor.
|
class |
Durability
Enum describing the durability guarantees for tables and
Mutation s
Note that the items must be sorted in order of increasing durability |
class |
HBaseAdmin
Provides an interface to manage HBase database table metadata + general
administrative functions.
|
class |
HConnectionManager
A non-instantiable class that manages creation of
HConnection s. |
class |
HTableMultiplexer
HTableMultiplexer provides a thread-safe non blocking PUT API across all the tables.
|
class |
Mutation |
class |
Operation
Superclass for any type that maps to a potentially application-level query.
|
class |
OperationWithAttributes |
class |
Query |
class |
RegionOfflineException
Thrown when a table can not be located
|
class |
ReversedClientScanner
A reversed client scanner which support backward scanning
|
class |
ReversedScannerCallable
A reversed ScannerCallable which supports backward scanning.
|
class |
RowMutations
Performs multiple mutations atomically on a single row.
|
class |
TableSnapshotScanner
A Scanner which performs a scan over snapshot files.
|
class |
UnmodifyableHTableDescriptor
Read-only table descriptor.
|
class |
WrongRowIOException |
Modifier and Type | Class and Description |
---|---|
class |
DoubleColumnInterpreter
a concrete column interpreter implementation.
|
class |
RowProcessorClient
Convenience class that is used to make RowProcessorEndpoint invocations.
|
Modifier and Type | Class and Description |
---|---|
class |
ReplicationAdmin
This class provides the administrative interface to HBase cluster
replication.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseMasterAndRegionObserver |
class |
BaseMasterObserver |
class |
BaseRegionObserver
An abstract class that implements RegionObserver.
|
class |
BaseRegionServerObserver
An abstract class that implements RegionServerObserver.
|
class |
BaseRowProcessorEndpoint<S extends com.google.protobuf.Message,T extends com.google.protobuf.Message>
This class demonstrates how to implement atomic read-modify-writes
using
HRegion.processRowsWithLocks(org.apache.hadoop.hbase.regionserver.RowProcessor<?, ?>, long, long) and Coprocessor endpoints. |
class |
BaseWALObserver
An abstract class that implements WALObserver.
|
class |
CoprocessorException
Thrown if a coprocessor encounters any exception.
|
class |
CoprocessorHost<E extends CoprocessorEnvironment>
Provides the common setup framework and runtime services for coprocessor
invocation from HBase services.
|
interface |
CoprocessorService
Coprocessor endpoints providing protobuf services should implement this
interface and return the
Service instance via CoprocessorService.getService() . |
interface |
EndpointObserver
Coprocessors implement this interface to observe and mediate endpoint invocations
on a region.
|
interface |
MasterCoprocessorEnvironment |
interface |
MasterObserver
Defines coprocessor hooks for interacting with operations on the
HMaster process. |
class |
MultiRowMutationEndpoint
This class demonstrates how to implement atomic multi row transactions using
HRegion.mutateRowsWithLocks(java.util.Collection, java.util.Collection)
and Coprocessor endpoints. |
class |
ObserverContext<E extends CoprocessorEnvironment>
Carries the execution state for a given invocation of an Observer coprocessor
(
RegionObserver , MasterObserver , or WALObserver )
method. |
interface |
RegionCoprocessorEnvironment |
interface |
RegionObserver
Coprocessors implement this interface to observe and mediate client actions
on the region.
|
interface |
WALCoprocessorEnvironment |
interface |
WALObserver
It's provided to have a way for coprocessors to observe, rewrite,
or skip WALEdits as they are being written to the WAL.
|
Modifier and Type | Class and Description |
---|---|
class |
ForeignException
A ForeignException is an exception from another thread or process.
|
interface |
ForeignExceptionListener
The ForeignExceptionListener is an interface for objects that can receive a ForeignException.
|
class |
TimeoutException
Exception for timeout of a task.
|
Modifier and Type | Class and Description |
---|---|
class |
OperationConflictException
The exception that is thrown if there's duplicate execution of non-idempotent operation.
|
class |
RegionInRecoveryException
Thrown when a read request issued against a region which is in recovering state.
|
class |
RegionMovedException
Subclass if the server knows the region is now on another server.
|
class |
RegionOpeningException
Subclass if the server knows the region is now on another server.
|
Modifier and Type | Class and Description |
---|---|
class |
FuzzyRowFilter
Filters data based on fuzzy row key.
|
Modifier and Type | Class and Description |
---|---|
class |
ByteBufferOutputStream
Not thread safe!
|
interface |
CellOutputStream
Accepts a stream of Cells.
|
Modifier and Type | Class and Description |
---|---|
static class |
Compression.Algorithm
Compression algorithms.
|
Modifier and Type | Class and Description |
---|---|
class |
Cipher
A common interface for a cryptographic algorithm.
|
interface |
CipherProvider
An CipherProvider contributes support for various cryptographic
Ciphers.
|
class |
Context
Crypto context.
|
interface |
Decryptor
Decryptors apply a cipher to an InputStream to recover plaintext.
|
class |
DefaultCipherProvider
The default cipher provider.
|
class |
Encryption
A facade for encryption algorithms and related support.
|
interface |
Encryptor
Encryptors apply a cipher to an OutputStream to produce ciphertext.
|
interface |
KeyProvider
KeyProvider is a interface to abstract the different methods of retrieving
key material from key storage such as Java key store.
|
class |
KeyStoreKeyProvider
A basic KeyProvider that can resolve keys from a protected KeyStore file
on the local filesystem.
|
Modifier and Type | Class and Description |
---|---|
class |
AES
AES-128, provided by the JCE
|
class |
AESDecryptor |
class |
AESEncryptor |
Modifier and Type | Class and Description |
---|---|
class |
DataBlockEncoding
Provide access to all data block encoding algorithms.
|
Modifier and Type | Class and Description |
---|---|
class |
HFilePrettyPrinter
Implements pretty-printing functionality for
HFile s. |
Modifier and Type | Class and Description |
---|---|
class |
BadAuthException |
class |
BalancedQueueRpcExecutor
An
RpcExecutor that will balance requests evenly across all its queues, but still remains
efficient with a single queue via an inlinable queue balancing mechanism. |
class |
CallerDisconnectedException
Exception indicating that the remote host making this IPC lost its
IPC connection.
|
class |
CoprocessorRpcChannel
Base class which provides clients with an RPC connection to
call coprocessor endpoint
Service s. |
class |
FatalConnectionException
Thrown when server finds fatal issue w/ connection setup: e.g.
|
interface |
PriorityFunction
Function to figure priority of incoming request.
|
class |
RemoteWithExtrasException
A
RemoteException with some extra information. |
static class |
RpcClient.CallTimeoutException
Client-side call timeout
|
static class |
RpcClient.FailedServerException |
class |
RpcExecutor |
class |
RpcScheduler
An interface for RPC request scheduling algorithm.
|
class |
RpcServer
An RPC server that hosts protobuf described Services.
|
interface |
RpcServerInterface
RpcServer Interface.
|
class |
RWQueueRpcExecutor
RPC Executor that uses different queues for reads and writes.
|
class |
ServerNotRunningYetException |
class |
SimpleRpcScheduler
A scheduler that maintains isolated handler pools for general, high-priority and replication
requests.
|
class |
StoppedRpcClientException |
class |
UnsupportedCellCodecException |
class |
UnsupportedCompressionCodecException |
class |
WrongVersionException |
Modifier and Type | Class and Description |
---|---|
class |
TableSnapshotInputFormat
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
|
Modifier and Type | Class and Description |
---|---|
class |
CellCreator
Facade to create Cells for HFileOutputFormat.
|
class |
HFileOutputFormat2
Writes HFiles.
|
class |
JobUtil
Utility methods to interact with a job.
|
class |
MultiTableInputFormat
Convert HBase tabular data from multiple scanners into a format that
is consumable by Map/Reduce.
|
class |
MultiTableInputFormatBase
A base for
MultiTableInputFormat s. |
class |
PutCombiner<K>
Combine Puts.
|
class |
TableSnapshotInputFormat
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
|
class |
TableSnapshotInputFormatImpl
API-agnostic implementation for mapreduce over table snapshots.
|
class |
TableSplit
A table split corresponds to a key range (low, high) and an optional scanner.
|
class |
TextSortReducer
Emits Sorted KeyValues.
|
class |
TsvImporterTextMapper
Write table content out to map output files.
|
interface |
VisibilityExpressionResolver
Interface to convert visibility expressions into Tags for storing along with Cells in HFiles.
|
Modifier and Type | Class and Description |
---|---|
class |
MetricsMaster
This class is for maintaining the various master statistics
and publishing them through the metrics interfaces.
|
class |
RegionPlan
Stores the plan for the move of an individual region.
|
static class |
RegionState.State |
Modifier and Type | Class and Description |
---|---|
class |
DisabledTableSnapshotHandler
Take a snapshot of a disabled table.
|
class |
SnapshotFileCache
Intelligently keep track of all the files for all the snapshots.
|
class |
SnapshotHFileCleaner
Implementation of a file cleaner that checks if a hfile is still used by snapshots of HBase
tables.
|
class |
SnapshotLogCleaner
Implementation of a log cleaner that checks if a log is still used by
snapshots of HBase tables.
|
Modifier and Type | Class and Description |
---|---|
class |
MasterProcedureManager
A life-cycle management interface for globally barriered procedures on master.
|
class |
ProcedureManager |
class |
ProcedureManagerHost<E extends ProcedureManager>
Provides the common setup framework and runtime services for globally
barriered procedure invocation from HBase services.
|
class |
RegionServerProcedureManager
A life-cycle management interface for globally barriered procedures on
region servers.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseRowProcessor<S extends com.google.protobuf.Message,T extends com.google.protobuf.Message>
Base class for RowProcessor with some default implementations.
|
class |
BloomType |
class |
LeaseException
Reports a problem with a lease
|
class |
MetricsRegionServer
This class is for maintaining the various regionserver statistics
and publishing them through the metrics interfaces.
|
class |
NoSuchColumnFamilyException
Thrown if request for nonexistent column family.
|
class |
RegionCoprocessorHost
Implements the coprocessor environment and runtime support for coprocessors
loaded within a
HRegion . |
class |
RegionServerCoprocessorHost |
class |
RegionServerRunningException
Thrown if the region server log directory exists (which indicates another
region server is running at the same address)
|
class |
RegionServerStoppedException
Thrown by the region server when it is in shutting down state.
|
interface |
RowProcessor<S extends com.google.protobuf.Message,T extends com.google.protobuf.Message>
Defines the procedure to atomically perform multiple scans and mutations
on a HRegion.
|
interface |
RpcSchedulerFactory
A factory class that constructs an
RpcScheduler for
a region server. |
class |
SimpleRpcSchedulerFactory
Constructs a
SimpleRpcScheduler . |
interface |
Store
Interface for objects that hold a column family in a Region.
|
Modifier and Type | Class and Description |
---|---|
class |
CompactionRequest
This class holds all logical details necessary to run a compaction.
|
Modifier and Type | Class and Description |
---|---|
class |
FailedLogCloseException
Thrown when we fail close of the write-ahead-log file.
|
class |
HLogPrettyPrinter
HLogPrettyPrinter prints the contents of a given HLog with a variety of
options affecting formatting and extent of content.
|
Modifier and Type | Class and Description |
---|---|
class |
AccessDeniedException
Exception thrown by access-related methods.
|
class |
EncryptionUtil
Some static utility methods for encryption uses in hbase-client.
|
class |
SecurityUtil
Security related generic utility methods.
|
Modifier and Type | Class and Description |
---|---|
class |
AccessControlClient
Utility client for doing access control admin operations.
|
interface |
AccessControlConstants |
class |
Permission
Base permissions instance representing the ability to perform a given set
of actions.
|
Modifier and Type | Class and Description |
---|---|
class |
FsDelegationToken
Helper class to obtain a filesystem delegation token.
|
Modifier and Type | Class and Description |
---|---|
class |
Authorizations
This class contains visibility labels associated with a Scan/Get deciding which all labeled data
current scan/get can access.
|
class |
CellVisibility
This contains a visibility expression which can be associated with a cell.
|
class |
InvalidLabelException |
class |
LabelAlreadyExistsException |
interface |
ScanLabelGenerator
This would be the interface which would be used add labels to the RPC context
and this would be stored against the UGI.
|
class |
VisibilityClient
Utility client for doing visibility labels admin operations.
|
interface |
VisibilityExpEvaluator
During the read (ie.
|
interface |
VisibilityLabelService
The interface which deals with visibility labels and user auths admin service as well as the cell
visibility expression storage part and read time evaluation.
|
Modifier and Type | Class and Description |
---|---|
class |
CorruptedSnapshotException
Exception thrown when the found snapshot info from the filesystem is not valid
|
class |
ExportSnapshot
Export the specified snapshot to a given FileSystem.
|
class |
HBaseSnapshotException
General exception base class for when a snapshot fails
|
class |
RestoreSnapshotException
Thrown when a snapshot could not be restored due to a server-side error when restoring it.
|
class |
SnapshotCreationException
Thrown when a snapshot could not be created due to a server-side error when
taking the snapshot.
|
class |
SnapshotDoesNotExistException
Thrown when the server is looking for a snapshot but can't find the snapshot on the filesystem
|
class |
SnapshotExistsException
Thrown when a snapshot exists but should not
|
class |
SnapshotInfo
Tool for dumping snapshot information.
|
class |
TablePartiallyOpenException
Thrown if a table should be online/offline but is partially open
|
class |
UnknownSnapshotException
Exception thrown when we get a request for a snapshot we don't recognize.
|
Modifier and Type | Interface and Description |
---|---|
interface |
DataType<T>
DataType is the base class for all HBase data types. |
class |
FixedLengthWrapper<T>
Wraps an existing
DataType implementation as a fixed-length
version of itself. |
class |
OrderedBlob
A
byte[] of variable-length. |
class |
OrderedBlobVar
An alternative to
OrderedBlob for use by Struct fields that
do not terminate the fields list. |
class |
OrderedBytesBase<T>
Base class for data types backed by the
OrderedBytes encoding
implementations. |
class |
OrderedFloat32
A
float of 32-bits using a fixed-length encoding. |
class |
OrderedFloat64
A
double of 64-bits using a fixed-length encoding. |
class |
OrderedInt16
A
short of 16-bits using a fixed-length encoding. |
class |
OrderedInt32
An
int of 32-bits using a fixed-length encoding. |
class |
OrderedInt64
A
long of 64-bits using a fixed-length encoding. |
class |
OrderedInt8
A
byte of 8-bits using a fixed-length encoding. |
class |
OrderedNumeric
An
Number of arbitrary precision and variable-length encoding. |
class |
OrderedString
A
String of variable-length. |
class |
RawByte
An
DataType for interacting with values encoded using
Bytes.putByte(byte[], int, byte) . |
class |
RawBytes
An
DataType for interacting with variable-length values
encoded using Bytes.putBytes(byte[], int, byte[], int, int) . |
class |
RawBytesFixedLength
An
DataType that encodes fixed-length values encoded using
Bytes.putBytes(byte[], int, byte[], int, int) . |
class |
RawBytesTerminated
An
DataType that encodes variable-length values encoded using
Bytes.putBytes(byte[], int, byte[], int, int) . |
class |
RawDouble
An
DataType for interacting with values encoded using
Bytes.putDouble(byte[], int, double) . |
class |
RawFloat
An
DataType for interacting with values encoded using
Bytes.putFloat(byte[], int, float) . |
class |
RawInteger
An
DataType for interacting with values encoded using
Bytes.putInt(byte[], int, int) . |
class |
RawLong
An
DataType for interacting with values encoded using
Bytes.putLong(byte[], int, long) . |
class |
RawShort
An
DataType for interacting with values encoded using
Bytes.putShort(byte[], int, short) . |
class |
RawString
An
DataType for interacting with values encoded using
Bytes.toBytes(String) . |
class |
RawStringFixedLength
An
DataType that encodes fixed-length values encoded using
Bytes.toBytes(String) . |
class |
RawStringTerminated
An
DataType that encodes variable-length values encoded using
Bytes.toBytes(String) . |
class |
Struct
Struct is a simple DataType for implementing "compound
rowkey" and "compound qualifier" schema design strategies. |
class |
StructBuilder
A helper for building
Struct instances. |
class |
StructIterator
An
Iterator over encoded Struct members. |
class |
TerminatedWrapper<T>
Wraps an existing
DataType implementation as a terminated
version of itself. |
class |
Union2<A,B>
|
class |
Union3<A,B,C>
The
Union family of DataType s encode one of a fixed
collection of Objects. |
class |
Union4<A,B,C,D>
The
Union family of DataType s encode one of a fixed
collection of Objects. |
Modifier and Type | Class and Description |
---|---|
class |
ByteBufferUtils
Utility functions for working with byte buffers, such as reading/writing
variable-length long numbers.
|
interface |
ByteRange
Lightweight, reusable class for specifying ranges of byte[]'s.
|
class |
ByteRangeUtils
Utility methods for working with
ByteRange . |
class |
CompressionTest
Compression validation test.
|
class |
ConcurrentIndex<K,V>
A simple concurrent map of sets.
|
class |
DirectMemoryUtils
Utilities for interacting with and monitoring DirectByteBuffer allocations.
|
class |
FileSystemVersionException
Thrown when the file system needs to be upgraded
|
class |
FSHDFSUtils
Implementation for hdfs
|
class |
HBaseFsck
HBaseFsck (hbck) is a tool for checking and repairing region consistency and
table integrity problems in a corrupted HBase.
|
class |
JsonMapper
Utility class for converting objects to JSON
|
class |
Merge
Utility that can merge any two regions in the same table: adjacent,
overlapping or disjoint.
|
class |
Order
Used to describe or modify the lexicographical sort order of a
byte[] . |
class |
OrderedBytes
Utility class that handles ordered byte arrays.
|
interface |
PositionedByteRange
Extends
ByteRange with additional methods to support tracking a
consumers position within the viewport. |
class |
PrettyPrinter |
class |
RegionSizeCalculator
Computes size of each region for given table and given column families.
|
class |
SimpleByteRange
A basic
ByteRange implementation. |
class |
SimplePositionedByteRange
Extends the basic
SimpleByteRange implementation with position
support. |
class |
VersionInfo
This class finds the package info for hbase and the VersionAnnotation
information.
|
Modifier and Type | Class and Description |
---|---|
class |
OfflineMetaRepair
This code is used to rebuild meta off line from file system data.
|
Modifier and Type | Class and Description |
---|---|
class |
HQuorumPeer
HBase's version of ZooKeeper's QuorumPeer.
|
class |
MiniZooKeeperCluster
TODO: Most of the code in this class is ripped from ZooKeeper tests.
|
class |
ZKServerTool
Tool for reading ZooKeeper servers from HBase XML configuration and producing
a line-by-line list for use by bash scripts.
|
Copyright © 2014 The Apache Software Foundation. All rights reserved.