| Interface | Description | 
|---|---|
| Addressing.AddressSelectionCondition | Interface for AddressSelectionCondition to check if address is acceptable | 
| AvlUtil.AvlInsertOrReplace<TNode extends AvlUtil.AvlNode> | |
| AvlUtil.AvlKeyComparator<TNode extends AvlUtil.AvlNode> | The AvlTree allows to lookup an object using a custom key. | 
| AvlUtil.AvlNodeVisitor<TNode extends AvlUtil.AvlNode> | Visitor that allows to traverse a set of AvlNodes. | 
| BloomFilter | Implements a Bloom filter, as defined by Bloom in 1970. | 
| BloomFilterBase | Common methods Bloom filter methods required at read and write time. | 
| BloomFilterWriter | Specifies methods needed to add elements to a Bloom filter and serialize the
 resulting Bloom filter as a sequence of bytes. | 
| ByteBufferAllocator | Defines the way the ByteBuffers are created | 
| ByteBufferUtils.ByteVisitor | |
| ByteRange | Lightweight, reusable class for specifying ranges of byte[]'s. | 
| Bytes.Comparer<T> | |
| CancelableProgressable | Similar interface as  Progressablebut returns
 a boolean to support canceling the operation. | 
| ConcurrentMapUtils.IOExceptionSupplier<V> | A supplier that throws IOException when get. | 
| EnvironmentEdge | Has some basic interaction with the environment. | 
| FileStatusFilter | |
| FSUtils.ProgressReporter | Called every so-often by storefile map builder getTableStoreFilePathMap to
 report progress. | 
| FSVisitor.StoreFileVisitor | |
| HbckErrorReporter | Deprecated Since 2.3.0. | 
| JSONBean.Writer | Use dumping out mbeans as JSON. | 
| KeyRange | A key range use in split coverage. | 
| LossyCounting.LossyCountingListener<T> | |
| ModifyRegionUtils.RegionEditTask | |
| ModifyRegionUtils.RegionFillTask | |
| ObjectPool.ObjectFactory<K,V> | An  ObjectFactoryobject is used to create
 new shared objects on demand. | 
| PoolMap.Pool<R> | |
| PoolMap.PoolResourceSupplier<R> | |
| PositionedByteRange | 
 Extends  ByteRangewith additional methods to support tracking a
 consumers position within the viewport. | 
| RegionSplitter.SplitAlgorithm | A generic interface for the RegionSplitter code to use for all it's
 functionality. | 
| Threads.PrintThreadInfoHelper | |
| TimeMeasurable<T> | Methods that implement this interface can be measured elapsed time. | 
| Class | Description | 
|---|---|
| AbstractByteRange | An abstract implementation of the ByteRange API | 
| AbstractFileStatusFilter | Typical base class for file status filter. | 
| AbstractHBaseTool | Common base class used for HBase command-line tools. | 
| AbstractPositionedByteRange | Extends the basic  SimpleByteRangeimplementation with position
 support. | 
| Addressing | Utility for network addresses, resolving and naming. | 
| AtomicUtils | Utilities related to atomic operations. | 
| AvlUtil | Helper class that allows to create and manipulate an AvlTree. | 
| AvlUtil.AvlIterableList | Helper class that allows to create and manipulate a linked list of AvlLinkedNodes | 
| AvlUtil.AvlLinkedNode<TNode extends AvlUtil.AvlLinkedNode> | This class extends the AvlNode and adds two links that will be used in conjunction
 with the AvlIterableList class. | 
| AvlUtil.AvlNode<TNode extends AvlUtil.AvlNode> | This class represent a node that will be used in an AvlTree. | 
| AvlUtil.AvlTree | Helper class that allows to create and manipulate an AVL Tree | 
| AvlUtil.AvlTreeIterator<TNode extends AvlUtil.AvlNode> | Iterator for the AvlTree | 
| BloomContext | The bloom context that is used by the StorefileWriter to add the bloom details
 per cell | 
| BloomFilterChunk | The basic building block for the  CompoundBloomFilter | 
| BloomFilterFactory | Handles Bloom filter initialization based on configuration and serialized metadata in the reader
 and writer of  HStoreFile. | 
