| Interface | Description | 
|---|---|
| Abortable | Interface to support the aborting of a given server or client. | 
| Cell | The unit of storage in HBase consisting of the following fields:
  | 
| CellBuilder | Use  CellBuilderFactoryto get CellBuilder instance. | 
| CellComparator | Comparator for comparing cells and has some specialized methods that allows comparing individual
 cell components like row, family, qualifier and timestamp | 
| CellScannable | Implementer can return a CellScanner over its Cell content. | 
| CellScanner | An interface for iterating through a sequence of cells. | 
| ClusterMetrics | Metrics information on the HBase cluster. | 
| CompoundConfiguration.ImmutableConfigMap | |
| CoordinatedStateManager | Implementations of this interface will keep and return to clients
 implementations of classes providing API to execute
 coordinated operations. | 
| Coprocessor | Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor,
 RegionServerCoprocessor, and WALCoprocessor. | 
| CoprocessorEnvironment<C extends Coprocessor> | Coprocessor environment state. | 
| ExtendedCell | Extension to  Cellwith server side required functions. | 
| ExtendedCellBuilder | For internal purpose. | 
| HDFSBlocksDistribution.Visitor | Implementations 'visit' hostAndWeight. | 
| KeyValue.SamePrefixComparator<T> | Avoids redundant comparisons for better performance. | 
| MetaTableAccessor.CloseableVisitor | Implementations 'visit' a catalog table row but with close() at the end. | 
| MetaTableAccessor.Visitor | Implementations 'visit' a catalog table row. | 
| RawCell | An extended version of cell that gives more power to CPs | 
| RawCellBuilder | Allows creating a cell with  TagAn instance of this type can be acquired by using RegionCoprocessorEnvironment#getCellBuilder
 (for prod code) andRawCellBuilderFactory(for unit tests). | 
| RegionMetrics | Encapsulates per-region load metrics. | 
| RegionStateListener | The listener interface for receiving region state events. | 
| ScheduledChore.ChoreServicer | |
| Server | Defines a curated set of shared functions implemented by HBase servers (Masters
 and RegionServers). | 
| ServerMetrics | This class is used for exporting current state of load on a RegionServer. | 
| Stoppable | Implementers are Stoppable. | 
| TableDescriptors | Get, remove and modify table descriptors. | 
| Tag | Tags are part of cells and helps to add metadata about them. | 
| UserMetrics | Encapsulates per-user load metrics. | 
| UserMetrics.ClientMetrics | 
| Class | Description | 
|---|---|
| ArrayBackedTag | This is a  Tagimplementation in which value is backed by an on heap byte array. | 
| AsyncConsoleAppender | Logger class that buffers before trying to log to the specified console. | 
| AsyncMetaTableAccessor | The asynchronous meta table accessor. | 
| AsyncMetaTableAccessor.MetaTableScanResultConsumer | |
| AuthUtil | Deprecated since 2.2.0, to be marked as
   InterfaceAudience.Privatein 4.0.0. | 
| BaseConfigurable | HBase version of Hadoop's Configured class that doesn't initialize the
 configuration via  BaseConfigurable.setConf(Configuration)in the constructor, but
 only sets the configuration through theBaseConfigurable.setConf(Configuration)method | 
| BBKVComparator | A comparator for case where  ByteBufferKeyValueis prevalent type (BBKV
 is base-type in hbase2). | 
| ByteBufferExtendedCell | This class is a server side extension to the  Cellinterface. | 
| ByteBufferKeyOnlyKeyValue | This is a key only Cell implementation which is identical to  KeyValue.KeyOnlyKeyValuewith respect to key serialization but have its data in the form of Byte buffer
 (onheap and offheap). | 
| ByteBufferKeyValue | This Cell is an implementation of  ByteBufferExtendedCellwhere the data resides in
 off heap/ on heap ByteBuffer | 
