Class and Description |
---|
ByteRange
Lightweight, reusable class for specifying ranges of byte[]'s.
|
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.
|
JVMClusterUtil.MasterThread
Datastructure to hold Master Thread and Master instance
|
JVMClusterUtil.RegionServerThread
Datastructure to hold RegionServer Thread and RegionServer instance
|
Pair
A generic class for pairs.
|
PairOfSameType
A generic, immutable class for pairs of objects both of type
T . |
PrettyPrinter.Unit |
RetryCounter
Operation retry accounting.
|
RetryCounterFactory |
Class and Description |
---|
Pair
A generic class for pairs.
|
RetryCounter
Operation retry accounting.
|
RetryCounterFactory |
Class and Description |
---|
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.
|
Pair
A generic class for pairs.
|
PrettyPrinter.Unit |
Class and Description |
---|
Pair
A generic class for pairs.
|
Class and Description |
---|
LossyCounting
LossyCounting utility, bounded data structure that maintains approximate high frequency elements
in data stream.
|
Pair
A generic class for pairs.
|
SortedList
Simple sorted list implementation that uses
ArrayList as the underlying
collection so we can support RandomAccess. |
Class and Description |
---|
Bytes.ByteArrayComparator
Byte array comparator class.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
Class and Description |
---|
JSONBean
Utility for doing JSON and MBeans.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
Class and Description |
---|
CancelableProgressable
Similar interface as
Progressable but returns a boolean to support
canceling the operation. |
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.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
Class and Description |
---|
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.
|
ObjectIntPair
A generic class for pair of an Object and and a primitive int value.
|
Class and Description |
---|
BloomFilter
Implements a Bloom filter, as defined by Bloom in 1970.
|
BloomFilterBase
Common methods Bloom filter methods required at read and write time.
|
BloomFilterChunk
The basic building block for the
CompoundBloomFilter |
BloomFilterWriter
Specifies methods needed to add elements to a Bloom filter and serialize the resulting Bloom
filter as a sequence of bytes.
|
ChecksumType
Checksum types.
|
Hash
This class represents a common API for hashing functions.
|
IdLock
Allows multiple concurrent clients to lock on a numeric id with a minimal memory overhead.
|
ObjectIntPair
A generic class for pair of an Object and and a primitive int value.
|
Class and Description |
---|
ByteBufferArray
This class manages an array of ByteBuffers with a default size 4MB.
|
IdReadWriteLock
Allows multiple concurrent clients to lock on a numeric id with ReentrantReadWriteLock.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
PoolMap
The
PoolMap maps a key to a collection of values, the elements of which are managed
by a pool. |
PoolMap.PoolType |
Class and Description |
---|
RegionSplitter.SplitAlgorithm
A generic interface for the RegionSplitter code to use for all it's functionality.
|
Class and Description |
---|
AbstractHBaseTool
Common base class used for HBase command-line tools.
|
Pair
A generic class for pairs.
|
RegionSplitter.SplitAlgorithm
A generic interface for the RegionSplitter code to use for all it's functionality.
|
Triple
Utility class to manage a triple.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
Class and Description |
---|
IdLock
Allows multiple concurrent clients to lock on a numeric id with a minimal memory overhead.
|
IdReadWriteLock
Allows multiple concurrent clients to lock on a numeric id with ReentrantReadWriteLock.
|
JVMClusterUtil.RegionServerThread
Datastructure to hold RegionServer Thread and RegionServer instance
|
NonceKey
This implementation is not smart and just treats nonce group and nonce as random bits.
|
Pair
A generic class for pairs.
|
ServerCommandLine
Base class for command lines that start up various HBase daemons.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
RetryCounter
Operation retry accounting.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
Class and Description |
---|
StealJobQueue
This queue allows a ThreadPoolExecutor to steal jobs from another ThreadPoolExecutor.
|
Class and Description |
---|
HbckRegionInfo
Maintain information about a particular region.
|
Pair
A generic class for pairs.
|
Class and Description |
---|
AbstractHBaseTool
Common base class used for HBase command-line tools.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
Class and Description |
---|
NonceKey
This implementation is not smart and just treats nonce group and nonce as random bits.
|
Class and Description |
---|
AvlUtil.AvlKeyComparator
The AvlTree allows to lookup an object using a custom key.
|
AvlUtil.AvlLinkedNode
This class extends the AvlNode and adds two links that will be used in conjunction with the
AvlIterableList class.
|
AvlUtil.AvlNode
This class represent a node that will be used in an AvlTree.
|
NonceKey
This implementation is not smart and just treats nonce group and nonce as random bits.
|
Pair
A generic class for pairs.
|
RetryCounter
Operation retry accounting.
|
Class and Description |
---|
RetryCounter
Operation retry accounting.
|
Class and Description |
---|
NonceKey
This implementation is not smart and just treats nonce group and nonce as random bits.
|
Pair
A generic class for pairs.
|
Class and Description |
---|
ChecksumType
Checksum types.
|
IdLock
Allows multiple concurrent clients to lock on a numeric id with a minimal memory overhead.
|
Class and Description |
---|
ObjectIntPair
A generic class for pair of an Object and and a primitive int value.
|
Class and Description |
---|
IdLock
Allows multiple concurrent clients to lock on a numeric id with a minimal memory overhead.
|
NonceKey
This implementation is not smart and just treats nonce group and nonce as random bits.
|
RetryCounter
Operation retry accounting.
|
Class and Description |
---|
AbstractHBaseTool
Common base class used for HBase command-line tools.
|
Class and Description |
---|
BloomContext
The bloom context that is used by the StorefileWriter to add the bloom details per cell
|
BloomFilter
Implements a Bloom filter, as defined by Bloom in 1970.
|
BloomFilterWriter
Specifies methods needed to add elements to a Bloom filter and serialize the resulting Bloom
filter as a sequence of bytes.
|
Bytes.RowEndKeyComparator
A
Bytes.ByteArrayComparator that treats the empty array as the largest value. |
CancelableProgressable
Similar interface as
Progressable but returns a boolean to support
canceling the operation. |
ChecksumType
Checksum types.
|
ConcatenatedLists
A collection class that contains multiple sub-lists, which allows us to not copy lists.
|
ConcatenatedLists.Iterator |
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.
|
IdLock
Allows multiple concurrent clients to lock on a numeric id with a minimal memory overhead.
|
JvmPauseMonitor
Class which sets up a simple thread which runs in a loop sleeping for a short interval of time.
|
KeyLocker
A utility class to manage a set of locks.
|
LossyCounting
LossyCounting utility, bounded data structure that maintains approximate high frequency elements
in data stream.
|
NettyEventLoopGroupConfig
Event loop group related config.
|
NonceKey
This implementation is not smart and just treats nonce group and nonce as random bits.
|
Pair
A generic class for pairs.
|
RollingStatCalculator
This class maintains mean and variation for any sequence of input provided to it.
|
ServerCommandLine
Base class for command lines that start up various HBase daemons.
|
Sleeper
Sleeper for current thread.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
Class and Description |
---|
CancelableProgressable
Similar interface as
Progressable but returns a boolean to support
canceling the operation. |
RetryCounter
Operation retry accounting.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
Class and 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.
|
ImmutableByteArray
Mainly used as keys for HashMap.
|
Pair
A generic class for pairs.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
Class and Description |
---|
KeyLocker
A utility class to manage a set of locks.
|
Pair
A generic class for pairs.
|
Class and Description |
---|
ConnectionCache
A utility to store user specific HConnections in memory.
|
JvmPauseMonitor
Class which sets up a simple thread which runs in a loop sleeping for a short interval of time.
|
Pair
A generic class for pairs.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
Class and Description |
---|
ByteRange
Lightweight, reusable class for specifying ranges of byte[]'s.
|
Pair
A generic class for pairs.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
Class and Description |
---|
ByteRange
Lightweight, reusable class for specifying ranges of byte[]'s.
|
Pair
A generic class for pairs.
|
Triple
Utility class to manage a triple.
|
Class and Description |
---|
AbstractFileStatusFilter
Typical base class for file status filter.
|
AbstractHBaseTool
Common base class used for HBase command-line tools.
|
FileStatusFilter |
FSUtils.BlackListDirFilter
Directory filter that doesn't include any of the directories in the specified blacklist
|
Pair
A generic class for pairs.
|
Class and Description |
---|
ConnectionCache
A utility to store user specific HConnections in memory.
|
JvmPauseMonitor
Class which sets up a simple thread which runs in a loop sleeping for a short interval of time.
|
Class and Description |
---|
Pair
A generic class for pairs.
|
Class and Description |
---|
AbstractHBaseTool
Common base class used for HBase command-line tools.
|
Pair
A generic class for pairs.
|
Class and Description |
---|
AbstractHBaseTool
Common base class used for HBase command-line tools.
|
Class and Description |
---|
Order
Used to describe or modify the lexicographical sort order of a
byte[] . |
PositionedByteRange
Extends
ByteRange with additional methods to support tracking a consumers position within
the viewport. |
Class and 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
SimpleByteRange implementation with position support. |
Addressing.AddressSelectionCondition
Interface for AddressSelectionCondition to check if address is acceptable
|
AvlUtil.AvlInsertOrReplace |
AvlUtil.AvlKeyComparator
The AvlTree allows to lookup an object using a custom key.
|
AvlUtil.AvlLinkedNode
This class extends the AvlNode and adds two links that will be used in conjunction with the
AvlIterableList class.
|
AvlUtil.AvlNode
This class represent a node that will be used in an AvlTree.
|
AvlUtil.AvlNodeVisitor
Visitor that allows to traverse a set of AvlNodes.
|
BloomContext
The bloom context that is used by the StorefileWriter to add the bloom details per cell
|
BloomFilter
Implements a Bloom filter, as defined by Bloom in 1970.
|
BloomFilterBase
Common methods Bloom filter methods required at read and write time.
|
BloomFilterChunk
The basic building block for the
CompoundBloomFilter |
BloomFilterWriter
Specifies methods needed to add elements to a Bloom filter and serialize the resulting Bloom
filter as a sequence of bytes.
|
BoundedPriorityBlockingQueue.PriorityQueue |
ByteBufferAllocator
Defines the way the ByteBuffers are created
|
ByteBufferUtils.ByteVisitor
Deprecated.
|
ByteBufferUtils.Comparer
Deprecated.
|
ByteBufferUtils.ComparerHolder.PureJavaComparer |
ByteBufferUtils.Converter
Deprecated.
|
ByteBufferUtils.ConverterHolder.PureJavaConverter |
ByteRange
Lightweight, reusable class for specifying ranges of byte[]'s.
|
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.Comparer |
Bytes.Converter |
Bytes.ConverterHolder.PureJavaConverter |
Bytes.LexicographicalComparerHolder.PureJavaComparer |
Bytes.LexicographicalComparerHolder.UnsafeComparer |
CancelableProgressable
Similar interface as
Progressable but returns a boolean to support
canceling the operation. |
CellHashKey
Extracts the byte for the hash calculation from the given cell
|
ChecksumType
Checksum types.
|
ClassLoaderBase
Base class loader that defines couple shared constants used by sub-classes.
|
ClassSize.MemoryLayout
MemoryLayout abstracts details about the JVM object layout.
|
ConcurrentMapUtils
Utility methods for dealing with Collections, including treating null collections as empty.
|
ConcurrentMapUtils.IOExceptionSupplier
A supplier that throws IOException when get.
|
ConnectionCache.ConnectionInfo |
CoprocessorClassLoader
ClassLoader used to load classes for Coprocessor instances.
|
Counter.Cell
Deprecated.
|
Counter.Container
Deprecated.
|
DNS.ServerType |
EnvironmentEdge
Has some basic interaction with the environment.
|
FileStatusFilter |
FSTableDescriptors
Implementation of
TableDescriptors that reads descriptors from the passed filesystem. |
FSTableDescriptors.SequenceIdAndFileLength |
FSUtils.BlackListDirFilter
Directory filter that doesn't include any of the directories in the specified blacklist
|
FSUtils.ProgressReporter
Called every so-often by storefile map builder getTableStoreFilePathMap to report progress.
|
FSVisitor.StoreFileVisitor |
Hash
This class represents a common API for hashing functions.
|
HashKey
Used to calculate the hash
Hash algorithms for Bloomfilters. |
HBaseFsck
Deprecated.
For removal in hbase-4.0.0. Use HBCK2 instead.
|
HBaseFsck.CheckRegionConsistencyWorkItem
Deprecated.
|
HbckErrorReporter
Deprecated.
Since 2.3.0. To be removed in hbase4. Use HBCK2 instead. Remove when
HBaseFsck is removed. |
HbckErrorReporter.ERROR_CODE
Deprecated.
|
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.
|
HbckTableInfo.IntegrityFixSuggester |
IdLock.Entry
An entry returned to the client as a lock object
|
IdReadWriteLock.ReferenceType |
ImmutableByteArray
Mainly used as keys for HashMap.
|
JenkinsHash
Produces 32-bit hash for hash table lookup.
|
JSONBean.Writer
Use dumping out mbeans as JSON.
|
JVMClusterUtil.MasterThread
Datastructure to hold Master Thread and Master instance
|
JVMClusterUtil.RegionServerThread
Datastructure to hold RegionServer Thread and RegionServer instance
|
JvmPauseMonitor.GcTimes |
KeyLocker
A utility class to manage a set of locks.
|
KeyRange
A key range use in split coverage.
|
LossyCounting.LossyCountingListener |
ModifyRegionUtils.RegionEditTask |
ModifyRegionUtils.RegionFillTask |
MovingAverage
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. |
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.
|
ObjectPool
A thread-safe shared object pool in which object creation is expected to be lightweight, and the
objects may be excessively created and discarded.
|
ObjectPool.ObjectFactory
An
ObjectFactory object is used to create new shared objects on demand. |
Order
Used to describe or modify the lexicographical sort order of a
byte[] . |
Pair
A generic class for pairs.
|
PoolMap.Pool |
PoolMap.PoolResourceSupplier |
PoolMap.PoolType |
PositionedByteRange
Extends
ByteRange with additional methods to support tracking a consumers position within
the viewport. |
PrettyPrinter.Unit |
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
This is a generic region split calculator.
|
RegionSplitter.NumberStringSplit |
RegionSplitter.SplitAlgorithm
A generic interface for the RegionSplitter code to use for all it's functionality.
|
RetryCounter
Operation retry accounting.
|
RetryCounter.BackoffPolicy
Policy for calculating sleeping intervals between retry attempts
|
RetryCounter.ExponentialBackoffPolicy |
RetryCounter.RetryConfig
Configuration for a retry counter
|
RetryCounterFactory |
RowBloomContext
Handles ROW bloom related context.
|
ShutdownHookManager
This class provides ShutdownHookManager shims for HBase to interact with the Hadoop 1.0.x and the
Hadoop 2.0+ series.
|
TimeMeasurable
Methods that implement this interface can be measured elapsed time.
|
Triple
Utility class to manage a triple.
|
WeakObjectPool
A
WeakReference based shared object pool. |
WindowMovingAverage
Instead of calculate a whole time average, this class focus on the last N.
|
Class and Description |
---|
HbckErrorReporter
Deprecated.
Since 2.3.0. To be removed in hbase4. Use HBCK2 instead. Remove when
HBaseFsck is removed. |
HbckRegionInfo
Maintain information about a particular region.
|
HbckTableInfo
Maintain information about a particular table.
|
Class and Description |
---|
CancelableProgressable
Similar interface as
Progressable but returns a boolean to support
canceling the operation. |
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.
|
ConcurrentMapUtils.IOExceptionSupplier
A supplier that throws IOException when get.
|
KeyLocker
A utility class to manage a set of locks.
|
Pair
A generic class for pairs.
|
Class and Description |
---|
RetryCounter
Operation retry accounting.
|
RetryCounterFactory |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.