| BloomFilterUtil | Utility methods related to BloomFilters | 
| BoundedCompletionService<V> | A completion service, close to the one available in the JDK 1.7
 However, this ones keeps the list of the future, and allows to cancel them all. | 
| BoundedPriorityBlockingQueue<E> | A generic bounded blocking Priority-Queue. | 
| BoundedPriorityBlockingQueue.PriorityQueue<E> | |
| ByteArrayHashKey | |
| ByteBufferArray | This class manages an array of ByteBuffers with a default size 4MB. | 
| ByteBufferUtils | Deprecated This class will become IA.Private in HBase 3.0. | 
| ByteBufferUtils.Comparer | |
| ByteBufferUtils.ComparerHolder | |
| ByteBufferUtils.ComparerHolder.PureJavaComparer | |
| ByteBufferUtils.ComparerHolder.UnsafeComparer | |
| ByteBufferUtils.Converter | |
| ByteBufferUtils.ConverterHolder | |
| ByteBufferUtils.ConverterHolder.PureJavaConverter | |
| ByteBufferUtils.ConverterHolder.UnsafeConverter | |
| ByteRangeUtils | Utility methods for working with  ByteRange. | 
| Bytes | Utility class that handles byte arrays, conversions to/from other types,
 comparisons, hash code generation, manufacturing keys for HashMaps or
 HashSets, and can be used as key in maps or trees. | 
| Bytes.ByteArrayComparator | Byte array comparator class. | 
| Bytes.Converter | |
| Bytes.ConverterHolder | |
| Bytes.ConverterHolder.PureJavaConverter | |
| Bytes.ConverterHolder.UnsafeConverter | |
| Bytes.LexicographicalComparerHolder | Provides a lexicographical comparer implementation; either a Java
 implementation or a faster implementation based on  Unsafe. | 
| Bytes.RowEndKeyComparator | A  Bytes.ByteArrayComparatorthat treats the empty array as the largest value. | 
| CellHashKey | Extracts the byte for the hash calculation from the given cell | 
| Classes | Utilities for class manipulation. | 
| ClassLoaderBase | Base class loader that defines couple shared constants used by sub-classes. | 
| ClassSize | Class for determining the "size" of a class, an attempt to calculate the
 actual bytes that an object of this class will occupy in memory
 The core of this class is taken from the Derby project | 
| ClassSize.MemoryLayout | MemoryLayout abstracts details about the JVM object layout. | 
| ClassSize.UnsafeLayout | UnsafeLayout uses Unsafe to guesstimate the object-layout related parameters like object header
 sizes and oop sizes
 See HBASE-15950. | 
| ClassSize.UnsafeLayout.HeaderSize | |
| ClientUtils | Common Utility class for clients | 
| CollectionBackedScanner | Utility scanner that wraps a sortable collection and serves as a KeyValueScanner. | 
| CollectionUtils | Deprecated Since 2.0.6/2.1.3/2.2.0 | 
| CommonFSUtils | Utility methods for interacting with the underlying file system. | 
| CommonFSUtils.DfsBuilderUtility | |
| CompressionTest | Compression validation test. | 
| ConcatenatedLists<T> | A collection class that contains multiple sub-lists, which allows us to not copy lists. | 
| ConcurrentMapUtils | Utility methods for dealing with Collections, including treating null collections as empty. | 
| ConfigurationUtil | Utilities for storing more complex collection types in
  Configurationinstances. | 
| ConnectionCache | A utility to store user specific HConnections in memory. | 
| CoprocessorClassLoader | ClassLoader used to load classes for Coprocessor instances. | 
| Counter | Deprecated since 2.0.0 and will be removed in 3.0.0. | 
| Counter.Cell | |
| Counter.Container | |
| DefaultEnvironmentEdge | Default implementation of an environment edge. | 
| DirectMemoryUtils | Utilities for interacting with and monitoring DirectByteBuffer allocations. | 
| DNS | Wrapper around Hadoop's DNS class to hide reflection. | 
| DynamicClassLoader | This is a class loader that can load classes dynamically from new
 jar files under a configured folder. | 
| EncryptionTest | |
| EnvironmentEdgeManager | Manages a singleton instance of the environment edge. | 
| ExceptionUtil | This class handles the different interruption classes. | 
| ExponentialMovingAverage | EMA is similar to  WeightedMovingAveragein weighted, but the weighting factor decrease
 exponentially. | 