| ByteBufferTag | This is a  Tagimplementation in which value is backed byByteBuffer | 
| CacheEvictionStats | |
| CacheEvictionStatsAggregator | Used to merge CacheEvictionStats. | 
| CacheEvictionStatsBuilder | |
| CellBuilderFactory | Create a CellBuilder instance. | 
| CellComparatorImpl | Compare two HBase cells. | 
| CellUtil | Utility methods helpful for slinging  Cellinstances. | 
| ChoreService | ChoreService is a service that can be used to schedule instances of  ScheduledChoreto run
 periodically while sharing threads. | 
| ChoreService.ChoreServiceThreadFactory | Custom ThreadFactory used with the ScheduledThreadPoolExecutor so that all the threads are
 daemon threads, and thus, don't prevent the JVM from shutting down | 
| ClusterId | The identifier for this cluster. | 
| ClusterMetricsBuilder | |
| ClusterMetricsBuilder.ClusterMetricsImpl | |
| ClusterStatus | Deprecated As of release 2.0.0, this will be removed in HBase 3.0.0
             Use  ClusterMetricsinstead. | 
| CompatibilityFactory | Class that will create many instances of classes provided by the hbase-hadoop{1|2}-compat jars. | 
| CompatibilitySingletonFactory | Factory for classes supplied by hadoop compatibility modules. | 
| CompoundConfiguration | Do a shallow merge of multiple KV configuration pools. | 
| CompoundConfiguration.ImmutableConfWrapper | |
| DaemonThreadFactory | Thread factory that creates daemon threads | 
| ExtendedCellBuilderFactory | |
| ExtendedCellBuilderImpl | |
| HBaseConfiguration | Adds HBase configuration files to a Configuration | 
| HBaseInterfaceAudience | This class defines constants for different classes of hbase limited private apis | 
| HColumnDescriptor | Deprecated | 
| HConstants | HConstants holds a bunch of HBase-related constants | 
| HDFSBlocksDistribution | Data structure to describe the distribution of HDFS blocks among hosts. | 
| HDFSBlocksDistribution.HostAndWeight | Stores the hostname and weight for that hostname. | 
| HDFSBlocksDistribution.HostAndWeight.WeightComparator | comparator used to sort hosts based on weight | 
| HealthCheckChore | The Class HealthCheckChore for running health checker regularly. | 
| HealthChecker | A utility for executing an external script that checks the health of
 the node. | 
| HealthReport | The Class HealthReport containing information about health of the node. | 
| HRegionInfo | Deprecated As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| HRegionLocation | Data structure to hold RegionInfo and the address for the hosting
 HRegionServer. | 
| HTableDescriptor | Deprecated As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| IndividualBytesFieldCell | |
| IndividualBytesFieldCellBuilder | |
| JitterScheduledThreadPoolExecutorImpl | ScheduledThreadPoolExecutor that will add some jitter to the RunnableScheduledFuture.getDelay. | 
| JMXListener | Pluggable JMX Agent for HBase(to fix the 2 random TCP ports issue
 of the out-of-the-box JMX Agent):
 1)connector port can share with the registry port if SSL is OFF
 2)support password authentication
 3)support subset of SSL (with default configuration) | 
| KeyValue | An HBase Key/Value. | 
| KeyValue.KeyOnlyKeyValue | A simple form of KeyValue that creates a keyvalue with only the key part of the byte[]
 Mainly used in places where we need to compare two cells. | 
| KeyValue.KVComparator | Deprecated : Use  CellComparatorImpl. | 
| KeyValue.MetaComparator | Deprecated :  MetaCellComparator.META_COMPARATORto be used. | 
| KeyValueBuilder | |
| KeyValueTestUtil | |
| KeyValueUtil | static convenience methods for dealing with KeyValues and collections of KeyValues | 
| LocalHBaseCluster | This class creates a single process HBase cluster. | 
| MetaCellComparator | |
| MetaTableAccessor | 
 Read/write operations on  hbase:metaregion as well as assignment information stored
 tohbase:meta. | 
