| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
Abortable
Interface to support the aborting of a given server or client. 
 | 
class  | 
AuthUtil
Utility methods for helping with security tasks. 
 | 
class  | 
CallDroppedException
Returned to the clients when their request was discarded due to server being overloaded. 
 | 
class  | 
CallQueueTooBigException  | 
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  | 
HBaseTestingUtility
Facility for testing HBase. 
 | 
class  | 
HColumnDescriptor
An HColumnDescriptor contains information about a column family such as the
 number of versions, compression settings, etc. 
 | 
class  | 
HRegionInfo
Information about a region. 
 | 
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  | 
KeepDeletedCells
Ways to keep cells marked for delete around. 
 | 
class  | 
LocalHBaseCluster
This class creates a single process HBase cluster. 
 | 
class  | 
MiniHBaseCluster
This class creates a single process HBase cluster. 
 | 
class  | 
NamespaceDescriptor
Namespace POJO class. 
 | 
static class  | 
NamespaceDescriptor.Builder  | 
class  | 
ProcedureInfo
Procedure information 
 | 
class  | 
RegionLoad
Encapsulates per-region load metrics. 
 | 
class  | 
RegionTooBusyException
Thrown by a region server if it will block and wait to serve a request. 
 | 
interface  | 
Server
Defines the set of shared functions implemented by HBase servers (Masters
 and RegionServers). 
 | 
class  | 
ServerLoad
This class is used for exporting current state of load on a RegionServer. 
 | 
class  | 
ServerName
Instance of an HBase ServerName. 
 | 
interface  | 
Stoppable
Implementers are Stoppable. 
 | 
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 | Interface and Description | 
|---|---|
interface  | 
BackupCopyService  | 
class  | 
BackupDriver  | 
class  | 
BackupInfo
An object to encapsulate the information for each backup request 
 | 
class  | 
BackupRequest
POJO class for backup request 
 | 
class  | 
BackupRestoreClientFactory  | 
class  | 
BackupRestoreServerFactory  | 
class  | 
BackupStatus
Backup status and related information encapsulated for a table. 
 | 
class  | 
HBackupFileSystem
View to an on-disk Backup Image FileSytem
 Provides the set of methods necessary to interact with the on-disk Backup Image data. 
 | 
interface  | 
IncrementalRestoreService  | 
interface  | 
RestoreClient  | 
class  | 
RestoreRequest  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
BackupCommands
General backup commands, options and usage messages 
 | 
class  | 
BackupException
Backup exception 
 | 
class  | 
BackupManager
Handles backup requests on server-side, creates backup context records in hbase:backup
 to keep track backup. 
 | 
class  | 
BackupManifest
Backup manifest Contains all the meta data of a backup image. 
 | 
class  | 
BackupSystemTable
This class provides 'hbase:backup' table API 
 | 
class  | 
BackupSystemTableHelper
A collection for methods used by BackupSystemTable. 
 | 
class  | 
IncrementalBackupManager
After a full backup was created, the incremental backup will only store the changes made
 after the last full or incremental backup. 
 | 
class  | 
RestoreClientImpl
The main class which interprets the given arguments and trigger restore operation. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
MapReduceBackupCopyService
Copier for backup operation. 
 | 
class  | 
MapReduceRestoreService  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
BackupLogCleaner
Implementation of a log cleaner that checks if a log is still scheduled for
 incremental backup before deleting it when its TTL is over. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
BackupClientUtil
A collection of methods used by multiple classes to backup HBase tables. 
 | 
class  | 
BackupServerUtil
A collection for methods used by multiple classes to backup HBase tables. 
 | 
class  | 
BackupSet
Backup set is a named group of HBase tables,
 which are managed together by Backup/Restore  
 framework. 
 | 
class  | 
RestoreServerUtil
A collection for methods used by multiple classes to restore HBase tables. 
 | 
| 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 | Interface and Description | 
|---|---|
interface  | 
Admin
The administrative API for HBase. 
 | 
static class  | 
Admin.MasterSwitchType  | 
interface  | 
BackupAdmin
The administrative API for HBase Backup. 
 | 
interface  | 
BufferedMutator
Used to communicate with a single HBase table similar to  
Table but meant for
 batched, asynchronous puts. | 