| FSRegionScanner | Thread that walks over the filesystem, and computes the mappings
 Region -> BestHost and Region ->  Map<HostName, fractional-locality-of-region> | 
| FSTableDescriptors | Implementation of  TableDescriptorsthat reads descriptors from the
 passed filesystem. | 
| FSUtils | Utility methods for interacting with the underlying file system. | 
| FSUtils.BlackListDirFilter | Directory filter that doesn't include any of the directories in the specified blacklist | 
| FSUtils.DirFilter | A  PathFilterthat only allows directories. | 
| FSUtils.FamilyDirFilter | Filter for all dirs that are legal column family names. | 
| FSUtils.FileFilter | A  PathFilterthat returns only regular files. | 
| FSUtils.HFileFilter | Filter for HFiles that excludes reference files. | 
| FSUtils.HFileLinkFilter | Filter for HFileLinks (StoreFiles and HFiles not included). | 
| FSUtils.ReferenceFileFilter | |
| FSUtils.RegionDirFilter | Filter for all dirs that don't start with '.' | 
| FSUtils.UserTableDirFilter | A  PathFilterthat returns usertable directories. | 
| FSVisitor | Utility methods for interacting with the hbase.root file system. | 
| FutureUtils | Helper class for processing futures. | 
| GetJavaProperty | A generic way for querying Java properties. | 
| GsonUtil | Helper class for gson. | 
| Hash | This class represents a common API for hashing functions. | 
| HashedBytes | This class encapsulates a byte array and overrides hashCode and equals so
 that it's identity is based on the data rather than the array instance. | 
| HashKey<T> | Used to calculate the hash  Hashalgorithms for Bloomfilters. | 
| HBaseConfTool | Tool that prints out a configuration. | 
| HBaseFsck | Deprecated For removal in hbase-4.0.0. | 
| HBaseFsck.FileLockCallable | |
| HBaseFsck.HBaseFsckTool | This is a Tool wrapper that gathers -Dxxx=yyy configuration settings from the command line. | 
| HBaseFsck.PrintingErrorReporter | |
| HBaseFsck.RegionBoundariesInformation | |
| HBaseFsck.WorkItemHdfsRegionInfo | Contact hdfs and get all information about specified table directory into
 regioninfo list. | 
| HBaseFsck.WorkItemOverlapMerge | |
| HBaseFsck.WorkItemRegion | Contact a region server and get all information from it | 
| HBaseFsckRepair | This class contains helper methods that repair parts of hbase's filesystem
 contents. | 
| HbckRegionInfo | Maintain information about a particular region. | 
| HbckRegionInfo.HdfsEntry | Stores the regioninfo entries from HDFS | 
| HbckRegionInfo.MetaEntry | Stores the regioninfo entries scanned from META | 
| HbckRegionInfo.OnlineEntry | Stores the regioninfo retrieved from Online region servers. | 
| HbckTableInfo | Maintain information about a particular table. | 
| HFileArchiveUtil | Helper class for all utilities related to archival/retrieval of HFiles | 
| IdLock | Allows multiple concurrent clients to lock on a numeric id with a minimal
 memory overhead. | 
| IdLock.Entry | An entry returned to the client as a lock object | 
| IdReadWriteLock<T> | Allows multiple concurrent clients to lock on a numeric id with ReentrantReadWriteLock. | 
| ImmutableByteArray | Mainly used as keys for HashMap. | 
| IncrementingEnvironmentEdge | Uses an incrementing algorithm instead of the default. | 
| JenkinsHash | Produces 32-bit hash for hash table lookup. | 
| JRubyFormat | Utility class for converting objects to JRuby. | 
| JSONBean | Utility for doing JSON and MBeans. | 
| JsonMapper | Utility class for converting objects to JSON | 
| JSONMetricUtil | |
| JVM | This class is a wrapper for the implementation of
 com.sun.management.UnixOperatingSystemMXBean
 It will decide to use the sun api or its own implementation
 depending on the runtime (vendor) used. | 
| JVMClusterUtil | Utility used running a cluster all in the one JVM. | 
| JVMClusterUtil.MasterThread | Datastructure to hold Master Thread and Master instance | 
| JVMClusterUtil.RegionServerThread | Datastructure to hold RegionServer Thread and RegionServer instance | 
| JvmPauseMonitor | Class which sets up a simple thread which runs in a loop sleeping
 for a short interval of time. | 