| MetaTableAccessor.CollectAllVisitor | Collects all returned. | 
| MetaTableAccessor.CollectingVisitor<T> | A  MetaTableAccessor.Visitorthat collects content out of passedResult. | 
| MetaTableAccessor.DefaultVisitorBase | A Visitor that skips offline regions and split parents | 
| MetaTableAccessor.ReplicationBarrierResult | |
| MetaTableAccessor.TableVisitorBase | A Visitor for a table. | 
| NamespaceDescriptor | Namespace POJO class. | 
| NamespaceDescriptor.Builder | |
| NoTagsByteBufferKeyValue | An extension of the ByteBufferKeyValue where the tags length is always 0 | 
| NoTagsKeyValue | An extension of the KeyValue where the tags length is always 0 | 
| PrivateCellUtil | Utility methods helpful slinging  Cellinstances. | 
| PrivateCellUtil.EmptyByteBufferExtendedCell | These cells are used in reseeks/seeks to improve the read performance. | 
| PrivateCellUtil.EmptyCell | These cells are used in reseeks/seeks to improve the read performance. | 
| PrivateCellUtil.FirstOnRowByteBufferExtendedCell | |
| PrivateCellUtil.FirstOnRowCell | |
| PrivateCellUtil.FirstOnRowColByteBufferExtendedCell | |
| PrivateCellUtil.FirstOnRowColCell | |
| PrivateCellUtil.FirstOnRowColTSByteBufferExtendedCell | |
| PrivateCellUtil.FirstOnRowColTSCell | |
| PrivateCellUtil.FirstOnRowDeleteFamilyCell | |
| PrivateCellUtil.LastOnRowByteBufferExtendedCell | |
| PrivateCellUtil.LastOnRowCell | |
| PrivateCellUtil.LastOnRowColByteBufferExtendedCell | |
| PrivateCellUtil.LastOnRowColCell | |
| PrivateCellUtil.TagRewriteByteBufferExtendedCell | |
| PrivateCellUtil.TagRewriteCell | This can be used when a Cell has to change with addition/removal of one or more tags. | 
| PrivateCellUtil.ValueAndTagRewriteByteBufferExtendedCell | |
| PrivateCellUtil.ValueAndTagRewriteCell | |
| RawCellBuilderFactory | Factory for creating cells for CPs. | 
| RegionLoad | Deprecated As of release 2.0.0, this will be removed in HBase 3.0.0
             Use  RegionMetricsinstead. | 
| RegionLocations | Container for holding a list of  HRegionLocation's that correspond to the
 same range. | 
| RegionMetricsBuilder | |
| RegionMetricsBuilder.RegionMetricsImpl | |
| RSGroupTableAccessor | Read rs group information from   hbase:rsgroup. | 
| ScheduledChore | ScheduledChore is a task performed on a period in hbase. | 
| ServerLoad | Deprecated As of release 2.0.0, this will be removed in HBase 3.0.0
             Use  ServerMetricsinstead. | 
| ServerMetricsBuilder | |
| ServerMetricsBuilder.ServerMetricsImpl | |
| ServerName | Name of a particular incarnation of an HBase Server. | 
| SharedConnection | Wraps a Connection to make it can't be closed or aborted. | 
| Size | It is used to represent the size with different units. | 
| SizeCachedByteBufferKeyValue | This Cell is an implementation of  ByteBufferExtendedCellwhere the data resides in
 off heap/ on heap ByteBuffer | 
| SizeCachedKeyValue | This class is an extension to KeyValue where rowLen and keyLen are cached. | 
| SizeCachedNoTagsByteBufferKeyValue | This Cell is an implementation of  ByteBufferExtendedCellwhere the data resides in
 off heap/ on heap ByteBuffer | 
| SizeCachedNoTagsKeyValue | This class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell. | 
| SplitLogCounters | Deprecated since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based
   distributed WAL splitter, see SplitWALManager | 
| SplitLogTask | Deprecated since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based
   distributed WAL splitter, see SplitWALManager | 
| SplitLogTask.Done | |
| SplitLogTask.Err | |
| SplitLogTask.Owned | |
| SplitLogTask.Resigned | |
| SplitLogTask.Unassigned | |
| SslRMIClientSocketFactorySecure | Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566 | 
| SslRMIServerSocketFactorySecure | Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566 | 
| TableName | Immutable POJO class for representing a table name. | 
| TagType | |
| TagUtil | |
| UserMetricsBuilder | |
| UserMetricsBuilder.ClientMetricsImpl | |
| UserMetricsBuilder.UserMetricsImpl | |
| ZKNamespaceManager | Class servers two purposes:
 1. | 
