Package org.apache.hadoop.hbase.util
package org.apache.hadoop.hbase.util
-
ClassDescriptionorg.apache.hadoop.hbase.util.AbstractByteRangeAn abstract implementation of the ByteRange APIorg.apache.hadoop.hbase.util.AbstractFileStatusFilterTypical base class for file status filter.org.apache.hadoop.hbase.util.AbstractHBaseToolCommon base class used for HBase command-line tools.org.apache.hadoop.hbase.util.AbstractPositionedByteRangeExtends the basic
SimpleByteRange
implementation with position support.org.apache.hadoop.hbase.util.AddressingUtility for network addresses, resolving and naming.org.apache.hadoop.hbase.util.Addressing.AddressSelectionConditionInterface for AddressSelectionCondition to check if address is acceptableorg.apache.hadoop.hbase.util.AtomicUtilsUtilities related to atomic operations.org.apache.hadoop.hbase.util.AvlUtilHelper 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.AvlIterableListHelper class that allows to create and manipulate a linked list of AvlLinkedNodesorg.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.AvlTreeHelper class that allows to create and manipulate an AVL Treeorg.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator<TNode extends org.apache.hadoop.hbase.util.AvlUtil.AvlNode>Iterator for the AvlTreeorg.apache.hadoop.hbase.util.BloomContextThe bloom context that is used by the StorefileWriter to add the bloom details per cellorg.apache.hadoop.hbase.util.BloomFilterImplements a Bloom filter, as defined by Bloom in 1970.org.apache.hadoop.hbase.util.BloomFilterBaseCommon methods Bloom filter methods required at read and write time.org.apache.hadoop.hbase.util.BloomFilterChunkThe basic building block for theCompoundBloomFilter
org.apache.hadoop.hbase.util.BloomFilterFactoryHandles Bloom filter initialization based on configuration and serialized metadata in the reader and writer ofHStoreFile
.org.apache.hadoop.hbase.util.BloomFilterUtilUtility methods related to BloomFiltersorg.apache.hadoop.hbase.util.BloomFilterWriterSpecifies 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.ByteArrayHashKeyorg.apache.hadoop.hbase.util.ByteBufferAllocatorDefines the way the ByteBuffers are createdorg.apache.hadoop.hbase.util.ByteBufferArrayThis class manages an array of ByteBuffers with a default size 4MB.org.apache.hadoop.hbase.util.ByteBufferUtilsDeprecated.This class will become IA.Private in HBase 3.0.org.apache.hadoop.hbase.util.ByteRangeLightweight, reusable class for specifying ranges of byte[]'s.org.apache.hadoop.hbase.util.ByteRangeUtilsUtility methods for working withByteRange
.org.apache.hadoop.hbase.util.BytesUtility 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.ByteArrayComparatorByte array comparator class.org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparatorABytes.ByteArrayComparator
that treats the empty array as the largest value.org.apache.hadoop.hbase.util.CancelableProgressableSimilar interface asProgressable
but returns a boolean to support canceling the operation.org.apache.hadoop.hbase.util.CellHashKeyExtracts the byte for the hash calculation from the given cellorg.apache.hadoop.hbase.util.ChecksumTypeChecksum types.org.apache.hadoop.hbase.util.ClassesUtilities for class manipulation.org.apache.hadoop.hbase.util.ClassLoaderBaseBase class loader that defines couple shared constants used by sub-classes.org.apache.hadoop.hbase.util.ClassSizeClass 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 projectorg.apache.hadoop.hbase.util.ClientUtilsCommon Utility class for clientsorg.apache.hadoop.hbase.util.CollectionBackedScannerUtility scanner that wraps a sortable collection and serves as a KeyValueScanner.org.apache.hadoop.hbase.util.CollectionUtilsDeprecated.Since 2.0.6/2.1.3/2.2.0org.apache.hadoop.hbase.util.CommonFSUtilsUtility methods for interacting with the underlying file system.org.apache.hadoop.hbase.util.CommonFSUtils.StreamLacksCapabilityExceptionHelper 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.CompressionTestCompression 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.ConcurrentMapUtilsUtility methods for dealing with Collections, including treating null collections as empty.org.apache.hadoop.hbase.util.ConfigurationUtilUtilities for storing more complex collection types inConfiguration
instances.org.apache.hadoop.hbase.util.ConnectionCacheA utility to store user specific HConnections in memory.org.apache.hadoop.hbase.util.CoprocessorClassLoaderClassLoader used to load classes for Coprocessor instances.org.apache.hadoop.hbase.util.CoprocessorConfigurationUtilHelper class for coprocessor host when configuration changes.org.apache.hadoop.hbase.util.CounterDeprecated.since 2.0.0 and will be removed in 3.0.0.org.apache.hadoop.hbase.util.DefaultEnvironmentEdgeDefault implementation of an environment edge.org.apache.hadoop.hbase.util.DirectMemoryUtilsUtilities for interacting with and monitoring DirectByteBuffer allocations.org.apache.hadoop.hbase.util.DNSWrapper around Hadoop's DNS class to hide reflection.org.apache.hadoop.hbase.util.DNS.ServerTypeorg.apache.hadoop.hbase.util.DynamicClassLoaderThis is a class loader that can load classes dynamically from new jar files under a configured folder.org.apache.hadoop.hbase.util.EncryptionTestorg.apache.hadoop.hbase.util.EnvironmentEdgeHas some basic interaction with the environment.org.apache.hadoop.hbase.util.EnvironmentEdgeManagerManages a singleton instance of the environment edge.org.apache.hadoop.hbase.util.ExceptionUtilThis class handles the different interruption classes.org.apache.hadoop.hbase.util.ExponentialMovingAverage<T>EMA is similar toWeightedMovingAverage
in weighted, but the weighting factor decrease exponentially.org.apache.hadoop.hbase.util.FileStatusFilterorg.apache.hadoop.hbase.util.FileSystemVersionExceptionThrown when the file system needs to be upgradedorg.apache.hadoop.hbase.util.FSTableDescriptorsImplementation ofTableDescriptors
that reads descriptors from the passed filesystem.org.apache.hadoop.hbase.util.FSUtilsUtility methods for interacting with the underlying file system.org.apache.hadoop.hbase.util.FSUtils.BlackListDirFilterDirectory filter that doesn't include any of the directories in the specified blacklistorg.apache.hadoop.hbase.util.FSUtils.DirFilterAPathFilter
that only allows directories.org.apache.hadoop.hbase.util.FSUtils.FamilyDirFilterFilter for all dirs that are legal column family names.org.apache.hadoop.hbase.util.FSUtils.HFileFilterFilter for HFiles that excludes reference files.org.apache.hadoop.hbase.util.FSUtils.HFileLinkFilterFilter for HFileLinks (StoreFiles and HFiles not included).org.apache.hadoop.hbase.util.FSUtils.ReferenceAndLinkFileFilterorg.apache.hadoop.hbase.util.FSUtils.ReferenceFileFilterorg.apache.hadoop.hbase.util.FSUtils.RegionDirFilterFilter for all dirs that don't start with '.'org.apache.hadoop.hbase.util.FSUtils.UserTableDirFilterAPathFilter
that returns usertable directories.org.apache.hadoop.hbase.util.FSVisitorUtility methods for interacting with the hbase.root file system.org.apache.hadoop.hbase.util.FSVisitor.StoreFileVisitororg.apache.hadoop.hbase.util.FutureUtilsHelper class for processing futures.org.apache.hadoop.hbase.util.GetJavaPropertyA generic way for querying Java properties.org.apache.hadoop.hbase.util.GsonUtilHelper class for gson.org.apache.hadoop.hbase.util.HashThis class represents a common API for hashing functions.org.apache.hadoop.hbase.util.HashedBytesThis 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 hashHash
algorithms for Bloomfilters.org.apache.hadoop.hbase.util.HBaseConfToolTool that prints out a configuration.org.apache.hadoop.hbase.util.HBaseFsckDeprecated.For removal in hbase-4.0.0.org.apache.hadoop.hbase.util.HBaseFsckRepairThis class contains helper methods that repair parts of hbase's filesystem contents.org.apache.hadoop.hbase.util.HbckErrorReporterDeprecated.Since 2.3.0.org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODEorg.apache.hadoop.hbase.util.HbckRegionInfoMaintain information about a particular region.org.apache.hadoop.hbase.util.HbckRegionInfo.HdfsEntryStores the regioninfo entries from HDFSorg.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntryStores the regioninfo entries scanned from METAorg.apache.hadoop.hbase.util.HbckTableInfoMaintain information about a particular table.org.apache.hadoop.hbase.util.HFileArchiveUtilHelper class for all utilities related to archival/retrieval of HFilesorg.apache.hadoop.hbase.util.IdLockAllows multiple concurrent clients to lock on a numeric id with a minimal memory overhead.org.apache.hadoop.hbase.util.IdLock.EntryAn entry returned to the client as a lock objectorg.apache.hadoop.hbase.util.IdReadWriteLock<T>Allows multiple concurrent clients to lock on a numeric id with ReentrantReadWriteLock.org.apache.hadoop.hbase.util.IdReadWriteLock.ReferenceTypeorg.apache.hadoop.hbase.util.ImmutableByteArrayMainly used as keys for HashMap.org.apache.hadoop.hbase.util.IncrementingEnvironmentEdgeUses an incrementing algorithm instead of the default.org.apache.hadoop.hbase.util.IOExceptionSupplier<V>A supplier that throws IOException when get.org.apache.hadoop.hbase.util.JenkinsHashProduces 32-bit hash for hash table lookup.org.apache.hadoop.hbase.util.JRubyFormatUtility class for converting objects to JRuby.org.apache.hadoop.hbase.util.JSONBeanUtility for doing JSON and MBeans.org.apache.hadoop.hbase.util.JSONBean.WriterUse dumping out mbeans as JSON.org.apache.hadoop.hbase.util.JsonMapperUtility class for converting objects to JSONorg.apache.hadoop.hbase.util.JSONMetricUtilorg.apache.hadoop.hbase.util.JVMThis 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.JVMClusterUtilUtility used running a cluster all in the one JVM.org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThreadDatastructure to hold Master Thread and Master instanceorg.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThreadDatastructure to hold RegionServer Thread and RegionServer instanceorg.apache.hadoop.hbase.util.JvmPauseMonitorClass which sets up a simple thread which runs in a loop sleeping for a short interval of time.org.apache.hadoop.hbase.util.JvmVersionUtility 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.KeyRangeA key range use in split coverage.org.apache.hadoop.hbase.util.LeaseNotRecoveredExceptionThrown when the lease was expected to be recovered, but the file can't be opened.org.apache.hadoop.hbase.util.LocatedBlockHelperhadoop 3.3.1 changed the return value of this method fromDatanodeInfo[]
toDatanodeInfoWithStorage[]
, 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.LogMonitoringUtility 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.ManualEnvironmentEdgeAn environment edge that uses a manually set value.org.apache.hadoop.hbase.util.MapreduceDependencyClasspathToolGenerate a classpath string containing any jars required by mapreduce jobs.org.apache.hadoop.hbase.util.MapReduceExtendedCellA wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers.org.apache.hadoop.hbase.util.MD5HashUtility class for MD5 MD5 hash produces a 128-bit digest.org.apache.hadoop.hbase.util.Methodsorg.apache.hadoop.hbase.util.ModifyRegionUtilsUtility methods for interacting with the regions.org.apache.hadoop.hbase.util.ModifyRegionUtils.RegionEditTaskorg.apache.hadoop.hbase.util.ModifyRegionUtils.RegionFillTaskorg.apache.hadoop.hbase.util.MovingAverage<T>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.org.apache.hadoop.hbase.util.MultiHConnectionProvides ability to create multiple Connection instances and allows to process a batch of actions using CHTable.doBatchWithCallback()org.apache.hadoop.hbase.util.MunkresAssignmentComputes 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.MurmurHashThis is a very fast, non-cryptographic hash suitable for general hash-based lookup.org.apache.hadoop.hbase.util.MurmurHash3This is a very fast, non-cryptographic hash suitable for general hash-based lookup.org.apache.hadoop.hbase.util.NettyEventLoopGroupConfigEvent loop group related config.org.apache.hadoop.hbase.util.NettyFutureUtilsHelper class for processing netty futures.org.apache.hadoop.hbase.util.NettyUnsafeUtilsWraps some usages of netty's unsafe API, for ease of maintainability.org.apache.hadoop.hbase.util.NonceKeyThis 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> AnObjectFactory
object is used to create new shared objects on demand.org.apache.hadoop.hbase.util.OrderUsed to describe or modify the lexicographical sort order of abyte[]
.org.apache.hadoop.hbase.util.OrderedBytesUtility 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 typeT
.org.apache.hadoop.hbase.util.PoolMap<K,V> ThePoolMap
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.PoolTypeorg.apache.hadoop.hbase.util.PositionedByteRangeExtendsByteRange
with additional methods to support tracking a consumers position within the viewport.org.apache.hadoop.hbase.util.PrettyPrinterorg.apache.hadoop.hbase.util.PrettyPrinter.Unitorg.apache.hadoop.hbase.util.ProcessUtilsProcess related utilities.org.apache.hadoop.hbase.util.Random64An instance of this class is used to generate a stream of pseudorandom numbers.org.apache.hadoop.hbase.util.ReadOnlyByteRangeExceptionException thrown when a read only byte range is modifiedorg.apache.hadoop.hbase.util.RecoverLeaseFSUtilsUtility 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.ReflectionUtilsorg.apache.hadoop.hbase.util.RegionMoverTool 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.RegionMoverBuilderBuilder 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.RegionSplitterTheRegionSplitter
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.DecimalStringSplitThe 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.HexStringSplitHexStringSplit is a well-knownRegionSplitter.SplitAlgorithm
for choosing region boundaries.org.apache.hadoop.hbase.util.RegionSplitter.NumberStringSplitorg.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithmA generic interface for the RegionSplitter code to use for all it's functionality.org.apache.hadoop.hbase.util.RegionSplitter.UniformSplitA 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.RetryCounterOperation retry accounting.org.apache.hadoop.hbase.util.RetryCounter.BackoffPolicyPolicy for calculating sleeping intervals between retry attemptsorg.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicyorg.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicyWithLimitorg.apache.hadoop.hbase.util.RetryCounter.RetryConfigConfiguration for a retry counterorg.apache.hadoop.hbase.util.RetryCounterFactoryorg.apache.hadoop.hbase.util.RollingStatCalculatorThis class maintains mean and variation for any sequence of input provided to it.org.apache.hadoop.hbase.util.RotateFileA file storage which supports atomic update through two files, i.e, rotating.org.apache.hadoop.hbase.util.RowBloomContextHandles ROW bloom related context.org.apache.hadoop.hbase.util.RowBloomHashKeyorg.apache.hadoop.hbase.util.RowColBloomContextHandles ROWCOL bloom related context.org.apache.hadoop.hbase.util.RowColBloomHashKeyAn hash key for ROWCOL bloom.org.apache.hadoop.hbase.util.RowPrefixFixedLengthBloomContextHandles ROWPREFIX bloom related context.org.apache.hadoop.hbase.util.ServerCommandLineBase class for command lines that start up various HBase daemons.org.apache.hadoop.hbase.util.ServerRegionReplicaUtilSimilar toRegionReplicaUtil
but for the server sideorg.apache.hadoop.hbase.util.ShutdownHookManagerThis 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.SimpleByteRangeA read only version of theByteRange
.org.apache.hadoop.hbase.util.SimpleMovingAverage<T>SMA measure the overall average execution time of a specific method.org.apache.hadoop.hbase.util.SimpleMutableByteRangeA basic mutableByteRange
implementation.org.apache.hadoop.hbase.util.SimplePositionedByteRangeExtends the basicSimpleMutableByteRange
implementation with position support and it is a readonly version.org.apache.hadoop.hbase.util.SimplePositionedMutableByteRangeExtends the basicAbstractPositionedByteRange
implementation with position support and it is a mutable version.org.apache.hadoop.hbase.util.SleeperSleeper for current thread.org.apache.hadoop.hbase.util.SoftObjectPool<K,V> ASoftReference
based shared object pool.org.apache.hadoop.hbase.util.SortedList<E>Simple sorted list implementation that usesArrayList
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.StringsUtility for Strings.org.apache.hadoop.hbase.util.TableDescriptorCheckerOnly used for master to sanity checkTableDescriptor
.org.apache.hadoop.hbase.util.ThreadsThread Utilityorg.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.UnsafeAccessorg.apache.hadoop.hbase.util.VersionInfoThis class finds the Version information for HBase.org.apache.hadoop.hbase.util.WeakObjectPool<K,V> AWeakReference
based shared object pool.org.apache.hadoop.hbase.util.WeightedMovingAverage<T>Different from SMASimpleMovingAverage
, 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.WritablesUtility class with methods for manipulating Writable objectsorg.apache.hadoop.hbase.util.YammerHistogramUtilsUtility functions for working with Yammer Metrics.org.apache.hadoop.hbase.util.ZKDataMigratorDeprecated.Since 2.0.0.