| JvmPauseMonitor.GcTimes | |
| JvmVersion | Utility class to get and check the current JVM version. | 
| KeyLocker<K> | A utility class to manage a set of locks. | 
| LogMonitoring | Utility functions for reading the log4j logs that are being written by HBase. | 
| LossyCounting<T> | LossyCounting utility, bounded data structure that maintains approximate high frequency
 elements in data stream. | 
| ManualEnvironmentEdge | An environment edge that uses a manually set value. | 
| MapreduceDependencyClasspathTool | Generate a classpath string containing any jars required by mapreduce jobs. | 
| MapReduceExtendedCell | A wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers. | 
| MD5Hash | Utility class for MD5
 MD5 hash produces a 128-bit digest. | 
| Methods | |
| ModifyRegionUtils | Utility methods for interacting with the regions. | 
| MoveWithAck | Move Regions and make sure that they are up on the target server.If a region movement fails we
 exit as failure | 
| MoveWithoutAck | Move Regions without Acknowledging.Usefule in case of RS shutdown as we might want to shut the
 RS down anyways and not abort on a stuck region. | 
| MovingAverage<T> | The purpose of introduction of  MovingAveragemainly is to measure execution time of a
 specific method, which can help us to know its performance fluctuation in response to different
 machine states or situations, better case, then to act accordingly. | 
| MultiHConnection | Provides ability to create multiple Connection instances and allows to process a batch of
 actions using CHTable.doBatchWithCallback() | 
| MunkresAssignment | Computes the optimal (minimal cost) assignment of jobs to workers (or other
 analogous) concepts given a cost matrix of each pair of job and worker, using
 the algorithm by James Munkres in "Algorithms for the Assignment and
 Transportation Problems", with additional optimizations as described by Jin
 Kue Wong in "A New Implementation of an Algorithm for the Optimal Assignment
 Problem: An Improved Version of Munkres' Algorithm". | 
| MurmurHash | This is a very fast, non-cryptographic hash suitable for general hash-based
 lookup. | 
| MurmurHash3 | This is a very fast, non-cryptographic hash suitable for general hash-based
 lookup. | 
| NettyEventLoopGroupConfig | Event loop group related config. | 
| NonceKey | This implementation is not smart and just treats nonce group and nonce as random bits. | 
| ObjectIntPair<T> | A generic class for pair of an Object and and a primitive int value. | 
| ObjectPool<K,V> | A thread-safe shared object pool in which object creation is expected to be lightweight, and the
 objects may be excessively created and discarded. | 
| OrderedBytes | Utility class that handles ordered byte arrays. | 
| Pair<T1,T2> | A generic class for pairs. | 
| PairOfSameType<T> | A generic, immutable class for pairs of objects both of type  T. | 
| PoolMap<K,V> | The  PoolMapmaps a key to a collection of values, the elements
 of which are managed by a pool. | 
| PoolMap.RoundRobinPool<R> | |
| PoolMap.ThreadLocalPool<R> | |
| PrettyPrinter | |
| ProcessUtils | Process related utilities. | 
| Random64 | An instance of this class is used to generate a stream of
 pseudorandom numbers. | 
| RecoverLeaseFSUtils | Utility methods for recovering file lease for hdfs. | 
| ReflectionUtils | |
| RegionMover | Tool for loading/unloading regions to/from given regionserver This tool can be run from Command
 line directly as a utility. | 
| RegionMover.RegionMoverBuilder | Builder for Region mover. | 
| RegionSplitCalculator<R extends KeyRange> | This is a generic region split calculator. | 
| RegionSplitter | The  RegionSplitterclass provides several utilities to help in the
 administration lifecycle for developers who choose to manually split regions
 instead of having HBase handle that automatically. | 
| RegionSplitter.DecimalStringSplit | The format of a DecimalStringSplit region boundary is the ASCII representation of
 reversed sequential number, or any other uniformly distributed decimal value. | 
| RegionSplitter.HexStringSplit | HexStringSplit is a well-known  RegionSplitter.SplitAlgorithmfor choosing region
 boundaries. | 