static interface  | 
BufferedMutator.ExceptionListener
Listens for asynchronous exceptions on a  
BufferedMutator. | 
class  | 
BufferedMutatorImpl
 Used to communicate with a single HBase table similar to  
HTable
 but meant for batched, potentially asynchronous puts. | 
class  | 
BufferedMutatorParams
Parameters for instantiating a  
BufferedMutator. | 
interface  | 
Connection
A cluster connection encapsulating lower level individual connections to actual servers and
 a connection to zookeeper. 
 | 
class  | 
ConnectionFactory
A non-instantiable class that manages creation of  
Connections. | 
class  | 
Consistency
Consistency defines the expected consistency level for an operation. 
 | 
class  | 
CoprocessorHConnection
Connection to an HTable from within a Coprocessor. 
 | 
class  | 
Durability
Enum describing the durability guarantees for tables and  
Mutations
 Note that the items must be sorted in order of increasing durability | 
class  | 
HBaseAdmin
HBaseAdmin is no longer a client API. 
 | 
protected static class  | 
HBaseAdmin.ProcedureFuture<V>
Future that waits on a procedure result. 
 | 
protected static class  | 
HBaseAdmin.TableFuture<V>  | 
class  | 
HBaseBackupAdmin
The administrative API implementation for HBase Backup . 
 | 
class  | 
HConnectionManager
Deprecated. 
 
Please use ConnectionFactory instead 
 | 
class  | 
HTableMultiplexer
HTableMultiplexer provides a thread-safe non blocking PUT API across all the tables. 
 | 
static class  | 
HTableMultiplexer.HTableMultiplexerStatus
HTableMultiplexerStatus keeps track of the current status of the HTableMultiplexer. 
 | 
class  | 
Mutation  | 
class  | 
Operation
Superclass for any type that maps to a potentially application-level query. 
 | 
class  | 
OperationWithAttributes  | 
class  | 
Query  | 
interface  | 
RegionLocator
Used to view region location information for a single HBase table. 
 | 
class  | 
RegionOfflineException
Thrown when a table can not be located 
 | 
class  | 
RowMutations
Performs multiple mutations atomically on a single row. 
 | 
interface  | 
Table
Used to communicate with a single HBase table. 
 | 
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  | 
ClientBackoffPolicyFactory  | 
| 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  | 
ScanMetrics
Provides client-side metrics related to scan operations. 
 | 
| 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  | 
CodecPerformance
Do basic codec performance eval. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ConfigurationManager
Maintains the set of all the classes which would like to get notified
 when the Configuration is reloaded from the disk in the Online Configuration
 Change mechanism, which lets you update certain configuration properties
 on-the-fly, without having to restart the cluster. 
 | 