| ZNodeClearer | Contains a set of methods for the collaboration between the start/stop scripts and the
 servers. | 
| Enum | Description | 
|---|---|
| Cell.Type | The valid types for user to build the cell. | 
| CellBuilderType | Used by  CellBuilderFactoryandExtendedCellBuilderFactory. | 
| ClusterMetrics.Option | Kinds of ClusterMetrics | 
| CompareOperator | Generic set of comparison operators. | 
| CompatibilitySingletonFactory.SingletonStorage | |
| Coprocessor.State | Lifecycle state of a given coprocessor instance. | 
| HConstants.OperationStatusCode | Status codes used for return values of bulk operations. | 
| HealthChecker.HealthCheckerExitStatus | |
| KeepDeletedCells | Ways to keep cells marked for delete around. | 
| KeyValue.Type | Key type. | 
| MemoryCompactionPolicy | Enum describing all possible memory compaction policies | 
| MetaTableAccessor.QueryType | |
| Size.Unit | 
| Exception | Description | 
|---|---|
| CallDroppedException | Returned to the clients when their request was discarded due to server being overloaded. | 
| CallQueueTooBigException | |
| ClockOutOfSyncException | This exception is thrown by the master when a region server clock skew is
 too high. | 
| ConcurrentTableModificationException | Thrown when a table has been modified concurrently | 
| DoNotRetryIOException | Subclass if exception is not meant to be retried: e.g. | 
| DroppedSnapshotException | Thrown during flush if the possibility snapshot content was not properly
 persisted into store files. | 
| FailedCloseWALAfterInitializedErrorException | Throw when failed cleanup unsuccessful initialized wal | 
| HBaseIOException | All hbase specific IOExceptions should be subclasses of HBaseIOException | 
| InvalidFamilyOperationException | Thrown if a request is table schema modification is requested but
 made for an invalid family name. | 
| MasterNotRunningException | Thrown if the master is not running | 
| MultiActionResultTooLarge | Exception thrown when the result needs to be chunked on the server side. | 
| NamespaceExistException | Thrown when a namespace exists but should not | 
| NamespaceNotFoundException | Thrown when a namespace can not be located | 
| NotAllMetaRegionsOnlineException | Thrown when an operation requires the root and all meta regions to be online | 
| NotServingRegionException | Thrown by a region server if it is sent a request for a region it is not serving. | 
| PleaseHoldException | This exception is thrown by the master when a region server was shut down and
 restarted so fast that the master still hasn't processed the server shutdown
 of the first instance, or when master is initializing and client call admin
 operations, or when an operation is performed on a region server that is still starting. | 
| RegionException | Thrown when something happens related to region handling. | 
| RegionTooBusyException | Thrown by a region server if it will block and wait to serve a request. | 
| ReplicationPeerNotFoundException | Thrown when a replication peer can not be found | 
| RetryImmediatelyException | |
| ServiceNotRunningException | |
| TableExistsException | Thrown when a table exists but should not. | 
| TableInfoMissingException | Failed to find  .tableinfofile under the table directory. | 
| TableNotDisabledException | Thrown if a table should be offline but is not. | 
| TableNotEnabledException | Thrown if a table should be enabled but is not. | 
| TableNotFoundException | Thrown when a table cannot be located. | 
| UnknownRegionException | Thrown when we are asked to operate on a region we know nothing about. | 
| UnknownScannerException | Thrown if a region server is passed an unknown scanner ID. | 
| YouAreDeadException | This exception is thrown by the master when a region server reports and is already being
 processed as dead. | 
| ZooKeeperConnectionException | Thrown if the client can't connect to ZooKeeper. | 
| Annotation Type | Description | 
|---|---|
| MetaMutationAnnotation | The field or the parameter to which this annotation can be applied only when it
 holds mutations for hbase:meta table. | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.