| RegionSplitter.NumberStringSplit | |
| RegionSplitter.UniformSplit | A SplitAlgorithm that divides the space of possible keys evenly. | 
| RetryCounter | Operation retry accounting. | 
| RetryCounter.BackoffPolicy | Policy for calculating sleeping intervals between retry attempts | 
| RetryCounter.ExponentialBackoffPolicy | |
| RetryCounter.ExponentialBackoffPolicyWithLimit | |
| RetryCounter.RetryConfig | Configuration for a retry counter | 
| RetryCounterFactory | |
| RollingStatCalculator | This class maintains mean and variation for any sequence of input provided to it. | 
| RowBloomContext | Handles ROW bloom related context. | 
| RowBloomHashKey | |
| RowColBloomContext | Handles ROWCOL bloom related context. | 
| RowColBloomHashKey | An hash key for ROWCOL bloom. | 
| RowPrefixFixedLengthBloomContext | Handles ROWPREFIX bloom related context. | 
| ServerCommandLine | Base class for command lines that start up various HBase daemons. | 
| ServerRegionReplicaUtil | Similar to  RegionReplicaUtilbut for the server side | 
| ShutdownHookManager | This class provides ShutdownHookManager shims for HBase to interact with the Hadoop 1.0.x and the
 Hadoop 2.0+ series. | 
| ShutdownHookManager.ShutdownHookManagerV1 | |
| ShutdownHookManager.ShutdownHookManagerV2 | |
| SimpleByteRange | A read only version of the  ByteRange. | 
| SimpleMovingAverage | SMA measure the overall average execution time of a specific method. | 
| SimpleMutableByteRange | A basic mutable  ByteRangeimplementation. | 
| SimplePositionedByteRange | Extends the basic  SimpleMutableByteRangeimplementation with position
 support and it is a readonly version. | 
| SimplePositionedMutableByteRange | Extends the basic  AbstractPositionedByteRangeimplementation with
 position support and it is a mutable version. | 
| Sleeper | Sleeper for current thread. | 
| SoftObjectPool<K,V> | A  SoftReferencebased shared object pool. | 
| SortedList<E> | Simple sorted list implementation that uses  ArrayListas
 the underlying collection so we can support RandomAccess. | 
| StealJobQueue<T> | This queue allows a ThreadPoolExecutor to steal jobs from another ThreadPoolExecutor. | 
| Strings | Utility for Strings. | 
| TableDescriptorChecker | Only used for master to sanity check  TableDescriptor. | 
| Threads | Thread Utility | 
| Threads.PrintThreadInfoLazyHolder | |
| Triple<A,B,C> | Utility class to manage a triple. | 
| UnsafeAccess | |
| UnsafeAvailChecker | |
| VersionInfo | This class finds the Version information for HBase. | 
| WeakObjectPool<K,V> | A  WeakReferencebased shared object pool. | 
| WeightedMovingAverage | Different from SMA  SimpleMovingAverage, WeightedMovingAverage gives each data different
 weight. | 
| WindowMovingAverage | Instead of calculate a whole time average, this class focus on the last N. | 
| Writables | Utility class with methods for manipulating Writable objects | 
| YammerHistogramUtils | Utility functions for working with Yammer Metrics. | 
| ZKDataMigrator | Deprecated Since 2.0.0. | 
| Enum | Description | 
|---|---|
| Bytes.LexicographicalComparerHolder.PureJavaComparer | |
| Bytes.LexicographicalComparerHolder.UnsafeComparer | |
| ChecksumType | Checksum types. | 
| DNS.ServerType | |
| HbckErrorReporter.ERROR_CODE | |
| IdReadWriteLock.ReferenceType | |
| Order | Used to describe or modify the lexicographical sort order of a
  byte[]. | 
| PoolMap.PoolType | |
| PrettyPrinter.Unit | 
| Exception | Description | 
|---|---|
| CommonFSUtils.StreamLacksCapabilityException | Helper exception for those cases where the place where we need to check a stream capability
 is not where we have the needed context to explain the impact and mitigation for a lack. | 
| FileSystemVersionException | Thrown when the file system needs to be upgraded | 
| LeaseNotRecoveredException | Thrown when the lease was expected to be recovered,
 but the file can't be opened. | 
| ReadOnlyByteRangeException | Exception thrown when a read only byte range is modified | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.