Uses of Package
org.apache.hadoop.hbase.util
Package
Description
Provides HBase Client
Restrict the domain of a data attribute, often times to fulfill business rules/requirements.
Table of Contents
Provides row-level filters applied to HRegion scan results during calls to
ResultScanner.next()
.This package provides access to JMX primarily through the
JMXJsonServlet
class.Provides implementations of
HFile
and HFile
BlockCache
.Provides
BucketCache
, an implementation of
BlockCache
.Tools to help define network clients and servers.
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Multi Cluster Replication
HBase REST
Provides an HBase Thrift
service.
This package provides the definition and implementation of HBase's
extensible data type API.
-
ClassDescriptionCommon base class used for HBase command-line tools.Lightweight, reusable class for specifying ranges of byte[]'s.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.Datastructure to hold Master Thread and Master instanceDatastructure to hold RegionServer Thread and RegionServer instanceEvent loop group related config.A generic class for pairs.A generic, immutable class for pairs of objects both of type
T
.Zipf distribution.A generic interface for the RegionSplitter code to use for all it's functionality.Operation retry accounting.Sleeper for current thread. -
ClassDescriptionCommon base class used for HBase command-line tools.A generic class for pairs.
-
-
ClassDescriptionCommon base class used for HBase command-line tools.A generic class for pairs.
-
ClassDescriptionA generic class for pairs.Operation retry accounting.
-
ClassDescriptionUtility 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.A supplier that throws IOException when get.A generic class for pairs.
-
-
ClassDescriptionLossyCounting utility, bounded data structure that maintains approximate high frequency elements in data stream.A generic class for pairs.Simple sorted list implementation that uses
ArrayList
as the underlying collection so we can support RandomAccess. -
-
-
-
-
-
ClassDescriptionSimilar interface as
Progressable
but returns a boolean to support canceling the operation.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. -
-
ClassDescriptionUtility 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.A generic class for pair of an Object and and a primitive int value.
-
ClassDescriptionImplements a Bloom filter, as defined by Bloom in 1970.Common methods Bloom filter methods required at read and write time.The basic building block for the
CompoundBloomFilter
Specifies methods needed to add elements to a Bloom filter and serialize the resulting Bloom filter as a sequence of bytes.Checksum types.This class represents a common API for hashing functions.Allows multiple concurrent clients to lock on a numeric id with a minimal memory overhead.A generic class for pair of an Object and and a primitive int value.A generic class for pairs. -
ClassDescriptionThis class manages an array of ByteBuffers with a default size 4MB.Allows multiple concurrent clients to lock on a numeric id with ReentrantReadWriteLock.A generic class for pairs.
-
-
ClassDescriptionA generic class for pairs.The
PoolMap
maps a key to a collection of values, the elements of which are managed by a pool. -
ClassDescriptionA generic interface for the RegionSplitter code to use for all it's functionality.
-
ClassDescriptionCommon base class used for HBase command-line tools.A supplier that throws IOException when get.A generic class for pairs.A generic interface for the RegionSplitter code to use for all it's functionality.Utility class to manage a triple.
-
-
ClassDescriptionAllows multiple concurrent clients to lock on a numeric id with a minimal memory overhead.Allows multiple concurrent clients to lock on a numeric id with ReentrantReadWriteLock.Datastructure to hold RegionServer Thread and RegionServer instanceThis implementation is not smart and just treats nonce group and nonce as random bits.A generic class for pairs.A generic, immutable class for pairs of objects both of type
T
.Base class for command lines that start up various HBase daemons. -
-
ClassDescriptionCommon base class used for HBase command-line tools.A generic class for pairs.
-
ClassDescriptionThis queue allows a ThreadPoolExecutor to steal jobs from another ThreadPoolExecutor.
-
ClassDescriptionMaintain information about a particular region.A generic class for pairs.
-
-
-
ClassDescriptionThis implementation is not smart and just treats nonce group and nonce as random bits.
-
ClassDescriptionThe AvlTree allows to lookup an object using a custom key.This class extends the AvlNode and adds two links that will be used in conjunction with the AvlIterableList class.This class represent a node that will be used in an AvlTree.This implementation is not smart and just treats nonce group and nonce as random bits.A generic class for pairs.Operation retry accounting.
-
-
-
ClassDescriptionChecksum types.Allows multiple concurrent clients to lock on a numeric id with a minimal memory overhead.
-
-
ClassDescriptionA generic class for pair of an Object and and a primitive int value.
-
ClassDescriptionAllows multiple concurrent clients to lock on a numeric id with a minimal memory overhead.An entry returned to the client as a lock objectThis implementation is not smart and just treats nonce group and nonce as random bits.Operation retry accounting.
-
-
ClassDescriptionThe bloom context that is used by the StorefileWriter to add the bloom details per cellImplements a Bloom filter, as defined by Bloom in 1970.Specifies methods needed to add elements to a Bloom filter and serialize the resulting Bloom filter as a sequence of bytes.A
Bytes.ByteArrayComparator
that treats the empty array as the largest value.Similar interface asProgressable
but returns a boolean to support canceling the operation.Checksum types.A collection class that contains multiple sub-lists, which allows us to not copy lists.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.Allows multiple concurrent clients to lock on a numeric id with a minimal memory overhead.Class which sets up a simple thread which runs in a loop sleeping for a short interval of time.A utility class to manage a set of locks.LossyCounting utility, bounded data structure that maintains approximate high frequency elements in data stream.This implementation is not smart and just treats nonce group and nonce as random bits.A generic class for pairs.Operation retry accounting.This class maintains mean and variation for any sequence of input provided to it.Base class for command lines that start up various HBase daemons. -
-
ClassDescriptionSimilar interface as
Progressable
but returns a boolean to support canceling the operation.Operation retry accounting. -
-
ClassDescriptionHelper 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.Mainly used as keys for HashMap.A generic class for pairs.
-
-
-
ClassDescriptionA utility to store user specific HConnections in memory.Class which sets up a simple thread which runs in a loop sleeping for a short interval of time.A generic class for pairs.
-
-
-
-
-
-
-
ClassDescriptionTypical base class for file status filter.Common base class used for HBase command-line tools.Directory filter that doesn't include any of the directories in the specified blacklistA generic class for pairs.
-
ClassDescriptionA utility to store user specific HConnections in memory.Class which sets up a simple thread which runs in a loop sleeping for a short interval of time.
-
-
ClassDescriptionCommon base class used for HBase command-line tools.A generic class for pairs.
-
-
ClassDescriptionUsed to describe or modify the lexicographical sort order of a
byte[]
.ExtendsByteRange
with additional methods to support tracking a consumers position within the viewport. -
ClassDescriptionAn abstract implementation of the ByteRange APITypical base class for file status filter.Common base class used for HBase command-line tools.Extends the basic
SimpleByteRange
implementation with position support.Interface for AddressSelectionCondition to check if address is acceptableThe AvlTree allows to lookup an object using a custom key.This class extends the AvlNode and adds two links that will be used in conjunction with the AvlIterableList class.This class represent a node that will be used in an AvlTree.Visitor that allows to traverse a set of AvlNodes.The bloom context that is used by the StorefileWriter to add the bloom details per cellImplements a Bloom filter, as defined by Bloom in 1970.Common methods Bloom filter methods required at read and write time.The basic building block for theCompoundBloomFilter
Specifies methods needed to add elements to a Bloom filter and serialize the resulting Bloom filter as a sequence of bytes.Defines the way the ByteBuffers are createdLightweight, reusable class for specifying ranges of byte[]'s.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.Byte array comparator class.Similar interface asProgressable
but returns a boolean to support canceling the operation.Extracts the byte for the hash calculation from the given cellChecksum types.Base class loader that defines couple shared constants used by sub-classes.MemoryLayout abstracts details about the JVM object layout.ClassLoader used to load classes for Coprocessor instances.Has some basic interaction with the environment.Implementation ofTableDescriptors
that reads descriptors from the passed filesystem.Directory filter that doesn't include any of the directories in the specified blacklistCalled every so-often by storefile map builder getTableStoreFilePathMap to report progress.This class represents a common API for hashing functions.Used to calculate the hashHash
algorithms for Bloomfilters.Deprecated.For removal in hbase-4.0.0.Deprecated.Deprecated.Since 2.3.0.Deprecated.Maintain information about a particular region.Stores the regioninfo entries from HDFSStores the regioninfo entries scanned from METAStores the regioninfo retrieved from Online region servers.Maintain information about a particular table.An entry returned to the client as a lock objectAllows multiple concurrent clients to lock on a numeric id with ReentrantReadWriteLock.Mainly used as keys for HashMap.A supplier that throws IOException when get.Produces 32-bit hash for hash table lookup.Use dumping out mbeans as JSON.Datastructure to hold Master Thread and Master instanceDatastructure to hold RegionServer Thread and RegionServer instanceA utility class to manage a set of locks.A key range use in split coverage.A generator of random keys and values for load testing.The purpose of introduction ofMovingAverage
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.Common base class for reader and writer parts of multi-thread HBase load test (See LoadTestTool).Default implementation of LoadTestDataGenerator that uses LoadTestKVGenerator, fixed set of column families, and random number of columns in range.Creates multiple threads that read and verify previously written dataCreates multiple threads that write key/values into theCreates multiple threads that write key/values into theCreates multiple threads that write key/values into theThis is a very fast, non-cryptographic hash suitable for general hash-based lookup.This is a very fast, non-cryptographic hash suitable for general hash-based lookup.Event loop group related config.A thread-safe shared object pool in which object creation is expected to be lightweight, and the objects may be excessively created and discarded.AnObjectFactory
object is used to create new shared objects on demand.Used to describe or modify the lexicographical sort order of abyte[]
.A generic class for pairs.ExtendsByteRange
with additional methods to support tracking a consumers position within the viewport.Interface for discrete (integer) random distributions.Tool for loading/unloading regions to/from given regionserver This tool can be run from Command line directly as a utility.Builder for Region mover.This is a generic region split calculator.A generic interface for the RegionSplitter code to use for all it's functionality.Operation retry accounting.Policy for calculating sleeping intervals between retry attemptsConfiguration for a retry counterHandles ROW bloom related context.This class provides ShutdownHookManager shims for HBase to interact with the Hadoop 1.0.x and the Hadoop 2.0+ series.Methods that implement this interface can be measured elapsed time.Utility class to manage a triple.AWeakReference
based shared object pool.Instead of calculate a whole time average, this class focus on the last N. -
ClassDescriptionDeprecated.Since 2.3.0.Maintain information about a particular region.Maintain information about a particular table.
-
ClassDescriptionA generator of random keys and values for load testing.Default implementation of LoadTestDataGenerator that uses LoadTestKVGenerator, fixed set of column families, and random number of columns in range.
-
ClassDescriptionSimilar interface as
Progressable
but returns a boolean to support canceling the operation.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.A supplier that throws IOException when get.A utility class to manage a set of locks.A generic class for pairs. -