interface  | 
ConfigurationObserver
Every class that wants to observe changes in Configuration properties,
 must implement interface (and also, register itself with the
  
ConfigurationManager object. | 
| 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 Message,T extends Message>
This class demonstrates how to implement atomic read-modify-writes
 using  
Region.processRowsWithLocks(org.apache.hadoop.hbase.regionserver.RowProcessor<?, ?>) and Coprocessor endpoints. | 
class  | 
BaseWALObserver
An abstract class that implements WALObserver. 
 | 
interface  | 
BulkLoadObserver
Coprocessors implement this interface to observe and mediate bulk load operations. 
 | 
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  | 
SingletonCoprocessorService
Coprocessor endpoints registered once per server and providing protobuf services should implement
 this interface and return the  
Service instance via SingletonCoprocessorService.getService(). | 
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  | 
ClientExceptionsUtil  | 
class  | 
ConnectionClosingException
Thrown when the client believes that we are trying to communicate to has
 been repeatedly unresponsive for a while. 
 | 
class  | 
OperationConflictException
The exception that is thrown if there's duplicate execution of non-idempotent operation. 
 | 
class  | 
PreemptiveFastFailException
Thrown when the client believes that we are trying to communicate to has
 been repeatedly unresponsive for a while. 
 | 
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. 
 | 
class  | 
UnknownProtocolException
An error requesting an RPC protocol that the server is not serving. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
FuzzyRowFilter
This is optimized version of a standard FuzzyRowFilter Filters data based on fuzzy row key. 
 | 
class  | 
MultiRowRangeFilter
Filter to support scan multiple row key ranges. 
 | 
static class  | 
MultiRowRangeFilter.RowRange  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AdminAuthorizedServlet
General servlet which is admin-authorized. 
 | 
class  | 
HttpServer
Create a Jetty embedded server to answer http requests. 
 | 
interface  | 
ServerConfigurationKeys
This interface contains constants for configuration keys used
 in the hbase http server code. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
LogLevel
Change log level in runtime. 
 | 
| 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. 
 | 
static class  | 
Encryption.Context
Crypto context 
 | 
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  
HFiles. | 
| 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  | 
CallRunner
The request processing logic, which is usually executed in thread pools provided by an
  
RpcScheduler. | 
class  | 
CallTimeoutException
Client-side call timeout 
 | 
class  | 
CoprocessorRpcChannel
Base class which provides clients with an RPC connection to
 call coprocessor endpoint  
com.google.protobuf.Services. | 
class  | 
FailedServerException
Indicates that we're trying to connect to a already known as dead server. 
 | 
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. | 
class  | 
RpcScheduler
An interface for RPC request scheduling algorithm. 
 | 
class  | 
RpcServer
An RPC server that hosts protobuf described Services. 
 | 
class  | 
RpcServer.Call
Datastructure that holds all necessary to a method invocation and then afterward, carries
 the result. 
 | 
interface  | 
RpcServerInterface  | 
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  
MultiTableInputFormats. | 
class  | 
PutCombiner<K>
Combine Puts. 
 | 
class  | 
TableSnapshotInputFormat
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot. 
 | 
class  | 
TableSnapshotInputFormatImpl
Hadoop MR 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  | 
MasterProcedureEnv  | 
class  | 
MasterProcedureQueue
ProcedureRunnableSet for the Master Procedures. 
 | 
class  | 
MasterProcedureUtil  | 
class  | 
ProcedurePrepareLatch
Latch used by the Master to have the prepare() sync behaviour for old
 clients, that can only get exceptions in a synchronous way. 
 | 
class  | 
ProcedureSyncWait
Helper to synchronously wait on conditions. 
 | 
interface  | 
TableProcedureInterface
Procedures that operates on a specific Table (e.g. 
 | 
| 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  | 
MobConstants
The constants used in mob. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
Sweeper
The sweep tool. 
 | 
| 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  | 
OnePhaseProcedure<TEnvironment>  | 
class  | 
Procedure<TEnvironment>
Base Procedure class responsible to handle the Procedure Metadata
 e.g. 
 | 
class  | 
ProcedureExecutor<TEnvironment>
Thread Pool that executes the submitted procedures. 
 | 
class  | 
ProcedureFairRunQueues<TKey,TQueue extends ProcedureFairRunQueues.FairObject>
This class is a container of queues that allows to select a queue
 in a round robin fashion, considering priority of the queue. 
 | 
interface  | 
ProcedureRunnableSet
Keep track of the runnable procedures 
 | 
class  | 
ProcedureSimpleRunQueue
Simple runqueue for the procedures 
 | 
class  | 
RemoteProcedureException
A RemoteProcedureException is an exception from another thread or process. 
 | 
class  | 
SequentialProcedure<TEnvironment>
A SequentialProcedure describes one step in a procedure chain. 
 | 
class  | 
StateMachineProcedure<TEnvironment,TState>
Procedure described by a series of steps. 
 | 
class  | 
TwoPhaseProcedure<TEnvironment>  | 
| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
ProcedureStore
The ProcedureStore is used by the executor to persist the state of each procedure execution. 
 | 
class  | 
ProcedureStoreTracker
Keeps track of live procedures. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ProcedureWALFile
Describes a WAL File 
 | 
class  | 
ProcedureWALFormat
Helper class that contains the WAL serialization utils. 
 | 
class  | 
ProcedureWALFormatReader
Helper class that loads the procedures stored in a WAL 
 | 
class  | 
ProcedureWALPrettyPrinter
ProcedureWALPrettyPrinter prints the contents of a given ProcedureWAL file 
 | 
class  | 
WALProcedureStore
WAL implementation of the ProcedureStore. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ByteSlot
Similar to the ByteArrayOutputStream, with the exception that we can prepend an header. 
 | 
class  | 
StringUtils  | 
class  | 
TimeoutBlockingQueue<E>  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ActivePolicyEnforcement
A class to ease dealing with tables that have and do not have violation policies
 being enforced in a uniform manner. 
 | 
class  | 
AverageIntervalRateLimiter
This limiter will refill resources at every TimeUnit/resources interval. 
 | 
class  | 
DefaultOperationQuota  | 
class  | 
FixedIntervalRateLimiter
With this limiter resources will be refilled only after a fixed interval of time. 
 | 
class  | 
MasterQuotaManager
Master Quota Manager. 
 | 
interface  | 
OperationQuota
Interface that allows to check the quota available for an operation. 
 | 
class  | 
QuotaCache
Cache that keeps track of the quota settings for the users and tables that are interacting with
 it. 
 | 
class  | 
QuotaExceededException
Generic quota exceeded exception 
 | 
class  | 
QuotaFilter
Filter to use to filter the QuotaRetriever results. 
 | 
interface  | 
QuotaLimiter
Internal interface used to interact with the user/table quota. 
 | 
class  | 
QuotaLimiterFactory  | 
class  | 
QuotaRetriever
Scanner to iterate over the quota settings. 
 | 
class  | 
QuotaScope
Describe the Scope of the quota rules. 
 | 
class  | 
QuotaSettings  | 
class  | 
QuotaSettingsFactory  | 
class  | 
QuotaState
In-Memory state of table or namespace quotas 
 | 
class  | 
QuotaTableUtil
Helper class to interact with the quota table. 
 | 
class  | 
QuotaType
Describe the Quota Type. 
 | 
class  | 
QuotaUtil
Helper class to interact with the quota table 
 | 
class  | 
RateLimiter
Simple rate limiter. 
 | 
class  | 
RegionServerRpcQuotaManager
Region Server Quota Manager. 
 | 
class  | 
RegionServerSpaceQuotaManager
A manager for filesystem space quotas in the RegionServer. 
 | 
class  | 
SpaceLimitingException
An Exception that is thrown when a space quota is in violation. 
 | 
interface  | 
SpaceQuotaSnapshotNotifier
An interface which abstract away the action taken to enable or disable
 a space quota violation policy across the HBase cluster. 
 | 
class  | 
SpaceViolationPolicy
Enumeration that represents the action HBase will take when a space quota is violated. 
 | 
class  | 
ThrottleType
Describe the Throttle Type. 
 | 
class  | 
ThrottlingException
Describe the throttling result. 
 | 
static class  | 
ThrottlingException.Type  | 
class  | 
TimeBasedLimiter
Simple time based limiter that checks the quota Throttle 
 | 
class  | 
UserQuotaState
In-Memory state of the user quotas 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
BaseRowProcessor<S extends Message,T extends Message>
Base class for RowProcessor with some default implementations. 
 | 
class  | 
BloomType  | 
interface  | 
FavoredNodesForRegion
Abstraction that allows different modules in RegionServer to update/get
 the favored nodes information for regions. 
 | 
interface  | 
HeapMemoryTuner
Makes the decision regarding proper sizing of the heap memory. 
 | 
interface  | 
InternalScanner
Internal scanners differ from client-side scanners in that they operate on
 HStoreKeys and byte[] instead of RowResults. 
 | 
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  | 
NoLimitScannerContext
This is a special  
ScannerContext subclass that is designed to be used globally when
 limits should not be enforced during invocations of InternalScanner.next(java.util.List)
 or InternalScanner.next(java.util.List). | 
class  | 
NoSuchColumnFamilyException
Thrown if request for nonexistent column family. 
 | 
interface  | 
OnlineRegions
Interface to Map of online regions. 
 | 
interface  | 
Region
Regions store data for a certain region of a table. 
 | 
class  | 
RegionCoprocessorHost
Implements the coprocessor environment and runtime support for coprocessors
 loaded within a  
Region. | 
interface  | 
RegionMergeTransaction
Executes region merge as a "transaction". 
 | 
class  | 
RegionMergeTransactionFactory
A factory for creating RegionMergeTransactions, which execute region split as a "transaction". 
 | 
interface  | 
RegionScanner
RegionScanner describes iterators over rows in an HRegion. 
 | 
class  | 
RegionServerAbortedException
Thrown by the region server when it is aborting. 
 | 
class  | 
RegionServerCoprocessorHost  | 
class  | 
RegionServerRunningException
Thrown if the region server log directory exists (which indicates another
 region server is running at the same address) 
 | 
interface  | 
RegionServerServices
Services provided by  
HRegionServer | 
class  | 
RegionServerStoppedException
Thrown by the region server when it is in shutting down state. 
 | 
interface  | 
RowProcessor<S extends Message,T extends Message>
Defines the procedure to atomically perform multiple scans and mutations
 on a HRegion. 
 | 
interface  | 
RpcSchedulerFactory
A factory class that constructs an  
RpcScheduler. | 
class  | 
ScannerContext
ScannerContext instances encapsulate limit tracking AND progress towards those limits during
 invocations of  
InternalScanner.next(java.util.List) and
 InternalScanner.next(java.util.List). | 
class  | 
ScanType
Enum to distinguish general scan types. 
 | 
class  | 
SimpleRpcSchedulerFactory
Constructs a  
SimpleRpcScheduler. | 
interface  | 
SplitTransaction
Executes region split as a "transaction". 
 | 
class  | 
SplitTransactionFactory
A factory for creating SplitTransactions, which execute region split as a "transaction". 
 | 
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  | 
FailedSyncBeforeLogCloseException
Thrown when we fail close of the write-ahead-log file. 
 | 
class  | 
HLogPrettyPrinter
Deprecated. 
 
use the "hbase wal" command 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ReplicationPeerConfig
A configuration for the replication peer cluster. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
RSGroupInfo
Stores the group information of region server groups. 
 | 
| 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. 
 | 
static class  | 
Permission.Action  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
FsDelegationToken
Helper class to obtain a filesystem delegation token. 
 | 
class  | 
TokenUtil
Utility methods for obtaining authentication tokens. 
 | 
| 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. 
 | 
class  | 
VisibilityControllerNotReadyException  | 
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  | 
PBType<T extends Message>
A base-class for  
DataType implementations backed by protobuf. | 
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 DataTypes encode one of a fixed
 collection of Objects. | 
class  | 
Union4<A,B,C,D>
The  
Union family of DataTypes encode one of a fixed
 collection of Objects. | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AbstractByteRange
An abstract implementation of the ByteRange API 
 | 
class  | 
AbstractPositionedByteRange
Extends the basic  
SimpleByteRange implementation with position
 support. | 
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  | 
Counter
High scalable counter. 
 | 
class  | 
DirectMemoryUtils
Utilities for interacting with and monitoring DirectByteBuffer allocations. 
 | 
class  | 
EncryptionTest  | 
class  | 
FastLongHistogram
FastLongHistogram is a thread-safe class that estimate distribution of data and computes the
 quantiles. 
 | 
class  | 
FileSystemVersionException
Thrown when the file system needs to be upgraded 
 | 
class  | 
ForeignExceptionUtil
Helper to convert Exceptions and StackTraces from/to protobuf. 
 | 
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  | 
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  | 
ReadOnlyByteRangeException
Exception thrown when a read only byte range is modified 
 | 
class  | 
RegionSizeCalculator
Computes size of each region for given table and given column families. 
 | 
class  | 
SimpleByteRange
A read only version of the  
ByteRange. | 
class  | 
SimpleMutableByteRange
A basic mutable  
ByteRange implementation. | 
class  | 
SimplePositionedByteRange
Extends the basic  
SimpleMutableByteRange implementation with position
 support and it is a readonly version. | 
class  | 
SimplePositionedMutableByteRange
Extends the basic  
AbstractPositionedByteRange implementation with
 position support and it is a mutable version. | 
class  | 
UnsafeAccess  | 
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  | 
DefaultWALProvider
A WAL Provider that returns a single thread safe WAL that writes to Hadoop FS. 
 | 
interface  | 
WAL
A Write Ahead Log (WAL) provides service for reading, writing waledits. 
 | 
class  | 
WALPrettyPrinter
WALPrettyPrinter prints the contents of a given WAL with a variety of
 options affecting formatting and extent of content. 
 | 
| 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. 
 |