Package org.apache.hadoop.hbase.util


package org.apache.hadoop.hbase.util
  • Class
    Description
    org.apache.hadoop.hbase.util.AbstractByteRange
    An abstract implementation of the ByteRange API
    org.apache.hadoop.hbase.util.AbstractFileStatusFilter
    Typical base class for file status filter.
    org.apache.hadoop.hbase.util.AbstractHBaseTool
    Common base class used for HBase command-line tools.
    org.apache.hadoop.hbase.util.AbstractPositionedByteRange
    Extends the basic SimpleByteRange implementation with position support.
    org.apache.hadoop.hbase.util.Addressing
    Utility for network addresses, resolving and naming.
    org.apache.hadoop.hbase.util.Addressing.AddressSelectionCondition
    Interface for AddressSelectionCondition to check if address is acceptable
    org.apache.hadoop.hbase.util.AtomicUtils
    Utilities related to atomic operations.
    org.apache.hadoop.hbase.util.AvlUtil
    Helper class that allows to create and manipulate an AvlTree.
    org.apache.hadoop.hbase.util.AvlUtil.AvlInsertOrReplace<TNode extends org.apache.hadoop.hbase.util.AvlUtil.AvlNode>
     
    org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
    Helper class that allows to create and manipulate a linked list of AvlLinkedNodes
    org.apache.hadoop.hbase.util.AvlUtil.AvlKeyComparator<TNode extends org.apache.hadoop.hbase.util.AvlUtil.AvlNode>
    The AvlTree allows to lookup an object using a custom key.
    org.apache.hadoop.hbase.util.AvlUtil.AvlLinkedNode<TNode extends org.apache.hadoop.hbase.util.AvlUtil.AvlLinkedNode>
    This class extends the AvlNode and adds two links that will be used in conjunction with the AvlIterableList class.
    org.apache.hadoop.hbase.util.AvlUtil.AvlNode<TNode extends org.apache.hadoop.hbase.util.AvlUtil.AvlNode>
    This class represent a node that will be used in an AvlTree.
    org.apache.hadoop.hbase.util.AvlUtil.AvlNodeVisitor<TNode extends org.apache.hadoop.hbase.util.AvlUtil.AvlNode>
    Visitor that allows to traverse a set of AvlNodes.
    org.apache.hadoop.hbase.util.AvlUtil.AvlTree
    Helper class that allows to create and manipulate an AVL Tree
    org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator<TNode extends org.apache.hadoop.hbase.util.AvlUtil.AvlNode>
    Iterator for the AvlTree
    org.apache.hadoop.hbase.util.BloomContext
    The bloom context that is used by the StorefileWriter to add the bloom details per cell
    org.apache.hadoop.hbase.util.BloomFilter
    Implements a Bloom filter, as defined by Bloom in 1970.
    org.apache.hadoop.hbase.util.BloomFilterBase
    Common methods Bloom filter methods required at read and write time.
    org.apache.hadoop.hbase.util.BloomFilterChunk
    The basic building block for the CompoundBloomFilter
    org.apache.hadoop.hbase.util.BloomFilterFactory
    Handles Bloom filter initialization based on configuration and serialized metadata in the reader and writer of HStoreFile.
    org.apache.hadoop.hbase.util.BloomFilterUtil
    Utility methods related to BloomFilters
    org.apache.hadoop.hbase.util.BloomFilterWriter
    Specifies methods needed to add elements to a Bloom filter and serialize the resulting Bloom filter as a sequence of bytes.
    org.apache.hadoop.hbase.util.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.
    org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue<E>
    A generic bounded blocking Priority-Queue.
    org.apache.hadoop.hbase.util.ByteArrayHashKey
     
    org.apache.hadoop.hbase.util.ByteBufferAllocator
    Defines the way the ByteBuffers are created
    org.apache.hadoop.hbase.util.ByteBufferArray
    This class manages an array of ByteBuffers with a default size 4MB.
    org.apache.hadoop.hbase.util.ByteBufferUtils
    Utility functions for working with byte buffers, such as reading/writing variable-length long numbers.
    org.apache.hadoop.hbase.util.ByteRange
    Lightweight, reusable class for specifying ranges of byte[]'s.
    org.apache.hadoop.hbase.util.ByteRangeUtils
    Utility methods for working with ByteRange.
    org.apache.hadoop.hbase.util.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.
    org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
    Byte array comparator class.
    org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
    A Bytes.ByteArrayComparator that treats the empty array as the largest value.
    org.apache.hadoop.hbase.util.CancelableProgressable
    Similar interface as Progressable but returns a boolean to support canceling the operation.
    org.apache.hadoop.hbase.util.CellHashKey
    Extracts the byte for the hash calculation from the given cell
    org.apache.hadoop.hbase.util.ChecksumType
    Checksum types.
    org.apache.hadoop.hbase.util.Classes
    Utilities for class manipulation.
    org.apache.hadoop.hbase.util.ClassLoaderBase
    Base class loader that defines couple shared constants used by sub-classes.
    org.apache.hadoop.hbase.util.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
    org.apache.hadoop.hbase.util.ClientUtils
    Common Utility class for clients
    org.apache.hadoop.hbase.util.CollectionBackedScanner
    Utility scanner that wraps a sortable collection and serves as a KeyValueScanner.
    org.apache.hadoop.hbase.util.CommonFSUtils
    Utility methods for interacting with the underlying file system.
    org.apache.hadoop.hbase.util.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.
    org.apache.hadoop.hbase.util.CompressionTest
    Compression validation test.
    org.apache.hadoop.hbase.util.ConcatenatedLists<T>
    A collection class that contains multiple sub-lists, which allows us to not copy lists.
    org.apache.hadoop.hbase.util.ConcurrentMapUtils
    Utility methods for dealing with Collections, including treating null collections as empty.
    org.apache.hadoop.hbase.util.ConfigurationUtil
    Utilities for storing more complex collection types in Configuration instances.
    org.apache.hadoop.hbase.util.ConnectionCache
    A utility to store user specific HConnections in memory.
    org.apache.hadoop.hbase.util.CoprocessorClassLoader
    ClassLoader used to load classes for Coprocessor instances.
    org.apache.hadoop.hbase.util.CoprocessorConfigurationUtil
    Helper class for coprocessor host when configuration changes.
    org.apache.hadoop.hbase.util.DefaultEnvironmentEdge
    Default implementation of an environment edge.
    org.apache.hadoop.hbase.util.DirectMemoryUtils
    Utilities for interacting with and monitoring DirectByteBuffer allocations.
    org.apache.hadoop.hbase.util.DNS
    Wrapper around Hadoop's DNS class to hide reflection.
    org.apache.hadoop.hbase.util.DNS.ServerType
     
    org.apache.hadoop.hbase.util.DynamicClassLoader
    This is a class loader that can load classes dynamically from new jar files under a configured folder.
    org.apache.hadoop.hbase.util.EncryptionTest
     
    org.apache.hadoop.hbase.util.EnvironmentEdge
    Has some basic interaction with the environment.
    org.apache.hadoop.hbase.util.EnvironmentEdgeManager
    Manages a singleton instance of the environment edge.
    org.apache.hadoop.hbase.util.ExceptionUtil
    This class handles the different interruption classes.
    org.apache.hadoop.hbase.util.ExponentialMovingAverage<T>
    EMA is similar to WeightedMovingAverage in weighted, but the weighting factor decrease exponentially.
    org.apache.hadoop.hbase.util.FileStatusFilter
     
    org.apache.hadoop.hbase.util.FileSystemVersionException
    Thrown when the file system needs to be upgraded
    org.apache.hadoop.hbase.util.FSTableDescriptors
    Implementation of TableDescriptors that reads descriptors from the passed filesystem.
    org.apache.hadoop.hbase.util.FSUtils
    Utility methods for interacting with the underlying file system.
    org.apache.hadoop.hbase.util.FSUtils.BlackListDirFilter
    Directory filter that doesn't include any of the directories in the specified blacklist
    org.apache.hadoop.hbase.util.FSUtils.DirFilter
    A PathFilter that only allows directories.
    org.apache.hadoop.hbase.util.FSUtils.FamilyDirFilter
    Filter for all dirs that are legal column family names.
    org.apache.hadoop.hbase.util.FSUtils.HFileFilter
    Filter for HFiles that excludes reference files.
    org.apache.hadoop.hbase.util.FSUtils.HFileLinkFilter
    Filter for HFileLinks (StoreFiles and HFiles not included).
    org.apache.hadoop.hbase.util.FSUtils.ReferenceAndLinkFileFilter
     
    org.apache.hadoop.hbase.util.FSUtils.ReferenceFileFilter
     
    org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
    Filter for all dirs that don't start with '.'
    org.apache.hadoop.hbase.util.FSUtils.UserTableDirFilter
    A PathFilter that returns usertable directories.
    org.apache.hadoop.hbase.util.FSVisitor
    Utility methods for interacting with the hbase.root file system.
    org.apache.hadoop.hbase.util.FSVisitor.StoreFileVisitor
     
    org.apache.hadoop.hbase.util.FutureUtils
    Helper class for processing futures.
    org.apache.hadoop.hbase.util.GetJavaProperty
    A generic way for querying Java properties.
    org.apache.hadoop.hbase.util.GsonUtil
    Helper class for gson.
    org.apache.hadoop.hbase.util.Hash
    This class represents a common API for hashing functions.
    org.apache.hadoop.hbase.util.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.
    org.apache.hadoop.hbase.util.HashKey<T>
    Used to calculate the hash Hash algorithms for Bloomfilters.
    org.apache.hadoop.hbase.util.HBaseConfTool
    Tool that prints out a configuration.
    org.apache.hadoop.hbase.util.HBaseFsck
    Deprecated.
    For removal in hbase-4.0.0.
    org.apache.hadoop.hbase.util.HBaseFsckRepair
    This class contains helper methods that repair parts of hbase's filesystem contents.
    org.apache.hadoop.hbase.util.HbckErrorReporter
    Deprecated.
    Since 2.3.0.
    org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
     
    org.apache.hadoop.hbase.util.HbckRegionInfo
    Maintain information about a particular region.
    org.apache.hadoop.hbase.util.HbckRegionInfo.HdfsEntry
    Stores the regioninfo entries from HDFS
    org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry
    Stores the regioninfo entries scanned from META
    org.apache.hadoop.hbase.util.HbckTableInfo
    Maintain information about a particular table.
    org.apache.hadoop.hbase.util.HFileArchiveUtil
    Helper class for all utilities related to archival/retrieval of HFiles
    org.apache.hadoop.hbase.util.IdLock
    Allows multiple concurrent clients to lock on a numeric id with a minimal memory overhead.
    org.apache.hadoop.hbase.util.IdLock.Entry
    An entry returned to the client as a lock object
    org.apache.hadoop.hbase.util.IdReadWriteLock<T>
    Allows multiple concurrent clients to lock on a numeric id with ReentrantReadWriteLock.
    org.apache.hadoop.hbase.util.IdReadWriteLockStrongRef<T>
     
    org.apache.hadoop.hbase.util.IdReadWriteLockWithObjectPool<T>
     
    org.apache.hadoop.hbase.util.IdReadWriteLockWithObjectPool.ReferenceType
     
    org.apache.hadoop.hbase.util.ImmutableByteArray
    Mainly used as keys for HashMap.
    org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
    Uses an incrementing algorithm instead of the default.
    org.apache.hadoop.hbase.util.IOExceptionConsumer<T>
     
    org.apache.hadoop.hbase.util.IOExceptionRunnable
     
    org.apache.hadoop.hbase.util.IOExceptionSupplier<V>
    A supplier that throws IOException when get.
    org.apache.hadoop.hbase.util.JenkinsHash
    Produces 32-bit hash for hash table lookup.
    org.apache.hadoop.hbase.util.JRubyFormat
    Utility class for converting objects to JRuby.
    org.apache.hadoop.hbase.util.JSONBean
    Utility for doing JSON and MBeans.
    org.apache.hadoop.hbase.util.JSONBean.Writer
    Use dumping out mbeans as JSON.
    org.apache.hadoop.hbase.util.JsonMapper
    Utility class for converting objects to JSON
    org.apache.hadoop.hbase.util.JSONMetricUtil
     
    org.apache.hadoop.hbase.util.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.
    org.apache.hadoop.hbase.util.JVMClusterUtil
    Utility used running a cluster all in the one JVM.
    org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread
    Datastructure to hold Master Thread and Master instance
    org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread
    Datastructure to hold RegionServer Thread and RegionServer instance
    org.apache.hadoop.hbase.util.JvmPauseMonitor
    Class which sets up a simple thread which runs in a loop sleeping for a short interval of time.
    org.apache.hadoop.hbase.util.JvmVersion
    Utility class to get and check the current JVM version.
    org.apache.hadoop.hbase.util.KeyLocker<K>
    A utility class to manage a set of locks.
    org.apache.hadoop.hbase.util.KeyRange
    A key range use in split coverage.
    org.apache.hadoop.hbase.util.LeaseNotRecoveredException
    Thrown when the lease was expected to be recovered, but the file can't be opened.
    org.apache.hadoop.hbase.util.LocatedBlockHelper
    hadoop 3.3.1 changed the return value of this method from DatanodeInfo[] to DatanodeInfoWithStorage[], which causes the JVM can not locate the method if we are compiled with hadoop 3.2 and then link with hadoop 3.3+, so here we need to use reflection to make it work for both hadoop versions, otherwise we need to publish more artifacts for different hadoop versions...
    org.apache.hadoop.hbase.util.LogMonitoring
    Utility functions for reading the log4j logs that are being written by HBase.
    org.apache.hadoop.hbase.util.LossyCounting<T>
    LossyCounting utility, bounded data structure that maintains approximate high frequency elements in data stream.
    org.apache.hadoop.hbase.util.LossyCounting.LossyCountingListener<T>
     
    org.apache.hadoop.hbase.util.ManualEnvironmentEdge
    An environment edge that uses a manually set value.
    org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
    Generate a classpath string containing any jars required by mapreduce jobs.
    org.apache.hadoop.hbase.util.MapReduceExtendedCell
    A wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers.
    org.apache.hadoop.hbase.util.MD5Hash
    Utility class for MD5 MD5 hash produces a 128-bit digest.
    org.apache.hadoop.hbase.util.Methods
     
    org.apache.hadoop.hbase.util.ModifyRegionUtils
    Utility methods for interacting with the regions.
    org.apache.hadoop.hbase.util.ModifyRegionUtils.RegionEditTask
     
    org.apache.hadoop.hbase.util.ModifyRegionUtils.RegionFillTask
     
    org.apache.hadoop.hbase.util.MovingAverage<T>
    The purpose of introduction of MovingAverage mainly 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.
    org.apache.hadoop.hbase.util.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".
    org.apache.hadoop.hbase.util.MurmurHash
    This is a very fast, non-cryptographic hash suitable for general hash-based lookup.
    org.apache.hadoop.hbase.util.MurmurHash3
    This is a very fast, non-cryptographic hash suitable for general hash-based lookup.
    org.apache.hadoop.hbase.util.NettyEventLoopGroupConfig
    Event loop group related config.
    org.apache.hadoop.hbase.util.NettyFutureUtils
    Helper class for processing netty futures.
    org.apache.hadoop.hbase.util.NettyUnsafeUtils
    Wraps some usages of netty's unsafe API, for ease of maintainability.
    org.apache.hadoop.hbase.util.NonceKey
    This implementation is not smart and just treats nonce group and nonce as random bits.
    org.apache.hadoop.hbase.util.ObjectIntPair<T>
    A generic class for pair of an Object and and a primitive int value.
    org.apache.hadoop.hbase.util.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.
    org.apache.hadoop.hbase.util.ObjectPool.ObjectFactory<K,V>
    An ObjectFactory object is used to create new shared objects on demand.
    org.apache.hadoop.hbase.util.OOMEChecker
     
    org.apache.hadoop.hbase.util.Order
    Used to describe or modify the lexicographical sort order of a byte[].
    org.apache.hadoop.hbase.util.OrderedBytes
    Utility class that handles ordered byte arrays.
    org.apache.hadoop.hbase.util.Pair<T1,T2>
    A generic class for pairs.
    org.apache.hadoop.hbase.util.PairOfSameType<T>
    A generic, immutable class for pairs of objects both of type T.
    org.apache.hadoop.hbase.util.PoolMap<K,V>
    The PoolMap maps a key to a collection of values, the elements of which are managed by a pool.
    org.apache.hadoop.hbase.util.PoolMap.Pool<R>
     
    org.apache.hadoop.hbase.util.PoolMap.PoolResourceSupplier<R>
     
    org.apache.hadoop.hbase.util.PoolMap.PoolType
     
    org.apache.hadoop.hbase.util.PositionedByteRange
    Extends ByteRange with additional methods to support tracking a consumers position within the viewport.
    org.apache.hadoop.hbase.util.PrettyPrinter
     
    org.apache.hadoop.hbase.util.PrettyPrinter.Unit
     
    org.apache.hadoop.hbase.util.ProcessUtils
    Process related utilities.
    org.apache.hadoop.hbase.util.Random64
    An instance of this class is used to generate a stream of pseudorandom numbers.
    org.apache.hadoop.hbase.util.ReadOnlyByteRangeException
    Exception thrown when a read only byte range is modified
    org.apache.hadoop.hbase.util.RecoverLeaseFSUtils
    Utility methods for recovering file lease for hdfs.
    org.apache.hadoop.hbase.util.ReflectedFunctionCache<I,R>
    Cache to hold resolved Functions of a specific signature, generated through reflection.
    org.apache.hadoop.hbase.util.ReflectionUtils
     
    org.apache.hadoop.hbase.util.RegionMover
    Tool for loading/unloading regions to/from given regionserver This tool can be run from Command line directly as a utility.
    org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
    Builder for Region mover.
    org.apache.hadoop.hbase.util.RegionSplitCalculator<R extends org.apache.hadoop.hbase.util.KeyRange>
    This is a generic region split calculator.
    org.apache.hadoop.hbase.util.RegionSplitter
    The RegionSplitter class provides several utilities to help in the administration lifecycle for developers who choose to manually split regions instead of having HBase handle that automatically.
    org.apache.hadoop.hbase.util.RegionSplitter.DecimalStringSplit
    The format of a DecimalStringSplit region boundary is the ASCII representation of reversed sequential number, or any other uniformly distributed decimal value.
    org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
    HexStringSplit is a well-known RegionSplitter.SplitAlgorithm for choosing region boundaries.
    org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplit
     
    org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
    A generic interface for the RegionSplitter code to use for all it's functionality.
    org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
    A SplitAlgorithm that divides the space of possible keys evenly.
    org.apache.hadoop.hbase.util.ReservoirSample<T>
    The simple version of reservoir sampling implementation.
    org.apache.hadoop.hbase.util.RetryCounter
    Operation retry accounting.
    org.apache.hadoop.hbase.util.RetryCounter.BackoffPolicy
    Policy for calculating sleeping intervals between retry attempts
    org.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicy
     
    org.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicyWithLimit
     
    org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
    Configuration for a retry counter
    org.apache.hadoop.hbase.util.RetryCounterFactory
     
    org.apache.hadoop.hbase.util.RollingStatCalculator
    This class maintains mean and variation for any sequence of input provided to it.
    org.apache.hadoop.hbase.util.RotateFile
    A file storage which supports atomic update through two files, i.e, rotating.
    org.apache.hadoop.hbase.util.RowBloomContext
    Handles ROW bloom related context.
    org.apache.hadoop.hbase.util.RowBloomHashKey
     
    org.apache.hadoop.hbase.util.RowColBloomContext
    Handles ROWCOL bloom related context.
    org.apache.hadoop.hbase.util.RowColBloomHashKey
    An hash key for ROWCOL bloom.
    org.apache.hadoop.hbase.util.RowPrefixFixedLengthBloomContext
    Handles ROWPREFIX bloom related context.
    org.apache.hadoop.hbase.util.ServerCommandLine
    Base class for command lines that start up various HBase daemons.
    org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
    Similar to RegionReplicaUtil but for the server side
    org.apache.hadoop.hbase.util.ShutdownHookManager
    This class provides ShutdownHookManager shims for HBase to interact with the Hadoop 1.0.x and the Hadoop 2.0+ series.
    org.apache.hadoop.hbase.util.SimpleByteRange
    A read only version of the ByteRange.
    org.apache.hadoop.hbase.util.SimpleMovingAverage<T>
    SMA measure the overall average execution time of a specific method.
    org.apache.hadoop.hbase.util.SimpleMutableByteRange
    A basic mutable ByteRange implementation.
    org.apache.hadoop.hbase.util.SimplePositionedByteRange
    Extends the basic SimpleMutableByteRange implementation with position support and it is a readonly version.
    org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
    Extends the basic AbstractPositionedByteRange implementation with position support and it is a mutable version.
    org.apache.hadoop.hbase.util.Sleeper
    Sleeper for current thread.
    org.apache.hadoop.hbase.util.SoftObjectPool<K,V>
    A SoftReference based shared object pool.
    org.apache.hadoop.hbase.util.SortedList<E>
    Simple sorted list implementation that uses ArrayList as the underlying collection so we can support RandomAccess.
    org.apache.hadoop.hbase.util.StealJobQueue<T>
    This queue allows a ThreadPoolExecutor to steal jobs from another ThreadPoolExecutor.
    org.apache.hadoop.hbase.util.Strings
    Utility for Strings.
    org.apache.hadoop.hbase.util.TableDescriptorChecker
    Only used for master to sanity check TableDescriptor.
    org.apache.hadoop.hbase.util.Threads
    Thread Utility
    org.apache.hadoop.hbase.util.TimeMeasurable<T>
    Methods that implement this interface can be measured elapsed time.
    org.apache.hadoop.hbase.util.Triple<A,B,C>
    Utility class to manage a triple.
    org.apache.hadoop.hbase.util.UnsafeAccess
     
    org.apache.hadoop.hbase.util.VersionInfo
    This class finds the Version information for HBase.
    org.apache.hadoop.hbase.util.WeakObjectPool<K,V>
    A WeakReference based shared object pool.
    org.apache.hadoop.hbase.util.WeightedMovingAverage<T>
    Different from SMA SimpleMovingAverage, WeightedMovingAverage gives each data different weight.
    org.apache.hadoop.hbase.util.WindowMovingAverage<T>
    Instead of calculate a whole time average, this class focus on the last N.
    org.apache.hadoop.hbase.util.Writables
    Utility class with methods for manipulating Writable objects
    org.apache.hadoop.hbase.util.YammerHistogramUtils
    Utility functions for working with Yammer Metrics.