All Classes and Interfaces

Class
Description
org.apache.hadoop.hbase.Abortable
Interface to support the aborting of a given server or client.
org.apache.hadoop.hbase.util.AbstractByteRange
An abstract implementation of the ByteRange API
org.apache.hadoop.hbase.client.AbstractClientScanner
Helper class for custom client scanners.
org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder
 
org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder.AbstractEncodedSeeker
Decorates EncodedSeeker with a HFileBlockDecodingContext
org.apache.hadoop.hbase.util.AbstractFileStatusFilter
Typical base class for file status filter.
org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL<W extends org.apache.hadoop.hbase.wal.WALProvider.WriterBase>
Implementation of WAL to go against FileSystem; i.e.
org.apache.hadoop.hbase.wal.AbstractFSWALProvider<T extends org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL<?>>
Base class of a WAL Provider that returns a single thread safe WAL that writes to Hadoop FS.
org.apache.hadoop.hbase.wal.AbstractFSWALProvider.Initializer
 
org.apache.hadoop.hbase.wal.AbstractFSWALProvider.WALStartTimeComparator
Comparator used to compare WAL files together based on their start time.
org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
A utility class that encapsulates SASL logic for RPC client.
org.apache.hadoop.hbase.util.AbstractHBaseTool
Common base class used for HBase command-line tools.
org.apache.hadoop.hbase.regionserver.AbstractMemStore
An abstract class, which implements the behaviour shared by all concrete memstore instances.
org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
Base class for cell sink that separates the provided cells into multiple files.
org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter.WriterFactory
 
org.apache.hadoop.hbase.util.AbstractPositionedByteRange
Extends the basic SimpleByteRange implementation with position support.
org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
Base class for Protobuf log writer.
org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
Base class for reading protobuf based wal reader
org.apache.hadoop.hbase.ipc.AbstractRpcClient<T extends org.apache.hadoop.hbase.ipc.RpcConnection>
Provides the basics for a RpcClient implementation like configuration and Logging.
org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementation
Blocking rpc channel that goes via hbase rpc.
org.apache.hadoop.hbase.ipc.AbstractRpcClient.RpcChannelImplementation
Async rpc channel that goes via hbase rpc.
org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
An abstract class for ScreenView that has the common useful methods and the default implementations for the abstract methods.
org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
Abstract implementation for SpaceViolationPolicyEnforcement.
org.apache.hadoop.hbase.wal.AbstractWALProvider
Base class for a WAL Provider.
org.apache.hadoop.hbase.wal.AbstractWALRoller<T extends org.apache.hadoop.hbase.Abortable>
Runs periodically to determine if the WAL should be rolled.
org.apache.hadoop.hbase.security.AccessDeniedException
Exception thrown by access-related methods.
org.apache.hadoop.hbase.client.Action
A Get, Put, Increment, Append, or Delete associated with it's region.
org.apache.hadoop.hbase.master.ActiveMasterManager
Handles everything on master-side related to master election.
org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
A class to ease dealing with tables that have and do not have violation policies being enforced.
org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
Adaptive LIFO blocking queue utilizing CoDel algorithm to prevent queue overloading.
org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
Adaptive is a heuristic that chooses whether to apply data compaction or not based on the level of redundancy in the data.
org.apache.hadoop.hbase.net.Address
An immutable type to hold a hostname and port combo, like an Endpoint or java.net.InetSocketAddress (but without danger of our calling resolve -- we do NOT want a resolve happening every time we want to hold a hostname and port combo).
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.client.Admin
The administrative API for HBase.
org.apache.hadoop.hbase.http.AdminAuthorizedFilter
 
org.apache.hadoop.hbase.http.AdminAuthorizedServlet
General servlet which is admin-authorized.
org.apache.hadoop.hbase.client.AdvancedScanResultConsumer
This is the low level API for asynchronous scan.
org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanController
Used to suspend or stop a scan, or get a scan cursor if available.
org.apache.hadoop.hbase.client.AdvancedScanResultConsumer.ScanResumer
Used to resume a scan.
org.apache.hadoop.hbase.io.crypto.aes.AES
AES-128, provided by the JCE
org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
 
org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
 
org.apache.hadoop.hbase.io.hfile.AgeSnapshot
Snapshot of block cache age in cache.
org.apache.hadoop.hbase.ipc.AnnotationReadingPriorityFunction<T extends org.apache.hadoop.hbase.HBaseRpcServicesBase<?>>
Reads special method annotations and table names to figure a priority for use by QoS facility in ipc; e.g: rpcs to hbase:meta get priority.
org.apache.hadoop.hbase.client.Append
Performs Append operations on a single row.
org.apache.hadoop.hbase.ArrayBackedTag
This is a Tag implementation in which value is backed by an on heap byte array.
org.apache.hadoop.hbase.master.AssignmentVerificationReport
Helper class that is used by RegionPlacementMaintainer to print information for favored nodes
org.apache.hadoop.hbase.client.AsyncAdmin
The asynchronous administrative API for HBase.
org.apache.hadoop.hbase.client.AsyncAdminBuilder
For creating AsyncAdmin.
org.apache.hadoop.hbase.client.AsyncAdminClientUtils
Additional Asynchronous Admin capabilities for clients.
org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller<T>
 
org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller.Callable<T>
 
org.apache.hadoop.hbase.client.AsyncBufferedMutator
Used to communicate with a single HBase table in batches.
org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilder
For creating AsyncBufferedMutator.
org.apache.hadoop.hbase.client.example.AsyncClientExample
A simple example shows how to use asynchronous client.
org.apache.hadoop.hbase.client.AsyncClusterConnection
The asynchronous connection for internal usage.
org.apache.hadoop.hbase.client.AsyncConnection
The asynchronous version of Connection.
org.apache.hadoop.hbase.client.AsyncConnectionImpl
The implementation of AsyncConnection.
org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutput
Interface for asynchronous filesystem output stream.
org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutputHelper
Helper class for creating AsyncFSOutput.
org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
An asynchronous implementation of FSWAL.
org.apache.hadoop.hbase.wal.AsyncFSWALProvider
A WAL provider that use AsyncFSWAL.
org.apache.hadoop.hbase.wal.AsyncFSWALProvider.AsyncWriter
 
org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller<T>
Retry caller for a request call to master.
org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller.Callable<T>
 
org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
AsyncWriter for protobuf-based WAL.
org.apache.hadoop.hbase.client.AsyncRegionReplicationRetryingCaller
For replicating edits to secondary replicas.
org.apache.hadoop.hbase.client.AsyncRegionServerAdmin
A simple wrapper of the AdminProtos.AdminService for a region server, which returns a CompletableFuture.
org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller<T>
 
org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller<T>
Retry caller for a request call to region server.
org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller.Callable<T>
 
org.apache.hadoop.hbase.client.AsyncTable<C extends org.apache.hadoop.hbase.client.ScanResultConsumerBase>
The interface for asynchronous version of Table.
org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateBuilder
Deprecated.
Since 3.0.0, will be removed in 4.0.0.
org.apache.hadoop.hbase.client.AsyncTable.CheckAndMutateWithFilterBuilder
Deprecated.
Since 3.0.0, will be removed in 4.0.0.
org.apache.hadoop.hbase.client.AsyncTable.CoprocessorCallback<R>
The callback when we want to execute a coprocessor call on a range of regions.
org.apache.hadoop.hbase.client.AsyncTable.CoprocessorServiceBuilder<S,R>
Helper class for sending coprocessorService request that executes a coprocessor call on regions which are covered by a range.
org.apache.hadoop.hbase.client.AsyncTable.PartialResultCoprocessorCallback<S,R>
Some coprocessors may support the idea of "partial results." If for some reason a coprocessor cannot return all results for a given region in a single response, the client side can be designed to recognize this and continuing requesting more results until they are completely accumulated in the client.
org.apache.hadoop.hbase.client.AsyncTableBuilder<C extends org.apache.hadoop.hbase.client.ScanResultConsumerBase>
For creating AsyncTable.
org.apache.hadoop.hbase.client.AsyncTableRegionLocator
The asynchronous version of RegionLocator.
org.apache.hadoop.hbase.util.AtomicUtils
Utilities related to atomic operations.
org.apache.hadoop.hbase.client.Attributes
 
org.apache.hadoop.hbase.hbtop.terminal.Attributes
The attributes of text in the terminal.
org.apache.hadoop.hbase.http.lib.AuthenticationFilterInitializer
This class is copied from Hadoop.
org.apache.hadoop.hbase.security.AuthMethod
Authentication method
org.apache.hadoop.hbase.AuthUtil
Deprecated.
since 2.2.0, to be marked as InterfaceAudience.Private in 4.0.0.
org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
This limiter will refill resources at every TimeUnit/resources interval.
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.backup.BackupAdmin
The administrative API for HBase Backup.
org.apache.hadoop.hbase.backup.BackupClientFactory
 
org.apache.hadoop.hbase.backup.BackupCopyJob
Backup copy job is a part of a backup process.
org.apache.hadoop.hbase.backup.BackupDriver
Command-line entry point for backup operation
org.apache.hadoop.hbase.backup.BackupHFileCleaner
Implementation of a file cleaner that checks if an hfile is still referenced by backup before deleting it from hfile archive directory.
org.apache.hadoop.hbase.backup.BackupInfo
An object to encapsulate the information for each backup session
org.apache.hadoop.hbase.backup.BackupInfo.BackupPhase
BackupPhase - phases of an ACTIVE backup session (running), when state of a backup session is BackupState.RUNNING
org.apache.hadoop.hbase.backup.BackupInfo.BackupState
Backup session states
org.apache.hadoop.hbase.backup.BackupInfo.Filter
 
org.apache.hadoop.hbase.backup.BackupMergeJob
Backup merge operation job interface.
org.apache.hadoop.hbase.backup.BackupObserver
An Observer to facilitate backup operations
org.apache.hadoop.hbase.backup.BackupRequest
POJO class for backup request
org.apache.hadoop.hbase.backup.BackupRequest.Builder
 
org.apache.hadoop.hbase.backup.BackupRestoreConstants
BackupRestoreConstants holds a bunch of HBase Backup and Restore constants
org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
 
org.apache.hadoop.hbase.backup.BackupRestoreFactory
Factory implementation for backup/restore related jobs
org.apache.hadoop.hbase.backup.BackupTableInfo
Backup related information encapsulated for a table.
org.apache.hadoop.hbase.backup.BackupType
 
org.apache.hadoop.hbase.ipc.BadAuthException
 
org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
An RpcExecutor that will balance requests evenly across all its queues, but still remains efficient with a single queue via an inlinable queue balancing mechanism.
History of balancer decisions taken for region movements.
org.apache.hadoop.hbase.client.BalancerDecision.Builder
 
org.apache.hadoop.hbase.namequeues.BalancerDecisionDetails
Balancer decision details that would be passed on to ring buffer for history
org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
In-memory Queue service provider for Balancer Decision events
org.apache.hadoop.hbase.client.BalanceRequest
Encapsulates options for executing a run of the Balancer.
org.apache.hadoop.hbase.client.BalanceRequest.Builder
Builder for constructing a BalanceRequest
org.apache.hadoop.hbase.client.BalanceResponse
Response returned from a balancer invocation
org.apache.hadoop.hbase.client.BalanceResponse.Builder
Used in HMaster to build a BalanceResponse for returning results of a balance invocation to callers
History of detail information that balancer movements was rejected
org.apache.hadoop.hbase.client.BalancerRejection.Builder
 
org.apache.hadoop.hbase.namequeues.BalancerRejectionDetails
Balancer rejection details that would be passed on to ring buffer for history
org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService
In-memory Queue service provider for Balancer Rejection events
org.apache.hadoop.hbase.BaseConfigurable
HBase version of Hadoop's Configured class that doesn't initialize the configuration via BaseConfigurable.setConf(Configuration) in the constructor, but only sets the configuration through the BaseConfigurable.setConf(Configuration) method
org.apache.hadoop.hbase.codec.BaseDecoder
Base implementation for Codec.Decoder.
org.apache.hadoop.hbase.codec.BaseDecoder.PBIS
 
org.apache.hadoop.hbase.codec.BaseEncoder
TODO javadoc
org.apache.hadoop.hbase.coprocessor.BaseEnvironment<C extends org.apache.hadoop.hbase.Coprocessor>
Encapsulation of the environment of each coprocessor
org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
A Base implementation for ReplicationEndpoints.
org.apache.hadoop.hbase.metrics.BaseSource
BaseSource for dynamic metrics to announce to Metrics2.
org.apache.hadoop.hbase.metrics.BaseSourceImpl
Hadoop 2 implementation of BaseSource (using metrics2 framework).
org.apache.hadoop.hbase.regionserver.BasicMemStoreCompactionStrategy
Basic strategy chooses between two actions: flattening a segment or merging indices of all segments in the pipeline.
org.apache.hadoop.hbase.client.BatchScanResultCache
A scan result cache for batched scan, i.e, scan.getBatch() > 0 && !scan.getAllowPartialResults().
org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminal
An implementation of the Terminal interface for batch mode.
org.apache.hadoop.hbase.hbtop.terminal.impl.batch.BatchTerminalPrinter
An implementation of the TerminalPrinter interface for batch mode.
org.apache.hadoop.hbase.filter.BigDecimalComparator
A BigDecimal comparator which numerical compares against the specified byte array
org.apache.hadoop.hbase.filter.BinaryComparator
A binary comparator which lexicographically compares against the specified byte array using Bytes.compareTo(byte[], byte[]).
org.apache.hadoop.hbase.filter.BinaryComponentComparator
A comparator which compares against a specified byte array, but only compares specific portion of the byte array.
org.apache.hadoop.hbase.filter.BinaryPrefixComparator
A comparator which compares against a specified byte array, but only compares up to the length of this byte array.
org.apache.hadoop.hbase.filter.BitComparator
A bit comparator which performs the specified bitwise operation on each of the bytes with the specified byte array.
org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
Bit operators.
org.apache.hadoop.hbase.io.hfile.BlockCache
Block cache interface.
org.apache.hadoop.hbase.io.hfile.BlockCacheFactory
 
org.apache.hadoop.hbase.io.hfile.BlockCacheKey
Cache Key for use with implementations of BlockCache
org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
Utilty for aggregating counts in CachedBlocks and toString/toJSON CachedBlocks and BlockCaches.
org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
Use one of these to keep a running account of cached blocks by file.
org.apache.hadoop.hbase.io.hfile.BlockCompressedSizePredicator
Allows for defining different compression rate predicates on its implementing classes.
org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
 
org.apache.hadoop.hbase.ipc.BlockingRpcCallback<R>
Simple RpcCallback implementation providing a Future-like BlockingRpcCallback.get() method, which will block util the instance's BlockingRpcCallback.run(Object) method has been called.
org.apache.hadoop.hbase.ipc.BlockingRpcClient
Does RPC against a cluster.
org.apache.hadoop.hbase.io.util.BlockIOUtils
 
org.apache.hadoop.hbase.io.hfile.BlockPriority
 
org.apache.hadoop.hbase.io.hfile.BlockType
Various types of HFile blocks.
org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
 
org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
BlockWithScanInfo is wrapper class for HFileBlock with other attributes.
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.io.hfile.BloomFilterMetrics
 
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.regionserver.BloomType
 
org.apache.hadoop.hbase.master.BooleanStateStore
Store a boolean state.
org.apache.hadoop.hbase.regionserver.BootstrapNodeManager
Manage the bootstrap node list at region server side.
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.wal.BoundedEntryBuffers
Used for BoundedRecoveredEditsOutputSink.
org.apache.hadoop.hbase.wal.BoundedGroupingStrategy
A WAL grouping strategy that limits the number of wal groups to "hbase.wal.regiongrouping.numgroups".
org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue<E>
A generic bounded blocking Priority-Queue.
org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
A WALSplitter sink that outputs HFiles.
org.apache.hadoop.hbase.tool.coprocessor.Branch1CoprocessorMethods
 
org.apache.hadoop.hbase.regionserver.BrokenStoreFileCleaner
This Chore, every time it runs, will clear the unsused HFiles in the data folder.
org.apache.hadoop.hbase.client.BufferedMutator
Used to communicate with a single HBase table similar to Table but meant for batched, asynchronous puts.
org.apache.hadoop.hbase.client.BufferedMutator.ExceptionListener
Listens for asynchronous exceptions on a BufferedMutator.
org.apache.hadoop.hbase.client.example.BufferedMutatorExample
An example of using the BufferedMutator interface.
org.apache.hadoop.hbase.client.BufferedMutatorParams
Parameters for instantiating a BufferedMutator.
org.apache.hadoop.hbase.replication.BulkLoadCellFilter
 
org.apache.hadoop.hbase.coprocessor.BulkLoadObserver
Coprocessors implement this interface to observe and mediate bulk load operations.
org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
This class represents a split policy which makes the split decision based on how busy a region is.
org.apache.hadoop.hbase.filter.ByteArrayComparable
Base class for byte array comparators
org.apache.hadoop.hbase.util.ByteArrayHashKey
 
org.apache.hadoop.hbase.io.ByteArrayOutputStream
Our own implementation of ByteArrayOutputStream where all methods are NOT synchronized and supports writing ByteBuffer directly to it.
org.apache.hadoop.hbase.http.gson.ByteArraySerializer
Serialize a byte[] using Bytes.toString().
org.apache.hadoop.hbase.nio.ByteBuff
An abstract class that abstracts out as to how the byte buffers are used, either single or multiple.
org.apache.hadoop.hbase.io.ByteBuffAllocator
ByteBuffAllocator is a nio ByteBuffer pool.
org.apache.hadoop.hbase.io.ByteBuffAllocator.Recycler
 
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.regionserver.ByteBufferChunkKeyValue
ByteBuffer based cell which has the chunkid at the 0th offset
org.apache.hadoop.hbase.ByteBufferExtendedCell
This class is a server side extension to the Cell interface.
org.apache.hadoop.hbase.io.ByteBufferInputStream
Not thread safe!
org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
This is a key only Cell implementation which is identical to KeyValue.KeyOnlyKeyValue with respect to key serialization but have its data in the form of Byte buffer (onheap and offheap).
org.apache.hadoop.hbase.ByteBufferKeyValue
This Cell is an implementation of ByteBufferExtendedCell where the data resides in off heap/ on heap ByteBuffer
org.apache.hadoop.hbase.io.ByteBufferListOutputStream
An OutputStream which writes data into ByteBuffers.
org.apache.hadoop.hbase.io.ByteBufferOutputStream
Not thread safe!
org.apache.hadoop.hbase.ByteBufferTag
This is a Tag implementation in which value is backed by ByteBuffer
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.io.ByteBufferWriter
This interface marks a class to support writing ByteBuffers into it.
org.apache.hadoop.hbase.io.ByteBufferWriterDataOutputStream
Our extension of DataOutputStream which implements ByteBufferWriter
org.apache.hadoop.hbase.io.ByteBufferWriterOutputStream
When deal with OutputStream which is not ByteBufferWriter type, wrap it with this class.
org.apache.hadoop.hbase.io.ByteBuffInputStream
Not thread safe!
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.io.hfile.Cacheable
Cacheable is an interface that allows for an object to be cached.
org.apache.hadoop.hbase.io.hfile.CacheableDeserializer<T extends org.apache.hadoop.hbase.io.hfile.Cacheable>
Interface for a deserializer.
org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
This class is used to manage the identifiers for CacheableDeserializer.
org.apache.hadoop.hbase.io.hfile.CacheConfig
Stores all of the cache objects and configuration for a single HFile.
org.apache.hadoop.hbase.io.hfile.CachedBlock
 
org.apache.hadoop.hbase.master.CachedClusterId
Caches the cluster ID of the cluster.
org.apache.hadoop.hbase.mob.CachedMobFile
Cached mob file.
org.apache.hadoop.hbase.CacheEvictionStats
 
org.apache.hadoop.hbase.CacheEvictionStatsAggregator
Used to merge CacheEvictionStats.
org.apache.hadoop.hbase.CacheEvictionStatsBuilder
 
org.apache.hadoop.hbase.io.hfile.CacheStats
Class that implements cache metrics.
org.apache.hadoop.hbase.ipc.CallCancelledException
Client side call cancelled.
org.apache.hadoop.hbase.CallDroppedException
Returned to the clients when their request was discarded due to server being overloaded.
org.apache.hadoop.hbase.ipc.CallerDisconnectedException
Exception indicating that the remote host making this IPC lost its IPC connection.
org.apache.hadoop.hbase.thrift.CallQueue
A BlockingQueue reports waiting time in queue and queue length to ThriftMetrics.
org.apache.hadoop.hbase.thrift.CallQueue.Call
 
org.apache.hadoop.hbase.ipc.CallQueueInfo
 
org.apache.hadoop.hbase.CallQueueTooBigException
Returned to clients when their request was dropped because the call queue was too big to accept a new call.
org.apache.hadoop.hbase.ipc.CallRunner
The request processing logic, which is usually executed in thread pools provided by an RpcScheduler.
org.apache.hadoop.hbase.ipc.CallTimeoutException
Client-side call timeout
org.apache.hadoop.hbase.util.CancelableProgressable
Similar interface as Progressable but returns a boolean to support canceling the operation.
org.apache.hadoop.hbase.io.compress.CanReinit
This is a marker interface that indicates if a compressor or decompressor type can support reinitialization via reinit(Configuration conf).
org.apache.hadoop.hbase.CatalogFamilyFormat
Helper class for generating/parsing "info" family cells in meta table.
org.apache.hadoop.hbase.CatalogReplicaMode
There are two modes with catalog replica support.
org.apache.hadoop.hbase.Cell
The unit of storage in HBase consisting of the following fields:
org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
Represents a single text cell of the terminal.
org.apache.hadoop.hbase.Cell.Type
The valid types for user to build the cell.
org.apache.hadoop.hbase.regionserver.CellArrayImmutableSegment
CellArrayImmutableSegment extends the API supported by a Segment, and ImmutableSegment.
org.apache.hadoop.hbase.regionserver.CellArrayMap<T extends org.apache.hadoop.hbase.Cell>
CellArrayMap is a simple array of Cells and cannot be allocated off-heap.
org.apache.hadoop.hbase.CellBuilder
Use CellBuilderFactory to get CellBuilder instance.
org.apache.hadoop.hbase.CellBuilderFactory
Create a CellBuilder instance.
org.apache.hadoop.hbase.CellBuilderType
Used by CellBuilderFactory and ExtendedCellBuilderFactory.
org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
CellChunkImmutableSegment extends the API supported by a Segment, and ImmutableSegment.
org.apache.hadoop.hbase.regionserver.CellChunkMap<T extends org.apache.hadoop.hbase.Cell>
CellChunkMap is an array of serialized representations of Cell (pointing to Chunks with full Cell data) and can be allocated both off-heap and on-heap.
org.apache.hadoop.hbase.codec.CellCodec
Basic Cell codec that just writes out all the individual elements of a Cell.
org.apache.hadoop.hbase.codec.CellCodecWithTags
Basic Cell codec that just writes out all the individual elements of a Cell including the tags.
Comparator for comparing cells and has some specialized methods that allows comparing individual cell components like row, family, qualifier and timestamp
org.apache.hadoop.hbase.CellComparatorImpl
Compare two HBase cells.
org.apache.hadoop.hbase.mapreduce.CellCounter
A job with a a map and reduce phase to count cells in a table.
org.apache.hadoop.hbase.mapreduce.CellCreator
Facade to create Cells for HFileOutputFormat.
org.apache.hadoop.hbase.regionserver.CellFlatMap<T extends org.apache.hadoop.hbase.Cell>
CellFlatMap stores a constant number of elements and is immutable after creation stage.
org.apache.hadoop.hbase.util.CellHashKey
Extracts the byte for the hash calculation from the given cell
org.apache.hadoop.hbase.io.CellOutputStream
Accepts a stream of Cells.
org.apache.hadoop.hbase.CellScannable
Implementer can return a CellScanner over its Cell content.
org.apache.hadoop.hbase.CellScanner
An interface for iterating through a sequence of cells.
org.apache.hadoop.hbase.ipc.CellScannerButNoCodecException
Thrown if a cellscanner but no codec to encode it with.
org.apache.hadoop.hbase.mapreduce.CellSerialization
 
org.apache.hadoop.hbase.mapreduce.CellSerialization.CellDeserializer
 
org.apache.hadoop.hbase.mapreduce.CellSerialization.CellSerializer
 
org.apache.hadoop.hbase.regionserver.CellSet<T extends org.apache.hadoop.hbase.Cell>
A Set of Cells, where an add will overwrite the entry if already exists in the set.
org.apache.hadoop.hbase.regionserver.CellSink
A sink of cells that allows appending cells to the Writers that implement it.
org.apache.hadoop.hbase.mapreduce.CellSortReducer
Emits sorted Cells.
org.apache.hadoop.hbase.CellUtil
Utility methods helpful for slinging Cell instances.
org.apache.hadoop.hbase.replication.ChainWALEmptyEntryFilter
A ChainWALEntryFilter for providing more flexible options
org.apache.hadoop.hbase.replication.ChainWALEntryFilter
A WALEntryFilter which contains multiple filters and applies them in chain order
org.apache.hadoop.hbase.regionserver.ChangedReadersObserver
If set of MapFile.Readers in Store change, implementors are notified.
org.apache.hadoop.hbase.chaos.ChaosAgent
An agent for executing destructive actions for ChaosMonkey.
org.apache.hadoop.hbase.chaos.ChaosAgent.LocalShell
Executes Command locally.
org.apache.hadoop.hbase.chaos.ChaosConstants
ChaosConstant holds a bunch of Choas-related Constants
org.apache.hadoop.hbase.chaos.ChaosService
Class used to start/stop Chaos related services (currently chaosagent)
org.apache.hadoop.hbase.chaos.ChaosUtils
ChaosUtils holds a bunch of useful functions like getting hostname and getting ZooKeeper quorum.
Used to perform CheckAndMutate operations.
A builder class for building a CheckAndMutate object.
org.apache.hadoop.hbase.client.CheckAndMutateResult
Represents a result of a CheckAndMutate operation
org.apache.hadoop.hbase.util.ChecksumType
Checksum types.
org.apache.hadoop.hbase.io.hfile.ChecksumUtil
Utility methods to compute and validate checksums.
org.apache.hadoop.hbase.ChoreService
ChoreService is a service that can be used to schedule instances of ScheduledChore to run periodically while sharing threads.
org.apache.hadoop.hbase.regionserver.Chunk
A chunk of memory out of which allocations are sliced.
org.apache.hadoop.hbase.regionserver.ChunkCreator
Does the management of memstoreLAB chunk creations.
org.apache.hadoop.hbase.regionserver.ChunkCreator.ChunkType
Types of chunks, based on their sizes
org.apache.hadoop.hbase.io.crypto.Cipher
A common interface for a cryptographic algorithm.
org.apache.hadoop.hbase.io.crypto.CipherProvider
An CipherProvider contributes support for various cryptographic Ciphers.
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.http.ClickjackingPreventionFilter
 
org.apache.hadoop.hbase.rest.client.Client
A wrapper around HttpClient which provides some useful function and semantics for interacting with the REST gateway.
org.apache.hadoop.hbase.rest.client.Client.ClientTrustStoreInitializationException
 
org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
Configurable policy for the amount of time a client should wait for a new request to the server when given the server load statistics.
org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory
 
org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory.NoBackoffPolicy
Default backoff policy that doesn't create any backoff for the client, regardless of load
org.apache.hadoop.hbase.client.ClientCoprocessorRpcController
Client side rpc controller for coprocessor implementation.
org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil
 
org.apache.hadoop.hbase.client.ClientInternalHelper
A helper class used to access the package private field in o.a.h.h.client package.
org.apache.hadoop.hbase.ClientMetaTableAccessor
The (asynchronous) meta table accessor used at client side.
org.apache.hadoop.hbase.ClientMetaTableAccessor.CloseableVisitor
Implementations 'visit' a catalog table row but with close() at the end.
org.apache.hadoop.hbase.ClientMetaTableAccessor.QueryType
 
org.apache.hadoop.hbase.ClientMetaTableAccessor.Visitor
Implementations 'visit' a catalog table row.
org.apache.hadoop.hbase.hbtop.mode.ClientModeStrategy
Implementation for ModeStrategy for client Mode.
org.apache.hadoop.hbase.client.ClientSideRegionScanner
A client scanner for a region opened for read-only on the client side.
org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
Class to help with dealing with a snapshot description on the client side.
org.apache.hadoop.hbase.client.ClientUtil
 
org.apache.hadoop.hbase.util.ClientUtils
Common Utility class for clients
org.apache.hadoop.hbase.ClockOutOfSyncException
This exception is thrown by the master when a region server clock skew is too high.
org.apache.hadoop.hbase.rest.client.Cluster
A list of 'host:port' addresses of HTTP servers operating as a single entity, for example multiple redundant web service gateways.
org.apache.hadoop.hbase.client.ClusterConnectionFactory
The factory for creating AsyncClusterConnection.
org.apache.hadoop.hbase.ClusterId
The identifier for this cluster.
org.apache.hadoop.hbase.replication.ClusterMarkingEntryFilter
Filters out entries with our peerClusterId (i.e.
org.apache.hadoop.hbase.ClusterMetrics
Metrics information on the HBase cluster.
org.apache.hadoop.hbase.ClusterMetrics.Option
Kinds of ClusterMetrics
org.apache.hadoop.hbase.ClusterMetricsBuilder
 
org.apache.hadoop.hbase.master.ClusterSchema
View and edit the current cluster schema.
org.apache.hadoop.hbase.master.ClusterSchemaService
Mixes in ClusterSchema and Service
org.apache.hadoop.hbase.master.ClusterStatusPublisher
Class to publish the cluster status to the client.
org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
 
org.apache.hadoop.hbase.master.ClusterStatusPublisher.Publisher
 
org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
Tracker on cluster settings up in zookeeper.
org.apache.hadoop.hbase.codec.Codec
Encoder/Decoder for Cell.
org.apache.hadoop.hbase.codec.Codec.Decoder
Implementations should implicitly clean up any resources allocated when the Decoder/CellScanner runs off the end of the cell block.
org.apache.hadoop.hbase.codec.Codec.Encoder
Call flush when done.
org.apache.hadoop.hbase.codec.CodecException
Thrown when problems in the codec whether setup or context.
org.apache.hadoop.hbase.util.CollectionBackedScanner
Utility scanner that wraps a sortable collection and serves as a KeyValueScanner.
org.apache.hadoop.hbase.hbtop.terminal.Color
Terminal color definitions.
org.apache.hadoop.hbase.filter.ColumnCountGetFilter
Simple filter that returns first N columns on row only.
org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
An ColumnFamilyDescriptor contains information about a column family such as the number of versions, compression settings, etc.
org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder
 
org.apache.hadoop.hbase.coprocessor.ColumnInterpreter<T,S,P extends org.apache.hbase.thirdparty.com.google.protobuf.Message,Q extends org.apache.hbase.thirdparty.com.google.protobuf.Message,R extends org.apache.hbase.thirdparty.com.google.protobuf.Message>
Defines how value for specific column is interpreted and provides utility methods like compare, add, multiply etc for them.
org.apache.hadoop.hbase.filter.ColumnPaginationFilter
A filter, based on the ColumnCountGetFilter, takes two arguments: limit and offset.
org.apache.hadoop.hbase.filter.ColumnPrefixFilter
This filter is used for selecting only those keys with columns that matches a particular prefix.
org.apache.hadoop.hbase.filter.ColumnRangeFilter
This filter is used for selecting only those keys with columns that are between minColumn to maxColumn.
org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
Implementing classes of this interface will be used for the tracking and enforcement of columns and numbers of versions and timeToLive during the course of a Get or Scan operation.
org.apache.hadoop.hbase.filter.ColumnValueFilter
Different from SingleColumnValueFilter which returns an entire row when specified condition is matched, ColumnValueFilter return the matched cell only.
org.apache.hadoop.hbase.regionserver.wal.CombinedAsyncWriter
An WALProvider.AsyncWriter wrapper which writes data to a set of WALProvider.AsyncWriter instances.
org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
CombinedBlockCache is an abstraction layer that combines FirstLevelBlockCache and BucketCache.
org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
 
org.apache.hadoop.hbase.regionserver.wal.CombinedWriter
 
org.apache.hadoop.hbase.regionserver.wal.CombinedWriterBase<T extends org.apache.hadoop.hbase.wal.WALProvider.WriterBase>
Base class for combined wal writer implementations.
org.apache.hadoop.hbase.hbtop.screen.help.CommandDescription
Represents a description of a command that we can execute in the top screen.
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.io.crypto.aes.CommonsCryptoAES
 
org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESDecryptor
 
org.apache.hadoop.hbase.io.crypto.aes.CommonsCryptoAESEncryptor
 
org.apache.hadoop.hbase.regionserver.CompactedHFilesDischargeHandler
Event handler that handles the removal and archival of the compacted hfiles
org.apache.hadoop.hbase.regionserver.CompactedHFilesDischarger
A chore service that periodically cleans up the compacted files when there are no active readers using those compacted files and also helps in clearing the block cache of these compacted file entries.
org.apache.hadoop.hbase.regionserver.CompactingMemStore
A memstore implementation which supports in-memory compaction.
org.apache.hadoop.hbase.regionserver.CompactingMemStore.IndexType
Types of indexes (part of immutable segments) to be used after flattening, compaction, or merge are applied.
org.apache.hadoop.hbase.regionserver.CompactionPipeline
The compaction pipeline of a CompactingMemStore, is a FIFO queue of segments.
org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
Query matcher for compaction.
org.apache.hadoop.hbase.client.CompactionState
POJO representing the compaction state
org.apache.hadoop.hbase.regionserver.throttle.CompactionThroughputControllerFactory
 
org.apache.hadoop.hbase.regionserver.CompactionTool
 
org.apache.hadoop.hbase.regionserver.CompactSplit
Compact region on request and then run split if appropriate
org.apache.hadoop.hbase.regionserver.CompactSplit.CompactionCompleteTracker
 
org.apache.hadoop.hbase.client.CompactType
Currently, there are only two compact types: NORMAL means do store files compaction; MOB means do mob files compaction.
org.apache.hadoop.hbase.filter.CompareFilter
This is a generic filter to be used to filter by comparison.
org.apache.hadoop.hbase.CompareOperator
Generic set of comparison operators.
org.apache.hadoop.hbase.CompatibilityFactory
Class that will create many instances of classes provided by the hbase-hadoop{1|2}-compat jars.
org.apache.hadoop.hbase.CompatibilitySingletonFactory
Factory for classes supplied by hadoop compatibility modules.
org.apache.hadoop.hbase.CompatibilitySingletonFactory.SingletonStorage
 
org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
The CompositeImmutableSegments is created as a collection of ImmutableSegments and supports the interface of a single ImmutableSegments.
org.apache.hadoop.hbase.io.hfile.CompoundBloomFilter
A Bloom filter implementation built on top of BloomFilterChunk, encapsulating a set of fixed-size Bloom filters written out at the time of HFile generation into the data block stream, and loaded on demand at query time.
org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterBase
 
org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
Adds methods required for writing a compound Bloom filter to the data section of an HFile to the CompoundBloomFilter class.
org.apache.hadoop.hbase.CompoundConfiguration
Do a shallow merge of multiple KV configuration pools.
org.apache.hadoop.hbase.io.compress.Compression
Compression related stuff.
org.apache.hadoop.hbase.io.compress.Compression.Algorithm
Compression algorithms.
org.apache.hadoop.hbase.regionserver.wal.CompressionContext
Context that holds the various dictionaries for compression in WAL.
org.apache.hadoop.hbase.regionserver.wal.CompressionContext.DictionaryIndex
 
org.apache.hadoop.hbase.util.CompressionTest
Compression validation test.
org.apache.hadoop.hbase.io.compress.CompressionUtil
 
org.apache.hadoop.hbase.regionserver.wal.Compressor
A set of static functions for running our custom WAL compression/decompression.
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.ConcurrentTableModificationException
Thrown when a table has been modified concurrently
org.apache.hadoop.hbase.conf.ConfigurationManager
Maintains the set of all the classes which would like to get notified when the Configuration is reloaded from the disk in the Online Configuration Change mechanism, which lets you update certain configuration properties on-the-fly, without having to restart the cluster.
org.apache.hadoop.hbase.conf.ConfigurationObserver
Every class that wants to observe changes in Configuration properties, must implement interface (and also, register itself with the ConfigurationManager.
org.apache.hadoop.hbase.util.ConfigurationUtil
Utilities for storing more complex collection types in Configuration instances.
org.apache.hadoop.hbase.http.conf.ConfServlet
A servlet to print out the running configuration data.
org.apache.hadoop.hbase.http.conf.ConfServlet.BadFormatException
 
org.apache.hadoop.hbase.client.Connection
A cluster connection encapsulating lower level individual connections to actual servers and a connection to zookeeper.
org.apache.hadoop.hbase.util.ConnectionCache
A utility to store user specific HConnections in memory.
org.apache.hadoop.hbase.exceptions.ConnectionClosedException
Thrown when the connection is closed
org.apache.hadoop.hbase.exceptions.ConnectionClosingException
Thrown when the client believes that we are trying to communicate to has been repeatedly unresponsive for a while.
org.apache.hadoop.hbase.client.ConnectionConfiguration
Configuration parameters for the connection.
org.apache.hadoop.hbase.client.ConnectionFactory
A non-instantiable class that manages creation of Connections.
org.apache.hadoop.hbase.client.ConnectionRegistry
Registry for meta information needed for connection setup to a HBase cluster.
org.apache.hadoop.hbase.client.ConnectionRegistryEndpoint
Define the necessary method for carrying ClientMetaService.
org.apache.hadoop.hbase.client.ConnectionRegistryFactory
The entry point for creating a ConnectionRegistry.
org.apache.hadoop.hbase.client.ConnectionRegistryURIFactory
For creating different ConnectionRegistry implementation.
org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder
Construct Span instances originating from the client side of a connection.
org.apache.hadoop.hbase.client.ConnectionUtils
Utility used by client connections.
org.apache.hadoop.hbase.client.Consistency
Consistency defines the expected consistency level for an operation.
org.apache.hadoop.hbase.rest.Constants
Common constants for org.apache.hadoop.hbase.rest
org.apache.hadoop.hbase.thrift.Constants
Thrift related constants
org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
A RegionSplitPolicy implementation which splits a region as soon as any of its store files exceeds a maximum configurable size.
org.apache.hadoop.hbase.io.crypto.Context
Crypto context.
org.apache.hadoop.hbase.CoordinatedStateManager
Implementations of this interface will keep and return to clients implementations of classes providing API to execute coordinated operations.
org.apache.hadoop.hbase.Coprocessor
Base interface for the 4 coprocessors - MasterCoprocessor, RegionCoprocessor, RegionServerCoprocessor, and WALCoprocessor.
org.apache.hadoop.hbase.Coprocessor.State
Lifecycle state of a given coprocessor instance.
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.client.CoprocessorDescriptor
CoprocessorDescriptor contains the details about how to build a coprocessor.
org.apache.hadoop.hbase.client.CoprocessorDescriptorBuilder
Used to build the CoprocessorDescriptor
org.apache.hadoop.hbase.CoprocessorEnvironment<C extends org.apache.hadoop.hbase.Coprocessor>
Coprocessor environment state.
org.apache.hadoop.hbase.coprocessor.CoprocessorException
Thrown if a coprocessor encounters any exception.
org.apache.hadoop.hbase.coprocessor.CoprocessorHost<C extends org.apache.hadoop.hbase.Coprocessor,E extends org.apache.hadoop.hbase.CoprocessorEnvironment<C>>
Provides the common setup framework and runtime services for coprocessor invocation from HBase services.
org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverGetter<C,O>
Implementations defined function to get an observer of type O from a coprocessor of type C.
org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethod
 
org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods
 
org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
Deprecated.
Please stop using this class again, as it is too low level, which is part of the rpc framework for HBase.
org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils
Utilities for handling coprocessor rpc service calls.
org.apache.hadoop.hbase.ipc.CoprocessorRpcUtils.BlockingRpcCallback<R>
Simple RpcCallback implementation providing a Future-like CoprocessorRpcUtils.BlockingRpcCallback.get() method, which will block util the instance's CoprocessorRpcUtils.BlockingRpcCallback.run(Object) method has been called.
org.apache.hadoop.hbase.coprocessor.CoprocessorService
Deprecated.
Since 2.0.
org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
 
org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation
 
org.apache.hadoop.hbase.tool.coprocessor.CoprocessorViolation.Severity
 
org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
Just copy data, do not do any kind of compression.
org.apache.hadoop.hbase.types.CopyOnWriteArrayMap<K,V>
A Map that keeps a sorted array in order to provide the concurrent map interface.
org.apache.hadoop.hbase.replication.CopyReplicationPeers
A tool for copying replication peer data across different replication peer storages.
org.apache.hadoop.hbase.mapreduce.CopyTable
Tool used to copy a table to another one which can be on a different setup.
org.apache.hadoop.hbase.coprocessor.CoreCoprocessor
Marker annotation that denotes Coprocessors that are core to HBase.
org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
Exception thrown when the found snapshot info from the filesystem is not valid.
org.apache.hadoop.hbase.io.hfile.CorruptHFileException
This exception is thrown when attempts to read an HFile fail due to corruption or truncation issues.
org.apache.hadoop.hbase.metrics.Counter
A mutable number optimized for high concurrency counting.
org.apache.hadoop.hbase.snapshot.CreateSnapshot
This is a command line class that will snapshot a given table.
org.apache.hadoop.hbase.regionserver.CreateStoreFileWriterParams
 
org.apache.hadoop.hbase.io.crypto.aes.CryptoAES
AES encryption and decryption.
org.apache.hadoop.hbase.io.crypto.CryptoCipherProvider
The default cipher provider.
org.apache.hadoop.hbase.regionserver.CSLMImmutableSegment
CSLMImmutableSegment is an abstract class that extends the API supported by a Segment, and ImmutableSegment.
org.apache.hadoop.hbase.tool.coprocessor.CurrentCoprocessorMethods
 
org.apache.hadoop.hbase.client.Cursor
Scan cursor to tell client where server is scanning Scan.setNeedCursorResult(boolean) Result.isCursor() Result.getCursor()
org.apache.hadoop.hbase.hbtop.terminal.CursorPosition
A 2-d position in 'terminal space'.
org.apache.hadoop.hbase.regionserver.CustomizedScanInfoBuilder
Helper class for CP hooks to change max versions and TTL.
org.apache.hadoop.hbase.regionserver.wal.DamagedWALException
Thrown when a failed append or sync on a WAL.
org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
Encoding of KeyValue.
org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
An interface which enable to seek while underlying data is encoded.
org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
Provide access to all data block encoding algorithms.
org.apache.hadoop.hbase.types.DataType<T>
DataType is the base class for all HBase data types.
org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriter
class for cell sink that separates the provided cells into multiple files for date tiered compaction.
org.apache.hadoop.hbase.regionserver.DateTieredStoreEngine
HBASE-15400 This store engine allows us to store data in date tiered layout with exponential sizing so that the more recent data has more granularity.
org.apache.hadoop.hbase.master.DeadServer
Class to hold dead servers list and utility querying dead server list.
org.apache.hadoop.hbase.io.DeallocateRewriteByteBuffAllocator
A ByteBuffAllocator that rewrite the bytebuffers right after released.
org.apache.hadoop.hbase.ipc.DecommissionedHostRejectedException
 
org.apache.hadoop.hbase.io.crypto.Decryptor
Decryptors apply a cipher to an InputStream to recover plaintext.
org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
The default cipher provider.
org.apache.hadoop.hbase.util.DefaultEnvironmentEdge
Default implementation of an environment edge.
org.apache.hadoop.hbase.regionserver.DefaultMemStore
The MemStore holds in-memory modifications to the Store.
org.apache.hadoop.hbase.mob.DefaultMobStoreCompactor
Compact passed set of files in the mob-enabled column family.
org.apache.hadoop.hbase.mob.DefaultMobStoreFlusher
An implementation of the StoreFlusher.
org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
Default StoreEngine creates the default compactor, policy, and store file manager, or their derivatives.
org.apache.hadoop.hbase.regionserver.DefaultStoreFlusher
Default implementation of StoreFlusher.
org.apache.hadoop.hbase.quotas.policies.DefaultViolationPolicyEnforcement
The default implementation for SpaceViolationPolicyEnforcement.
org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
This implementation creates tags by expanding expression using label ordinal.
org.apache.hadoop.hbase.ipc.DelegatingHBaseRpcController
Simple delegating controller for use with the RpcControllerFactory to help override standard behavior of a HBaseRpcController.
org.apache.hadoop.hbase.io.DelegatingInputStream
An input stream that delegates all operations to another input stream.
org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
Users of the hbase.region.server.rpc.scheduler.factory.class customization config can return an implementation which extends this class in order to minimize impact of breaking interface changes.
org.apache.hadoop.hbase.client.Delete
Used to perform Delete operations on a single row.
org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker
This interface is used for the tracking and enforcement of Deletes during the course of a Get or Scan operation.
org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
Returns codes for delete result.
org.apache.hadoop.hbase.zookeeper.DeletionListener
A ZooKeeper watcher meant to detect deletions of ZNodes.
org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
Deprecated.
since 3.0.0 and will be removed in 4.0.0.
org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitRestriction
A RegionSplitRestriction implementation that groups rows by a prefix of the row-key with a delimiter.
org.apache.hadoop.hbase.thrift.DemoClient
See the instructions under hbase-examples/README.txt
org.apache.hadoop.hbase.filter.DependentColumnFilter
A filter for adding inter-column timestamp matching Only cells with a correspondingly timestamped entry in the target column will be retained Not compatible with Scan.setBatch as operations need full rows for correct filtering
org.apache.hadoop.hbase.exceptions.DeserializationException
Failed deserialization.
org.apache.hadoop.hbase.io.util.Dictionary
Dictionary interface Dictionary indexes should be either bytes or shorts, only positive.
org.apache.hadoop.hbase.io.compress.DictionaryCache
A utility class for managing compressor/decompressor dictionary loading and caching of load results.
org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
Compress using: - store size of common prefix - save column family once, it is same within HFile - use integer compression for key, value and prefix (7-bit encoding) - use bits to avoid duplication key length, value length and type if it same as previous - store in 3 bits length of timestamp field - allow diff in timestamp instead of actual value Format: - 1 byte: flag - 1-5 bytes: key length (only if FLAG_SAME_KEY_LENGTH is not set in flag) - 1-5 bytes: value length (only if FLAG_SAME_VALUE_LENGTH is not set in flag) - 1-5 bytes: prefix length - ...
org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffCompressionState
 
org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffSeekerState
 
org.apache.hadoop.hbase.util.DirectMemoryUtils
Utilities for interacting with and monitoring DirectByteBuffer allocations.
org.apache.hadoop.hbase.regionserver.DisabledRegionSplitPolicy
A RegionSplitPolicy that disables region splits.
org.apache.hadoop.hbase.quotas.policies.DisableTableViolationPolicyEnforcement
A SpaceViolationPolicyEnforcement which disables the table.
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.DoNotRetryIOException
Subclass if exception is not meant to be retried: e.g.
org.apache.hadoop.hbase.client.DoNotRetryRegionException
Similar to RegionException, but disables retries.
org.apache.hadoop.hbase.master.DrainingServerTracker
Tracks the list of draining region servers via ZK.
org.apache.hadoop.hbase.hbtop.mode.DrillDownInfo
Information about drilling down.
org.apache.hadoop.hbase.mapred.Driver
Driver for hbase mapreduce jobs.
org.apache.hadoop.hbase.mapreduce.Driver
Driver for hbase mapreduce jobs.
org.apache.hadoop.hbase.regionserver.querymatcher.DropDeletesCompactionScanQueryMatcher
A query matcher for compaction which can drop delete markers.
org.apache.hadoop.hbase.DroppedSnapshotException
Thrown during flush if the possibility snapshot content was not properly persisted into store files.
org.apache.hadoop.hdfs.DummyDFSOutputStream
A dummy DFSOutputStream which is mainly used for lease renewal.
org.apache.hadoop.hbase.regionserver.DumpRegionServerMetrics
Utility for doing JSON and MBeans.
org.apache.hadoop.hbase.client.Durability
Enum describing the durability guarantees for tables and Mutations Note that the items must be sorted in order of increasing durability
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.regionserver.EagerMemStoreCompactionStrategy
 
org.apache.hadoop.hbase.ipc.EmptyServiceNameException
 
org.apache.hadoop.hbase.zookeeper.EmptyWatcher
An empty ZooKeeper watcher
org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
Encapsulates a data block compressed using a particular encoding algorithm.
org.apache.hadoop.hbase.io.encoding.EncoderBufferTooSmallException
Internal error which indicates a bug in a data block encoding algorithm.
org.apache.hadoop.hbase.io.encoding.EncodingState
Keeps track of the encoding state.
org.apache.hadoop.hbase.io.crypto.Encryption
A facade for encryption algorithms and related support.
org.apache.hadoop.hbase.io.crypto.Encryption.Context
Crypto context
org.apache.hadoop.hbase.util.EncryptionTest
 
org.apache.hadoop.hbase.security.EncryptionUtil
Some static utility methods for encryption uses in hbase-client.
org.apache.hadoop.hbase.io.crypto.Encryptor
Encryptors apply a cipher to an OutputStream to produce ciphertext.
org.apache.hadoop.hbase.coprocessor.EndpointObserver
Coprocessors implement this interface to observe and mediate endpoint invocations on a region.
org.apache.hadoop.hbase.client.locking.EntityLock
Lock for HBase Entity either a Table, a Namespace, or Regions.
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.hbtop.terminal.impl.EscapeSequences
Utility class for escape sequences.
org.apache.hadoop.hbase.quotas.ExceedOperationQuota
 
org.apache.hadoop.hbase.metrics.ExceptionTrackingSource
Common interface for metrics source implementations which need to track individual exception types thrown or received.
org.apache.hadoop.hbase.metrics.ExceptionTrackingSourceImpl
Common base implementation for metrics sources which need to track exceptions thrown or received.
org.apache.hadoop.hbase.util.ExceptionUtil
This class handles the different interruption classes.
org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager
The class to manage the excluded datanodes of the WALs on the regionserver.
org.apache.hadoop.hbase.io.hfile.ExclusiveMemHFileBlock
The ByteBuffAllocator won't allocate pooled heap ByteBuff now; at the same time, if allocate an off-heap ByteBuff from allocator, then it must be a pooled one.
org.apache.hadoop.hbase.ExecutorStatusChore
The Class ExecutorStatusChore for collect Executor status info periodically and report to metrics system
org.apache.hadoop.hbase.rest.ExistsResource
 
org.apache.hadoop.hbase.mob.ExpiredMobFileCleaner
The cleaner to delete the expired MOB files.
org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
This class is used for the tracking and enforcement of columns and numbers of versions during the course of a Get or Scan operation, when explicit column qualifiers have been asked for in the query.
org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
Simple exponential backoff policy on for the client that uses a percent^4 times the max backoff to generate the backoff time.
org.apache.hadoop.hbase.util.ExponentialMovingAverage<T>
EMA is similar to WeightedMovingAverage in weighted, but the weighting factor decrease exponentially.
org.apache.hadoop.hbase.mapreduce.Export
Export an HBase table.
org.apache.hadoop.hbase.client.example.ExportEndpointExample
A simple example on how to use Export.
org.apache.hadoop.hbase.snapshot.ExportSnapshot
Export the specified snapshot to a given FileSystem.
org.apache.hadoop.hbase.snapshot.ExportSnapshot.ChecksumComparison
Indicates the checksum comparison result.
org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
 
org.apache.hadoop.hbase.snapshot.ExportSnapshotException
Thrown when a snapshot could not be exported due to an error during the operation.
org.apache.hadoop.hbase.mapreduce.ExportUtils
Some helper methods are used by Export and org.apache.hadoop.hbase.coprocessor.Export (in hbase-endpooint).
org.apache.hadoop.hbase.ExtendedCell
Extension to Cell with server side required functions.
org.apache.hadoop.hbase.ExtendedCellBuilder
For internal purpose.
org.apache.hadoop.hbase.ExtendedCellBuilderFactory
 
org.apache.hadoop.hbase.ExtendedCellBuilderImpl
 
org.apache.hadoop.hbase.ExtendedCellScannable
We use this class in HBase internally for getting ExtendedCell directly without casting.
org.apache.hadoop.hbase.ExtendedCellScanner
We use this class in HBase internally for getting ExtendedCell directly without casting.
org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization
Similar to CellSerialization, but includes the sequenceId from an ExtendedCell.
org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellDeserializer
 
org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellSerializer
 
org.apache.hadoop.hbase.backup.FailedArchiveException
Exception indicating that some files in the requested set could not be archived.
org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
Thrown when we fail close of the write-ahead-log file.
org.apache.hadoop.hbase.exceptions.FailedSanityCheckException
Exception thrown if a mutation fails sanity checks.
org.apache.hadoop.hbase.ipc.FailedServerException
Indicates that we're trying to connect to a already known as dead server.
org.apache.hadoop.hbase.ipc.FailedServers
A class to manage a list of servers that failed recently.
org.apache.hadoop.hbase.regionserver.wal.FailedSyncBeforeLogCloseException
Thrown when we fail close of the write-ahead-log file.
org.apache.hadoop.hbase.ipc.FallbackDisallowedException
Indicate that the rpc server tells client to fallback to simple auth but client is disabled to do so.
org.apache.hadoop.hbase.filter.FamilyFilter
This filter is used to filter based on the column family.
org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
An asynchronous HDFS output stream implementation which fans out data to datanode and only supports writing file with only one block.
org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
Helper class for implementing FanOutOneBlockAsyncDFSOutput.
org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper.NameNodeException
Exception other than RemoteException thrown when calling create on namenode
org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper
Helper class for adding sasl support for FanOutOneBlockAsyncDFSOutput.
org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
Encoder similar to DiffKeyDeltaEncoder but supposedly faster.
org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder.FastDiffSeekerState
 
org.apache.hadoop.hbase.ipc.FastPathBalancedQueueRpcExecutor
Balanced queue executor with a fastpath.
org.apache.hadoop.hbase.ipc.FastPathRpcHandler
 
org.apache.hadoop.hbase.ipc.FastPathRWQueueRpcExecutor
RPC Executor that extends RWQueueRpcExecutor with fast-path feature, used in FastPathBalancedQueueRpcExecutor.
org.apache.hadoop.hbase.ipc.FatalConnectionException
Thrown when server finds fatal issue w/ connection setup: e.g.
org.apache.hadoop.hbase.favored.FavoredNodeAssignmentHelper
Helper class for FavoredNodeLoadBalancer that has all the intelligence for racks, meta scans, etc.
org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
An implementation of the LoadBalancer that assigns favored nodes for each region.
org.apache.hadoop.hbase.regionserver.FavoredNodesForRegion
Abstraction that allows different modules in RegionServer to update/get the favored nodes information for regions.
org.apache.hadoop.hbase.favored.FavoredNodesManager
FavoredNodesManager is responsible for maintaining favored nodes info in internal cache and META table.
org.apache.hadoop.hbase.favored.FavoredNodesPlan
This class contains the mapping information between each region name and its favored region server list.
org.apache.hadoop.hbase.favored.FavoredNodesPlan.Position
 
org.apache.hadoop.hbase.favored.FavoredNodesPromoter
 
org.apache.hadoop.hbase.hbtop.field.Field
Represents fields that are displayed in the top screen.
org.apache.hadoop.hbase.hbtop.field.FieldInfo
Information about a field.
org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
The presentation logic for the field screen.
org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter.ResultListener
 
org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenView
The screen where we can change the displayed fields, the sort key and the order of the fields.
org.apache.hadoop.hbase.hbtop.field.FieldValue
Represents a value of a field.
org.apache.hadoop.hbase.hbtop.field.FieldValueType
Represents the type of a FieldValue.
org.apache.hadoop.hbase.ipc.FifoRpcScheduler
A very simple RpcScheduler} that serves incoming requests in order.
org.apache.hadoop.hbase.regionserver.FifoRpcSchedulerFactory
Factory to use when you want to use the FifoRpcScheduler
org.apache.hadoop.hbase.quotas.FileArchiverNotifier
Interface allowing various implementations of tracking files that have recently been archived to allow for the Master to notice changes to snapshot sizes for space quotas.
org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactory
Factory class to create FileArchiverNotifier instances.
org.apache.hadoop.hbase.quotas.FileArchiverNotifierFactoryImpl
A factory for getting instances of FileArchiverNotifier.
org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
Tracks file archiving and updates the hbase quota table.
org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl.QuotaSnapshotSizeSerializationException
An Exception thrown when SnapshotSize updates to hbase:quota fail to be written.
org.apache.hadoop.hbase.io.FileChangeWatcher
Instances of this class can be used to watch a directory for file changes.
org.apache.hadoop.hbase.io.FileChangeWatcher.State
 
org.apache.hadoop.hbase.io.FileLink
The FileLink is a sort of hardlink, that allows access to a file given a set of locations.
org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
FileLink InputStream that handles the switch between the original path and the alternative locations, when the file is moved.
org.apache.hadoop.hbase.util.FileStatusFilter
 
org.apache.hadoop.hbase.quotas.FileSystemUtilizationChore
A chore which computes the size of each HRegion on the FileSystem hosted by the given HRegionServer.
org.apache.hadoop.hbase.util.FileSystemVersionException
Thrown when the file system needs to be upgraded
org.apache.hadoop.hbase.filter.Filter
Interface for row and column filters directly applied within the regionserver.
org.apache.hadoop.hbase.filter.Filter.ReturnCode
Return codes for filterValue().
org.apache.hadoop.hbase.filter.FilterAllFilter
 
org.apache.hadoop.hbase.filter.FilterBase
Abstract base class to help you implement new Filters.
org.apache.hadoop.hbase.http.FilterContainer
A container interface to add javax.servlet.Filter.
org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenPresenter
The presentation logic for the filter display mode.
org.apache.hadoop.hbase.hbtop.screen.top.FilterDisplayModeScreenView
The filter display mode in the top screen.
org.apache.hadoop.hbase.http.FilterInitializer
Initialize a javax.servlet.Filter.
org.apache.hadoop.hbase.filter.FilterList
Implementation of Filter that represents an ordered List of Filters which will be evaluated with a specified boolean operator FilterList.Operator.MUST_PASS_ALL (AND) or FilterList.Operator.MUST_PASS_ONE (OR).
org.apache.hadoop.hbase.filter.FilterList.Operator
set operator
org.apache.hadoop.hbase.filter.FilterListBase
Base class for FilterList.
org.apache.hadoop.hbase.filter.FilterListWithAND
FilterListWithAND represents an ordered list of filters which will be evaluated with an AND operator.
org.apache.hadoop.hbase.filter.FilterListWithOR
FilterListWithOR represents an ordered list of filters which will be evaluated with an OR operator.
org.apache.hadoop.hbase.filter.FilterWrapper
This is a Filter wrapper class which is used in the server side.
org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
 
org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
A filter that will only return the first KV from each row.
org.apache.hadoop.hbase.io.hfile.FirstLevelBlockCache
In-memory BlockCache that may be backed by secondary layer(s).
org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
The HFile has a fixed trailer which contains offsets to other variable parts of the file.
org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
With this limiter resources will be refilled only after a fixed interval of time.
org.apache.hadoop.hbase.types.FixedLengthWrapper<T>
Wraps an existing DataType implementation as a fixed-length version of itself.
org.apache.hadoop.hbase.regionserver.FlushAllLargeStoresPolicy
A FlushPolicy that only flushes store larger a given threshold.
org.apache.hadoop.hbase.regionserver.FlushAllStoresPolicy
A FlushPolicy that always flushes all stores for a given region.
org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
A FlushPolicy that only flushes store larger a given threshold.
org.apache.hadoop.hbase.regionserver.FlushLifeCycleTracker
Used to track flush execution.
org.apache.hadoop.hbase.regionserver.FlushNonSloppyStoresFirstPolicy
A FlushPolicy that only flushes store larger than a given threshold.
org.apache.hadoop.hbase.regionserver.FlushPolicy
A flush policy determines the stores that need to be flushed when flushing a region.
org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
The class that creates a flush policy from a conf and HTableDescriptor.
org.apache.hadoop.hbase.regionserver.FlushRegionCallable
 
org.apache.hadoop.hbase.regionserver.FlushRequester
Request a flush.
org.apache.hadoop.hbase.regionserver.FlushRequestListener
Listener which will get notified regarding flush requests of regions.
org.apache.hadoop.hbase.regionserver.throttle.FlushThroughputControllerFactory
 
org.apache.hadoop.hbase.errorhandling.ForeignException
A ForeignException is an exception from another thread or process.
org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
The dispatcher acts as the state holding entity for foreign error handling.
org.apache.hadoop.hbase.errorhandling.ForeignExceptionListener
The ForeignExceptionListener is an interface for objects that can receive a ForeignException.
org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
This is an interface for a cooperative exception throwing mechanism.
org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
Wrapper for input stream(s) that takes care of the interaction of FS and HBase checksums, as well as closing streams.
org.apache.hadoop.hbase.regionserver.wal.FSHLog
The original implementation of FSWAL.
org.apache.hadoop.hbase.wal.FSHLogProvider
A WAL provider that use FSHLog.
org.apache.hadoop.hbase.wal.FSHLogProvider.Writer
 
org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
A filesystem based replication peer storage.
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.filter.FuzzyRowFilter
This is optimized version of a standard FuzzyRowFilter Filters data based on fuzzy row key.
org.apache.hadoop.hbase.metrics.Gauge<T>
A metrics which measures a discrete value.
org.apache.hadoop.hbase.client.Get
Used to perform Get operations on a single row.
org.apache.hadoop.hbase.util.GetJavaProperty
A generic way for querying Java properties.
org.apache.hadoop.hbase.quotas.GlobalQuotaSettings
An object which captures all quotas types (throttle or space) for a subject (user, table, or namespace).
org.apache.hadoop.hbase.quotas.GlobalQuotaSettingsImpl
Implementation of GlobalQuotaSettings to hide the Protobuf messages we use internally.
org.apache.hadoop.hbase.mapred.GroupingTableMap
Extract grouping columns from input record
org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Extract grouping columns from input record.
org.apache.hadoop.hbase.http.gson.GsonMessageBodyWriter<T>
Implements JSON serialization via Gson for JAX-RS.
org.apache.hadoop.hbase.util.GsonUtil
Helper class for gson.
org.apache.hadoop.hbase.io.HalfStoreFileReader
A facade for a HFile.Reader that serves up either the top or bottom half of a HFile where 'bottom' is the first half of the file containing the keys that sort lowest and 'top' is the second half of the file with keys that sort greater than those of the bottom half.
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.mapreduce.HashTable
 
org.apache.hadoop.hbase.mapreduce.HashTable.HashMapper
 
org.apache.hadoop.hbase.mapreduce.HashTable.TableHash
 
org.apache.hadoop.hbase.coprocessor.HasMasterServices
Deprecated.
Since 2.0.0 to be removed in 4.0.0.
org.apache.hadoop.hbase.coprocessor.HasRegionServerServices
Deprecated.
Since 2.0.0 to be removed in 4.0.0.
org.apache.hadoop.hbase.backup.HBackupFileSystem
View to an on-disk Backup Image FileSytem Provides the set of methods necessary to interact with the on-disk Backup Image data.
org.apache.hadoop.hbase.HBaseCluster
Deprecated.
since 3.0.0, will be removed in 4.0.0.
org.apache.hadoop.hbase.HBaseCommonTestingUtility
Deprecated.
since 3.0.0, will be removed in 4.0.0.
org.apache.hadoop.hbase.HBaseConfiguration
Adds HBase configuration files to a Configuration
org.apache.hadoop.hbase.util.HBaseConfTool
Tool that prints out a configuration.
org.apache.hadoop.hbase.exceptions.HBaseException
Base checked exception in HBase.
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.thrift.HbaseHandlerMetricsProxy
Converts a Hbase.Iface using InvocationHandler so that it reports process time of each call to ThriftMetrics.
org.apache.hadoop.hbase.client.HBaseHbck
Use Connection.getHbck() to obtain an instance of Hbck instead of constructing an HBaseHbck directly.
org.apache.hadoop.hbase.HBaseInterfaceAudience
This class defines constants for different classes of hbase limited private apis
org.apache.hadoop.hbase.HBaseIOException
All hbase specific IOExceptions should be subclasses of HBaseIOException
org.apache.hadoop.hbase.log.HBaseMarkers
 
org.apache.hadoop.hbase.security.HBasePolicyProvider
Implementation of secure Hadoop policy provider for mapping protocol interfaces to hbase-policy.xml entries.
org.apache.hadoop.hbase.nio.HBaseReferenceCounted
The HBaseReferenceCounted disabled several methods in Netty's ReferenceCounted, because those methods are unlikely to be used.
org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
A BaseReplicationEndpoint for replication endpoints whose target cluster is an HBase cluster.
org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint.SinkPeer
Wraps a replication region server sink to provide the ability to identify it.
org.apache.hadoop.hbase.ipc.HBaseRpcController
Optionally carries Cells across the proxy/service interface down into ipc.
org.apache.hadoop.hbase.ipc.HBaseRpcController.CancellationCallback
 
org.apache.hadoop.hbase.ipc.HBaseRpcControllerImpl
Get instances via RpcControllerFactory on client-side.
org.apache.hadoop.hbase.ipc.HBaseRPCErrorHandler
An interface for calling out of RPC for error conditions.
org.apache.hadoop.hbase.HBaseRpcServicesBase<S extends org.apache.hadoop.hbase.HBaseServerBase<?>>
Base class for Master and RegionServer RpcServices.
org.apache.hadoop.hbase.security.HBaseSaslRpcClient
A utility class that encapsulates SASL logic for RPC client.
org.apache.hadoop.hbase.security.HBaseSaslRpcServer
A utility class that encapsulates SASL logic for RPC server.
org.apache.hadoop.hbase.HBaseServerBase<R extends org.apache.hadoop.hbase.HBaseRpcServicesBase<?>>
Base class for hbase services, such as master or region server.
org.apache.hadoop.hbase.HBaseServerException
Base class for exceptions thrown by an HBase server.
org.apache.hadoop.hbase.client.backoff.HBaseServerExceptionPauseManager
 
org.apache.hadoop.hbase.thrift.HBaseServiceHandler
abstract class for HBase handler providing a Connection cache and get table/admin method
org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
General exception base class for when a snapshot fails.
org.apache.hadoop.hbase.HBaseTestingUtility
Deprecated.
since 3.0.0, will be removed in 4.0.0.
org.apache.hadoop.hbase.HBaseTestingUtility.SeenRowTracker
A tracker for tracking and validating table rows generated with HBaseTestingUtility.loadTable(Table, byte[])
org.apache.hadoop.hbase.io.crypto.tls.HBaseTrustManager
A custom TrustManager that supports hostname verification We attempt to perform verification using just the IP address first and if that fails will attempt to perform a reverse DNS lookup and verify using the hostname.
org.apache.hadoop.hbase.HBaseZKTestingUtility
Deprecated.
since 3.0.0, will be removed in 4.0.0.
org.apache.hadoop.hbase.client.Hbck
Hbck fixup tool APIs.
org.apache.hadoop.hbase.HbckEmptyRegionInfo
POJO to present Empty Region Info from Catalog Janitor Inconsistencies Report via REST API.
org.apache.hadoop.hbase.util.HbckErrorReporter
Deprecated.
Since 2.3.0.
org.apache.hadoop.hbase.util.HbckErrorReporter.ERROR_CODE
 
org.apache.hadoop.hbase.HbckInconsistentRegions
POJO to present HBCK Inconsistent Regions from HBCK Inconsistencies Report via REST API.
org.apache.hadoop.hbase.HbckOrphanRegionsOnFS
POJO to present Orphan Region on FS from HBCK Inconsistencies Report via REST API.
org.apache.hadoop.hbase.HbckOrphanRegionsOnRS
POJO to present Orphan Region on RS from HBCK Inconsistencies Report via REST API.
org.apache.hadoop.hbase.HbckOverlapRegions
POJO to present Region Overlap from Catalog Janitor Inconsistencies Report via REST API.
org.apache.hadoop.hbase.HbckRegionDetails
POJO class for HBCK RegionInfo in HBCK Inconsistencies report.
org.apache.hadoop.hbase.HbckRegionHoles
POJO to present Region Holes from Catalog Janitor Inconsistencies Report via REST API.
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.HbckServerName
POJO class for ServerName in HBCK Inconsistencies report.
org.apache.hadoop.hbase.util.HbckTableInfo
Maintain information about a particular table.
org.apache.hadoop.hbase.HbckUnknownServers
POJO to present Unknown Regions from Catalog Janitor Inconsistencies Report via REST API.
org.apache.hadoop.hbase.hbtop.HBTop
A real-time monitoring tool for HBase like Unix top command.
org.apache.hadoop.hbase.HConstants
HConstants holds a bunch of HBase-related constants
org.apache.hadoop.hbase.HConstants.OperationStatusCode
Status codes used for return values of bulk operations.
org.apache.hadoop.hbase.HDFSBlocksDistribution
Data structure to describe the distribution of HDFS blocks among hosts.
org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
Stores the hostname and weight for that hostname.
org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight.WeightComparator
Comparator used to sort hosts based on weight
org.apache.hadoop.hbase.HDFSBlocksDistribution.Visitor
Implementations 'visit' hostAndWeight.
org.apache.hadoop.hbase.hbtop.screen.top.Header
Represents headers for the metrics in the top screen.
org.apache.hadoop.hbase.HealthCheckChore
The Class HealthCheckChore for running health checker regularly.
org.apache.hadoop.hbase.ipc.HeapByteBufAllocator
A pooled ByteBufAllocator that does not prefer direct buffers regardless of platform settings.
org.apache.hadoop.hbase.regionserver.HeapMemoryManager
Manages tuning of Heap memory using HeapMemoryTuner.
org.apache.hadoop.hbase.regionserver.HeapMemoryManager.HeapMemoryTuneObserver
Every class that wants to observe heap memory tune actions must implement this interface.
org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
POJO to pass all the relevant information required to do the heap memory tuning.
org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
POJO which holds the result of memory tuning done by HeapMemoryTuner implementation.
org.apache.hadoop.hbase.regionserver.HeapMemoryTuner
Makes the decision regarding proper sizing of the heap memory.
org.apache.hadoop.hbase.io.HeapSize
Implementations can be asked for an estimate of their size in bytes.
org.apache.hbase.archetypes.exemplars.client.HelloHBase
Successful running of this application requires access to an active instance of HBase.
org.apache.hbase.archetypes.exemplars.shaded_client.HelloHBase
Successful running of this application requires access to an active instance of HBase.
org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenPresenter
The presentation logic for the help screen.
org.apache.hadoop.hbase.hbtop.screen.help.HelpScreenView
The help screen.
org.apache.hadoop.hbase.io.hfile.HFile
File format for hbase.
org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader
An abstraction used by the block index.
org.apache.hadoop.hbase.io.hfile.HFile.Reader
An interface used by clients to open and iterate an HFile.
org.apache.hadoop.hbase.io.hfile.HFile.Writer
API required to write an HFile
org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
This variety of ways to construct writers is used throughout the code, and we want to be able to swap writer implementations.
org.apache.hadoop.hbase.backup.HFileArchiver
Utility class to handle the removal of HFiles (or the respective StoreFiles) for a HRegion from the FileSystem.
org.apache.hadoop.hbase.util.HFileArchiveUtil
Helper class for all utilities related to archival/retrieval of HFiles
org.apache.hadoop.hbase.io.hfile.HFileBlock
Cacheable Blocks of an HFile version 2 file.
org.apache.hadoop.hbase.io.hfile.HFileBlock.BlockDeserializer
 
org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
 
org.apache.hadoop.hbase.io.encoding.HFileBlockDecodingContext
A decoding context that is created by a reader's encoder, and is shared across all of the reader's read operations.
org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
A default implementation of HFileBlockDecodingContext.
org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
A default implementation of HFileBlockEncodingContext.
org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
An encoding context that is created by a writer's encoder, and is shared across the writer's whole lifetime.
org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
Provides functionality to write (HFileBlockIndex.BlockIndexWriter) and read BlockIndexReader single-level and multi-level block indexes.
org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
Writes the block index into the output stream.
org.apache.hadoop.hbase.io.hfile.HFileContext
Read-only HFile Context Information.
org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
A builder that helps in building up the HFileContext
org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
This class marches through all of the region's hfiles and verifies that they are all valid files.
org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
Controls what kind of data block encoding is used.
org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
Do different kinds of data block encoding according to column family options.
org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder
Controls what kind of index block encoding is used.
org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder.EncodedSeeker
 
org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoderImpl
Do different kinds of index block encoding according to column family options.
org.apache.hadoop.hbase.io.hfile.HFileInfo
Metadata Map of attributes for HFile written out as HFile Trailer.
org.apache.hadoop.hbase.mapreduce.HFileInputFormat
Simple MR input format for HFiles.
org.apache.hadoop.hbase.io.HFileLink
HFileLink describes a link to an hfile.
org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
Writes HFiles.
org.apache.hadoop.hbase.HFilePerformanceEvaluation
This class runs performance benchmarks for HFile.
org.apache.hadoop.hbase.io.hfile.HFilePreadReader
Implementation of HFile.Reader to deal with pread.
org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
Implements pretty-printing functionality for HFiles.
org.apache.hadoop.hbase.io.hfile.HFileReaderImpl
Implementation that can handle all hfile versions of HFile.Reader.
org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.BlockIndexNotLoadedException
 
org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
Scanner that operates on encoded data blocks.
org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
 
org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.NotSeekedException
An exception thrown when an operation requiring a scanner to be seeked is invoked on a scanner that is not seeked.
org.apache.hadoop.hbase.io.hfile.HFileScanner
A scanner allows you to position yourself within a HFile and scan through it.
org.apache.hadoop.hbase.io.hfile.HFileStreamReader
Implementation of HFile.Reader to deal with stream read do not perform any prefetch operations (HFilePreadReader will do this).
org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
Common functionality needed by all versions of HFile writers.
org.apache.hadoop.hbase.filter.HintingFilter
Marker interface for filters that may return SEEK_NEXT_USING_HINT.
org.apache.hadoop.hbase.metrics.Histogram
A metric which measures the distribution of values.
org.apache.hadoop.hbase.master.HMaster
HMaster is the "master server" for HBase.
org.apache.hadoop.hbase.master.HMaster.TableDescriptorGetter
Implement to return TableDescriptor after pre-checks
org.apache.hadoop.hbase.master.HMasterCommandLine
 
org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
 
org.apache.hadoop.hbase.regionserver.HMobStore
The store implementation to save MOBs (medium objects), it extends the HStore.
org.apache.hadoop.hbase.zookeeper.HQuorumPeer
HBase's version of ZooKeeper's QuorumPeer.
org.apache.hadoop.hbase.regionserver.HRegion
Regions store data for a certain region of a table.
org.apache.hadoop.hbase.regionserver.HRegion.BulkLoadListener
Listener class to enable callers of bulkLoadHFile() to perform any necessary pre/post processing of a given bulkload call
org.apache.hadoop.hbase.regionserver.HRegion.FlushResult
 
org.apache.hadoop.hbase.regionserver.HRegion.FlushResult.Result
 
org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
Objects from this class are created when flushing to describe all the different states that that method ends up in.
org.apache.hadoop.hbase.regionserver.HRegion.PrepareFlushResult
A result object from prepare flush cache stage
org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
Class used to represent a lock on a row.
org.apache.hadoop.hbase.regionserver.HRegionFileSystem
View to an on-disk Region.
org.apache.hadoop.hbase.HRegionLocation
Data structure to hold RegionInfo and the address for the hosting HRegionServer.
org.apache.hadoop.hbase.mapred.HRegionPartitioner<K2,V2>
This is used to partition the output keys into groups of keys.
org.apache.hadoop.hbase.mapreduce.HRegionPartitioner<KEY,VALUE>
This is used to partition the output keys into groups of keys.
org.apache.hadoop.hbase.regionserver.HRegionServer
HRegionServer makes a set of HRegions available to clients.
org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
Class responsible for parsing the command line and starting the RegionServer.
org.apache.hadoop.hbase.regionserver.HRegionWALFileSystem
A Wrapper for the region FileSystem operations adding WAL specific operations
org.apache.hadoop.hbase.regionserver.HStore
A Store holds a column family in a Region.
org.apache.hadoop.hbase.regionserver.HStoreFile
A Store data file.
org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
A TThreadedSelectorServer.Args that reads hadoop configuration
org.apache.hadoop.hbase.http.HtmlQuoting
This class is responsible for quoting HTML characters.
org.apache.hadoop.hbase.thrift.HttpAuthenticationException
 
org.apache.hadoop.hbase.http.HttpConfig
Statics to get access to Http related configuration.
org.apache.hadoop.hbase.http.HttpConfig.Policy
 
org.apache.hadoop.hbase.thrift.HttpDoAsClient
See the instructions under hbase-examples/README.txt
org.apache.hadoop.hbase.client.example.HttpProxyExample
A simple example on how to use AsyncTable to write a fully asynchronous HTTP proxy server.
org.apache.hadoop.hbase.http.HttpRequestLog
RequestLog object for use with Http
org.apache.hadoop.hbase.http.HttpServer
Create a Jetty embedded server to answer http requests.
org.apache.hadoop.hbase.http.HttpServer.Builder
Class to construct instances of HTTP server with specific options.
org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
A Servlet input filter that quotes all HTML active characters in the parameter names and values.
org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
 
org.apache.hadoop.hbase.http.HttpServer.StackServlet
A very simple servlet to serve up a text representation of the current stack traces.
org.apache.hadoop.hbase.http.HttpServerUtil
HttpServer utility.
org.apache.hadoop.hbase.mapred.IdentityTableMap
Pass the given key and record as-is to reduce
org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
Pass the given key and record as-is to the reduce phase.
org.apache.hadoop.hbase.mapred.IdentityTableReduce
Write to table each key, record pair
org.apache.hadoop.hbase.mapreduce.IdentityTableReducer
Convenience class that simply writes all values (which must be Put or Delete instances) passed to it out to the configured HBase table.
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.exceptions.IllegalArgumentIOException
Exception thrown when an illegal argument is passed to a function/procedure.
org.apache.hadoop.hbase.util.ImmutableByteArray
Mainly used as keys for HashMap.
org.apache.hadoop.hbase.io.ImmutableBytesWritable
A byte sequence that is usable as a key or value.
org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
A Comparator optimized for ImmutableBytesWritable.
org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
A MemStoreLAB implementation which wraps N MemStoreLABs.
org.apache.hadoop.hbase.client.ImmutableScan
Immutable version of Scan
org.apache.hadoop.hbase.regionserver.ImmutableSegment
ImmutableSegment is an abstract class that extends the API supported by a Segment, and is not needed for a MutableSegment.
org.apache.hadoop.hbase.thrift.ImplType
An enum of server implementation selections
org.apache.hadoop.hbase.mapreduce.Import
Import data written by Export.
org.apache.hadoop.hbase.mapreduce.Import.CellImporter
A mapper that just writes out KeyValues.
org.apache.hadoop.hbase.mapreduce.Import.CellReducer
 
org.apache.hadoop.hbase.mapreduce.Import.CellSortImporter
 
org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable
 
org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable.CellWritableComparator
 
org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparablePartitioner
 
org.apache.hadoop.hbase.mapreduce.Import.Importer
Write table content out to files in hdfs.
org.apache.hadoop.hbase.mapreduce.ImportTsv
Tool to import data from a TSV file.
org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.BadTsvLineException
 
org.apache.hadoop.hbase.regionserver.querymatcher.IncludeAllCompactionQueryMatcher
A compaction query matcher that always return INCLUDE and drops nothing.
org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
 
org.apache.hadoop.hbase.filter.InclusiveStopFilter
A Filter that stops after the given row.
org.apache.hadoop.hbase.filter.IncompatibleFilterException
Used to indicate a filter incompatibility
org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
Split size is the number of regions that are on this server that all are of the same table, cubed, times 2x the region flush size OR the maximum region split size, whichever is smaller.
org.apache.hadoop.hbase.client.Increment
Used to perform Increment operations on a single row.
org.apache.hadoop.hbase.thrift.IncrementCoalescer
This class will coalesce increments from a thift server if hbase.regionserver.thrift.coalesceIncrement is set to true.
org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
 
org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
Uses an incrementing algorithm instead of the default.
org.apache.hadoop.hbase.io.encoding.IndexBlockEncoding
Provide access to all index block encoding algorithms.
org.apache.hadoop.hbase.mapreduce.IndexBuilder
Example map/reduce job to construct index tables that can be used to quickly find a row based on the value of a column.
org.apache.hadoop.hbase.mapreduce.IndexBuilder.Map
Internal Mapper to be run by Hadoop.
org.apache.hadoop.hbase.io.hfile.IndexOnlyLruBlockCache
An on heap block cache implementation extended LruBlockCache and only cache index block.
org.apache.hadoop.hbase.IndividualBytesFieldCell
 
org.apache.hadoop.hbase.http.InfoServer
Create a Jetty embedded server to answer http requests.
org.apache.hadoop.hbase.regionserver.storefiletracker.InitializeStoreFileTrackerProcedure
Procedure for setting StoreFileTracker information to table descriptor.
org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
A way to write "inline" blocks into an HFile.
org.apache.hadoop.hbase.InnerStoreCellComparator
Compare two HBase cells inner store, skip compare family for better performance.
org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
The presentation logic for the input mode.
org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenView
The input mode in the top screen.
org.apache.hadoop.hbase.regionserver.InputStreamBlockDistribution
Computes the HDFSBlockDistribution for a file based on the underlying located blocks for an HdfsDataInputStream reading that file.
org.apache.hadoop.hbase.regionserver.InternalScan
Special scanner, currently used for increment operations to allow additional server-side arguments for Scan operations.
org.apache.hadoop.hbase.regionserver.InternalScanner
Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[] instead of RowResults.
org.apache.hadoop.hbase.metrics.Interns
Helpers to create interned metrics info
org.apache.hadoop.hbase.InvalidFamilyOperationException
Thrown if a request is table schema modification is requested but made for an invalid family name.
org.apache.hadoop.hbase.io.hfile.InvalidHFileException
Thrown when an invalid HFile format is detected
org.apache.hadoop.hbase.regionserver.InvalidMutationDurabilityException
Thrown if Mutation's Durability is skip wal but table need replication.
org.apache.hadoop.hbase.filter.InvalidRowFilterException
Used to indicate an invalid RowFilter.
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.client.trace.IpcClientSpanBuilder
Construct Span instances originating from the client side of an IPC.
org.apache.hadoop.hbase.server.trace.IpcServerSpanBuilder
Construct Span instances originating from the server side of an IPC.
org.apache.hadoop.hbase.client.IsolationLevel
Specify Isolation levels in Scan operations.
org.apache.hadoop.hbase.mapreduce.JarFinder
Finds the Jar for a class.
org.apache.hadoop.hbase.util.JenkinsHash
Produces 32-bit hash for hash table lookup.
org.apache.hadoop.hbase.JitterScheduledThreadPoolExecutorImpl
ScheduledThreadPoolExecutor that will add some jitter to the RunnableScheduledFuture.getDelay.
org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
Provides Read only web access to JMX.
org.apache.hadoop.hbase.JMXListener
Pluggable JMX Agent for HBase(to fix the 2 random TCP ports issue of the out-of-the-box JMX Agent): 1)connector port can share with the registry port if SSL is OFF 2)support password authentication 3)support subset of SSL (with default configuration)
org.apache.hadoop.hbase.mapreduce.JobUtil
Utility methods to interact with a job.
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.logging.JulToSlf4jInitializer
Setup SLF4JBridgeHandler.
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.metrics.JvmPauseMonitorSource
Interface for sources that will export JvmPauseMonitor metrics
org.apache.hadoop.hbase.util.JvmVersion
Utility class to get and check the current JVM version.
org.apache.hadoop.hbase.KeepDeletedCells
Ways to keep cells marked for delete around.
org.apache.hadoop.hbase.util.KerberosUtils
 
org.apache.hadoop.hbase.util.KeyLocker<K>
A utility class to manage a set of locks.
org.apache.hadoop.hbase.exceptions.KeyManagerException
 
org.apache.hadoop.hbase.filter.KeyOnlyFilter
A filter that will only return the key component of each KV (the value will be rewritten as empty).
org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
Deprecated.
since 3.0.0 and will be removed in 4.0.0.
org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitRestriction
A RegionSplitRestriction implementation that groups rows by a prefix of the row-key.
org.apache.hadoop.hbase.hbtop.terminal.KeyPress
Represents the user pressing a key on the keyboard.
org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
org.apache.hadoop.hbase.hbtop.terminal.impl.KeyPressGenerator
This generates KeyPress objects from the given input stream and offers them to the given queue.
org.apache.hadoop.hbase.io.crypto.KeyProvider
KeyProvider is a interface to abstract the different methods of retrieving key material from key storage such as Java key store.
org.apache.hadoop.hbase.util.KeyRange
A key range use in split coverage.
org.apache.hadoop.hbase.io.crypto.tls.KeyStoreFileType
This enum represents the file type of a KeyStore or TrustStore.
org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
A basic KeyProvider that can resolve keys from a protected KeyStore file on the local filesystem.
org.apache.hadoop.hbase.KeyValue
An HBase Key/Value.
org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
A simple form of KeyValue that creates a keyvalue with only the key part of the byte[] Mainly used in places where we need to compare two cells.
org.apache.hadoop.hbase.KeyValue.SamePrefixComparator<T>
Avoids redundant comparisons for better performance.
org.apache.hadoop.hbase.KeyValue.Type
Key type.
org.apache.hadoop.hbase.codec.KeyValueCodec
Codec that does KeyValue version 1 serialization.
org.apache.hadoop.hbase.codec.KeyValueCodec.ByteBuffKeyValueDecoder
 
org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueDecoder
 
org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueEncoder
 
org.apache.hadoop.hbase.codec.KeyValueCodecWithTags
Codec that does KeyValue version 1 serialization with serializing tags also.
org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.ByteBuffKeyValueDecoder
 
org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueDecoder
 
org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueEncoder
 
org.apache.hadoop.hbase.regionserver.KeyValueHeap
Implements a heap merge across any number of KeyValueScanners.
org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
 
org.apache.hadoop.hbase.regionserver.KeyValueScanner
Scanner that returns the next KeyValue.
org.apache.hadoop.hbase.KeyValueTestUtil
 
org.apache.hadoop.hbase.KeyValueUtil
static convenience methods for dealing with KeyValues and collections of KeyValues
org.apache.hadoop.hbase.regionserver.LastSequenceId
Last flushed sequence Ids for the regions and their stores on region server
org.apache.hadoop.hbase.regionserver.LeaseException
Reports a problem with a lease
org.apache.hadoop.hbase.regionserver.LeaseListener
LeaseListener is an interface meant to be implemented by users of the Leases class.
org.apache.hadoop.hbase.regionserver.LeaseManager
Leases There are several server classes in HBase that need to track external clients that occasionally send heartbeats.
org.apache.hadoop.hbase.regionserver.LeaseManager.LeaseStillHeldException
Thrown if we are asked to create a lease but lease on passed name already exists.
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.master.LoadBalancer
Makes decisions about the placement and movement of Regions across RegionServers.
org.apache.hadoop.hbase.util.LoadTestDataGeneratorWithMOB
A load test data generator for MOB
org.apache.hadoop.hbase.util.LoadTestDataGeneratorWithTags
 
org.apache.hadoop.hbase.util.LoadTestKVGenerator
A generator of random keys and values for load testing.
org.apache.hadoop.hbase.util.LoadTestTool
A command-line utility that reads, writes, and verifies data.
org.apache.hadoop.hbase.util.LoadTestUtil
This class was created by moving all load test related code from HFileTestUtil and HBaseTestingUtil as part of refactoring for hbase-diagnostics module creation in HBASE-28432
org.apache.hadoop.hbase.LocalHBaseCluster
This class creates a single process HBase cluster.
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.client.locking.LockServiceClient
Helper class to create "master locks" for namespaces, tables and regions.
org.apache.hadoop.hbase.logging.Log4jUtils
A bridge class for operating on log4j, such as changing log level, etc.
Abstract response class representing online logs response from ring-buffer use-cases e.g slow/large RPC logs, balancer decision logs
org.apache.hadoop.hbase.namequeues.LogHandlerUtils
Event Handler utility class
org.apache.hadoop.hbase.http.log.LogLevel
Change log level in runtime.
org.apache.hadoop.hbase.http.log.LogLevel.Servlet
A servlet implementation
org.apache.hadoop.hbase.util.LogMonitoring
Utility functions for reading the log4j logs that are being written by HBase.
Deprecated.
as of 2.4.0.
org.apache.hadoop.hbase.client.LogQueryFilter.FilterByOperator
 
org.apache.hadoop.hbase.client.LogQueryFilter.Type
 
org.apache.hadoop.hbase.regionserver.LogRoller
Runs periodically to determine if the WAL should be rolled.
org.apache.hadoop.hbase.filter.LongComparator
A long comparator which numerical compares against the specified byte array
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.io.hfile.LruAdaptiveBlockCache
This realisation improve performance of classical LRU cache up to 3 times via reduce GC job.
org.apache.hadoop.hbase.io.hfile.LruBlockCache
A block cache implementation that is memory-aware using HeapSize, memory-bound using an LRU eviction algorithm, and concurrent: backed by a ConcurrentHashMap and with a non-blocking eviction thread giving constant-time LruBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable, boolean) and LruBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean) operations.
org.apache.hadoop.hbase.io.hfile.LruCachedBlock
Represents an entry in the LruBlockCache.
org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
A memory-bound queue that will grow until an element brings total size >= maxSize.
org.apache.hadoop.hbase.io.util.LRUDictionary
WALDictionary using an LRU eviction algorithm.
org.apache.hadoop.hbase.regionserver.querymatcher.MajorCompactionScanQueryMatcher
Query matcher for major compaction.
org.apache.hadoop.hbase.util.compaction.MajorCompactionTTLRequest
This request helps determine if a region has to be compacted based on table's TTL.
org.apache.hadoop.hbase.util.compaction.MajorCompactor
 
org.apache.hadoop.hbase.util.compaction.MajorCompactorTTL
This tool compacts a table's regions that are beyond it's TTL.
org.apache.hadoop.hbase.util.ManualEnvironmentEdge
An environment edge that uses a manually set value.
org.apache.hadoop.hbase.mob.ManualMobMaintHFileCleaner
BaseHFileCleanerDelegate that prevents cleaning HFiles from a mob region keeps a map of table name strings to mob region name strings over the life of a JVM instance.
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.zookeeper.MasterAddressTracker
Manages the location of the current active Master for the RegionServer.
org.apache.hadoop.hbase.master.MasterAnnotationReadingPriorityFunction
Priority function specifically for the master.
org.apache.hadoop.hbase.coprocessor.MasterCoprocessor
 
org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment
 
org.apache.hadoop.hbase.master.MasterCoprocessorHost
Provides the coprocessor framework and environment for master oriented operations.
org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
A special RpcScheduler} only used for master.
org.apache.hadoop.hbase.regionserver.MasterFifoRpcSchedulerFactory
Factory to use when you want to use the MasterFifoRpcScheduler
org.apache.hadoop.hbase.master.MasterFileSystem
This class abstracts a bunch of operations the HMaster needs to interact with the underlying file system like creating the initial layout, checking file system status, etc.
org.apache.hadoop.hbase.zookeeper.MasterMaintenanceModeTracker
Tracks the master Maintenance Mode via ZK.
org.apache.hadoop.hbase.MasterNotRunningException
Thrown if the master is not running
org.apache.hadoop.hbase.coprocessor.MasterObserver
Defines coprocessor hooks for interacting with operations on the HMaster process.
org.apache.hadoop.hbase.quotas.MasterQuotaManager
Master Quota Manager.
org.apache.hadoop.hbase.quotas.MasterQuotasObserver
An observer to automatically delete quotas when a table/namespace is deleted.
org.apache.hadoop.hbase.master.MasterRegionServerList
MasterRegion based RegionServerList.
org.apache.hadoop.hbase.client.MasterRegistry
Deprecated.
Since 2.5.0, will be removed in 4.0.0.
org.apache.hadoop.hbase.exceptions.MasterRegistryFetchException
Exception thrown when an master registry RPC fails in client.
org.apache.hadoop.hbase.master.MasterRpcServices
Implements the master RPC services.
org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapper
A wrapper class for MasterRpcServices shortcut that ensures a client version is available to the callee without a current RPC call.
org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapper.ServiceCallFunction<Req,Resp>
 
org.apache.hadoop.hbase.master.MasterServices
A curated subset of services provided by HMaster.
org.apache.hadoop.hbase.master.MasterStateStore
A state storage which stores the state in master local region.
org.apache.hadoop.hbase.exceptions.MasterStoppedException
Thrown when the master is stopped
org.apache.hadoop.hbase.client.MasterSwitchType
Represents the master switch type
org.apache.hadoop.hbase.master.MasterWalManager
This class abstracts a bunch of operations the HMaster needs when splitting log files e.g.
org.apache.hadoop.hbase.metrics.MBeanSource
Object that will register an mbean with the underlying metrics implementation.
org.apache.hadoop.hbase.metrics.MBeanSourceImpl
Hadoop2 metrics2 implementation of an object that registers MBeans.
org.apache.hadoop.hbase.util.MD5Hash
Utility class for MD5 MD5 hash produces a 128-bit digest.
org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
Class to store blocks into memcached.
org.apache.hadoop.hbase.MemoryCompactionPolicy
Enum describing all possible memory compaction policies
org.apache.hadoop.hbase.io.util.MemorySizeUtil
Util class to calculate memory size for memstore(on heap, off heap), block cache(L1, L2) of RS.
org.apache.hadoop.hbase.regionserver.MemStore
The MemStore holds in-memory modifications to the Store.
org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy
MemStoreCompactionStrategy is the root of a class hierarchy which defines the strategy for choosing the next action to apply in an (in-memory) memstore compaction.
org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy.Action
Types of actions to be done on the pipeline upon MemStoreCompaction invocation.
org.apache.hadoop.hbase.regionserver.MemStoreCompactor
The ongoing MemStore Compaction manager, dispatches a solo running compaction and interrupts the compaction if requested.
org.apache.hadoop.hbase.regionserver.MemStoreCompactorSegmentsIterator
The MemStoreCompactorSegmentsIterator extends MemStoreSegmentsIterator and performs the scan for compaction operation meaning it is based on SQM
org.apache.hadoop.hbase.regionserver.MemStoreFlusher
Thread that flushes cache on request NOTE: This class extends Thread rather than Chore because the sleep time can be interrupted when there is something to do, rather than the Chore sleep time which is invariant.
org.apache.hadoop.hbase.regionserver.MemStoreLAB
A memstore-local allocation buffer.
org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
A memstore-local allocation buffer.
org.apache.hadoop.hbase.regionserver.MemStoreMergerSegmentsIterator
The MemStoreMergerSegmentsIterator extends MemStoreSegmentsIterator and performs the scan for simple merge operation meaning it is NOT based on SQM
org.apache.hadoop.hbase.regionserver.MemStoreSegmentsIterator
The MemStoreSegmentsIterator is designed to perform one iteration over given list of segments For another iteration new instance of MemStoreSegmentsIterator needs to be created The iterator is not thread-safe and must have only one instance per MemStore in each period of time
org.apache.hadoop.hbase.regionserver.MemStoreSize
Data structure of three longs.
org.apache.hadoop.hbase.regionserver.MemStoreSizing
Accounting of current heap and data sizes.
org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
MemStoreSnapshot is a Context Object to hold details of the snapshot taken on a MemStore.
org.apache.hadoop.hbase.exceptions.MergeRegionException
Thrown when something is wrong in trying to merge two regions.
org.apache.hadoop.hbase.codec.MessageCodec
Codec that just writes out Cell as a protobuf Cell Message.
org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenPresenter
The presentation logic for the message mode.
org.apache.hadoop.hbase.hbtop.screen.top.MessageModeScreenView
The message mode in the top screen.
org.apache.hadoop.hbase.MetaCellComparator
A CellComparatorImpl for hbase:meta catalog table KeyValues.
org.apache.hadoop.hbase.MetaMutationAnnotation
The field or the parameter to which this annotation can be applied only when it holds mutations for hbase:meta table.
org.apache.hadoop.hbase.MetaRegionLocationCache
A cache of meta region location metadata.
org.apache.hadoop.hbase.ipc.MetaRWQueueRpcExecutor
RPC Executor that uses different queues for reads and writes for meta.
org.apache.hadoop.hbase.MetaTableAccessor
Read/write operations on hbase:meta region as well as assignment information stored to hbase:meta.
org.apache.hadoop.hbase.zookeeper.MetaTableLocator
Utility class to perform operation (get/wait for/verify/set/delete) on znode in ZooKeeper which keeps hbase:meta region server location.
org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
A coprocessor that collects metrics from meta table.
org.apache.hadoop.hbase.metrics.Meter
A metric which measure the rate at which some operation is invoked.
org.apache.hadoop.hbase.util.Methods
 
org.apache.hadoop.hbase.metrics.Metric
Parent interface for all metrics.
org.apache.hadoop.metrics2.MetricHistogram
Metrics Histogram interface.
org.apache.hadoop.hbase.metrics.MetricRegistries
MetricRegistries is collection of MetricRegistry's.
org.apache.hadoop.hbase.metrics.MetricRegistriesLoader
 
org.apache.hadoop.hbase.metrics.MetricRegistry
General purpose factory for creating various metrics.
org.apache.hadoop.hbase.metrics.MetricRegistryFactory
A Factory for creating MetricRegistries.
org.apache.hadoop.hbase.metrics.MetricRegistryInfo
HBase Metrics are grouped in different MetricRegistry'ies.
org.apache.hadoop.hbase.master.MetricsAssignmentManager
 
org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
 
org.apache.hadoop.hbase.client.MetricsConnection
This class is for maintaining the various connection statistics and publishing them through the metrics interfaces.
org.apache.hadoop.hbase.client.MetricsConnection.CallStats
A container class for collecting details about the RPC call as it percolates.
org.apache.hadoop.hbase.client.MetricsConnection.CallTracker
 
org.apache.hadoop.hbase.client.MetricsConnection.RegionStats
 
org.apache.hadoop.hbase.client.MetricsConnection.RunnerStats
 
org.apache.hadoop.hbase.coprocessor.MetricsCoprocessor
Utility class for tracking metrics for various types of coprocessors.
org.apache.hadoop.hbase.metrics.MetricSet
A set of named metrics.
org.apache.hadoop.metrics2.MetricsExecutor
ScheduledExecutorService for metrics.
org.apache.hadoop.hbase.ipc.MetricsHBaseServer
 
org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactory
 
org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryImpl
 
org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
 
org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
 
org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
This class is for maintaining the various regionserver's heap memory manager statistics and publishing them through the metrics interfaces.
org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
This interface will be implemented by a MetricsSource that will export metrics from HeapMemoryManager in RegionServer into the hadoop metrics system.
org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
Hadoop2 implementation of MetricsHeapMemoryManagerSource.
org.apache.hadoop.hbase.io.MetricsIO
 
org.apache.hadoop.hbase.io.MetricsIOSource
 
org.apache.hadoop.hbase.io.MetricsIOSourceImpl
 
org.apache.hadoop.hbase.io.MetricsIOWrapper
 
org.apache.hadoop.hbase.io.MetricsIOWrapperImpl
 
org.apache.hadoop.hbase.master.MetricsMaster
This class is for maintaining the various master statistics and publishing them through the metrics interfaces.
org.apache.hadoop.hbase.master.MetricsMasterFileSystem
 
org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
 
org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
 
org.apache.hadoop.hbase.master.MetricsMasterProcSource
Interface that classes that expose metrics about the master will implement.
org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactory
Interface of a factory to create MetricsMasterSource when given a MetricsMasterWrapper
org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactoryImpl
Factory to create MetricsMasterProcSource when given a MetricsMasterWrapper
org.apache.hadoop.hbase.master.MetricsMasterProcSourceImpl
Hadoop2 implementation of MetricsMasterSource.
org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
A collection of exposed metrics for space quotas from the HBase Master.
org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceFactory
Interface of a factory to create MetricsMasterQuotaSource when given a MetricsMasterWrapper.
org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceFactoryImpl
Factory to create MetricsMasterQuotaSource instances when given a MetricsMasterWrapper.
org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
Implementation of MetricsMasterQuotaSource which writes the values passed in via the interface to the metrics backend.
org.apache.hadoop.hbase.master.MetricsMasterSource
Interface that classes that expose metrics about the master will implement.
org.apache.hadoop.hbase.master.MetricsMasterSourceFactory
Interface of a factory to create MetricsMasterSource when given a MetricsMasterWrapper
org.apache.hadoop.hbase.master.MetricsMasterSourceFactoryImpl
Factory to create MetricsMasterSource when given a MetricsMasterWrapper
org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
Hadoop2 implementation of MetricsMasterSource.
org.apache.hadoop.hbase.master.MetricsMasterWrapper
This is the interface that will expose information to hadoop1/hadoop2 implementations of the MetricsMasterSource.
org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
Impl for exposing HMaster Information through JMX
org.apache.hadoop.hbase.regionserver.MetricsRegion
This is the glue between the HRegion and whatever hadoop shim layer is loaded (hbase-hadoop1-compat or hbase-hadoop2-compat).
org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
This interface will be implemented by a MetricsSource that will export metrics from multiple regions into the hadoop metrics system.
org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
 
org.apache.hadoop.hbase.regionserver.MetricsRegionServer
Maintains regionserver statistics and publishes them through the metrics interfaces.
org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
A collection of exposed metrics for space quotas from an HBase RegionServer.
org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSourceImpl
Implementation of MetricsRegionServerQuotaSource.
org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Interface for classes that expose metrics about the regionserver.
org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
Interface of a factory to create Metrics Sources used inside of regionservers.
org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
Factory to create MetricsRegionServerSource when given a MetricsRegionServerWrapper
org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl.FactoryStorage
 
org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
Hadoop2 implementation of MetricsRegionServerSource.
org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
This is the interface that will expose RegionServer information to hadoop1/hadoop2 implementations of the MetricsRegionServerSource.
org.apache.hadoop.hbase.regionserver.MetricsRegionSource
This interface will be implemented to allow single regions to push metrics into MetricsRegionAggregateSource that will in turn push data to the Hadoop metrics system.
org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
Interface of class that will wrap an HRegion and export numbers so they can be used in MetricsRegionSource
org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
org.apache.hadoop.hbase.rest.MetricsREST
 
org.apache.hadoop.hbase.rest.MetricsRESTSource
Interface of the Metrics Source that will export data to Hadoop's Metrics2 system.
org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
Hadoop Two implementation of a metrics2 source that will export metrics from the Rest server to the hadoop metrics2 subsystem.
org.apache.hadoop.hbase.master.MetricsSnapshot
 
org.apache.hadoop.hbase.master.MetricsSnapshotSource
 
org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
 
org.apache.hadoop.hbase.regionserver.MetricsTable
 
org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSource
This interface will be implemented by a MetricsSource that will export metrics from multiple regions of a table into the hadoop metrics system.
org.apache.hadoop.hbase.regionserver.MetricsTableAggregateSourceImpl
 
org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
 
org.apache.hadoop.hbase.regionserver.MetricsTableSource
This interface will be implemented to allow region server to push table metrics into MetricsRegionAggregateSource that will in turn push data to the Hadoop metrics system.
org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
 
org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregate
Interface of class that will wrap a MetricsTableSource and export numbers so they can be used in MetricsTableSource
org.apache.hadoop.hbase.regionserver.MetricsTableWrapperAggregateImpl
 
org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Interface of a class that will export metrics about Thrift to hadoop's metrics2.
org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
Factory that will be used to create metrics sources for the two diffent types of thrift servers.
org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactoryImpl
Class used to create metrics sources for Thrift and Thrift2 servers.
org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
Hadoop 2 version of MetricsThriftServerSource Implements BaseSource through BaseSourceImpl, following the pattern
org.apache.hadoop.hbase.regionserver.MetricsUserAggregate
 
org.apache.hadoop.hbase.regionserver.MetricsUserAggregateFactory
 
org.apache.hadoop.hbase.regionserver.MetricsUserAggregateImpl
 
org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSource
This interface will be implemented by a MetricsSource that will export metrics from multiple users into the hadoop metrics system.
org.apache.hadoop.hbase.regionserver.MetricsUserAggregateSourceImpl
 
org.apache.hadoop.hbase.regionserver.MetricsUserSource
 
org.apache.hadoop.hbase.regionserver.MetricsUserSource.ClientMetrics
 
org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
 
org.apache.hadoop.hbase.regionserver.wal.MetricsWAL
Class used to push numbers about the WAL into the metrics subsystem.
org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSource
 
org.apache.hadoop.hbase.namequeues.MetricsWALEventTrackerSourceImpl
 
org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
Interface of the source that will export metrics about the region server's WAL.
org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
Class that transitions metrics from MetricsWAL into the metrics subsystem.
org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
Interface of the source that will export metrics about the ZooKeeper.
org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
Class that transitions metrics from MetricsZooKeeper into the metrics subsystem.
org.apache.hadoop.hbase.rsgroup.MigrateRSGroupProcedure
Procedure for migrating rs group information to table descriptor.
org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress<T>
Wraps together the mutations which are applied as a batch to the region and their operation status and WALEdits.
org.apache.hadoop.hbase.MiniHBaseCluster
Deprecated.
since 3.0.0, will be removed in 4.0.0.
org.apache.hadoop.hbase.MiniHBaseCluster.MiniHBaseClusterRegionServer
Subclass so can get at protected methods (none at moment).
org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
TODO: Most of the code in this class is ripped from ZooKeeper tests.
org.apache.hadoop.hbase.regionserver.querymatcher.MinorCompactionScanQueryMatcher
Query matcher for minor compaction.
org.apache.hadoop.hbase.quotas.policies.MissingSnapshotViolationPolicyEnforcement
A SpaceViolationPolicyEnforcement which can be treated as a singleton.
org.apache.hadoop.hbase.mob.MobCell
The MobCell will maintain a Cell and a StoreFileScanner inside.
org.apache.hadoop.hbase.client.MobCompactPartitionPolicy
Enum describing the mob compact partition policy types.
org.apache.hadoop.hbase.mob.MobConstants
The constants used in mob.
org.apache.hadoop.hbase.mob.MobFile
The mob file.
org.apache.hadoop.hbase.mob.MobFileCache
The cache for mob files.
org.apache.hadoop.hbase.mob.MobFileCleanerChore
The class MobFileCleanerChore for running cleaner regularly to remove the expired and obsolete (files which have no active references to) mob files.
org.apache.hadoop.hbase.mob.MobFileCleanupUtil
 
org.apache.hadoop.hbase.mob.MobFileCompactionChore
Periodic MOB compaction chore.
org.apache.hadoop.hbase.mob.MobFileName
The mob file name.
org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter
Scans a given table + CF for all mob reference cells to get the list of backing mob files.
org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefMapper
 
org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer
 
org.apache.hadoop.hbase.mob.MobStoreEngine
MobStoreEngine creates the mob specific compactor, and store flusher.
org.apache.hadoop.hbase.regionserver.MobStoreScanner
Scanner scans both the memstore and the MOB Store.
org.apache.hadoop.hbase.mob.MobUtils
The mob utilities
org.apache.hadoop.hbase.io.crypto.MockAesKeyProvider
Return a fixed secret key for AES for testing.
org.apache.hadoop.hbase.MockRegionServerServices
Basic mock region server services.
org.apache.hadoop.hbase.hbtop.mode.Mode
Represents a display mode in the top screen.
org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
The presentation logic for the mode screen.
org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenView
The screen where we can choose the Mode in the top screen.
org.apache.hadoop.hbase.hbtop.mode.ModeStrategyUtils
 
org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyColumnFamilyStoreFileTrackerProcedure
 
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.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure
This procedure is used to change the store file tracker implementation.
org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyTableStoreFileTrackerProcedure
 
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.MultiActionResultTooLarge
Exception thrown when the result needs to be chunked on the server side.
org.apache.hadoop.hbase.nio.MultiByteBuff
Provides a unified view of all the underlying ByteBuffers and will look as if a bigger sequential buffer.
org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
This filter is used for selecting only those keys with columns that matches a particular prefix.
org.apache.hadoop.hbase.client.MultiResponse
A container for Result objects, grouped by regionName.
org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
This class implements atomic multi row transactions using HRegion.mutateRowsWithLocks(Collection, Collection, long, long) and Coprocessor endpoints.
org.apache.hadoop.hbase.filter.MultiRowRangeFilter
Filter to support scan multiple row key ranges.
org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
 
org.apache.hadoop.hbase.rest.MultiRowResource
 
org.apache.hadoop.hbase.rest.MultiRowResultReader
 
org.apache.hadoop.hbase.mapreduce.MultiTableHFileOutputFormat
Create 3 level tree directory, first level is using table name as parent directory and then use family name as child directory, and all related HFiles for one family are under child directory -tableName1 -columnFamilyName1 -columnFamilyName2 -HFiles -tableName2 -columnFamilyName1 -HFiles -columnFamilyName2
org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
Convert HBase tabular data from multiple scanners into a format that is consumable by Map/Reduce.
org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
A base for MultiTableInputFormats.
org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
Hadoop output format that writes to one or more HBase tables.
org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
Record writer for outputting to multiple HTables.
org.apache.hadoop.hbase.mapred.MultiTableSnapshotInputFormat
MultiTableSnapshotInputFormat generalizes TableSnapshotInputFormat allowing a MapReduce job to run over one or more table snapshots, with one or more scans configured for each.
org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormat
MultiTableSnapshotInputFormat generalizes TableSnapshotInputFormat allowing a MapReduce job to run over one or more table snapshots, with one or more scans configured for each.
org.apache.hadoop.hbase.mapreduce.MultiTableSnapshotInputFormatImpl
Shared implementation of mapreduce code over multiple table snapshots.
org.apache.hadoop.hbase.util.MultiThreadedAction
Common base class for reader and writer parts of multi-thread HBase load test (See LoadTestTool).
org.apache.hadoop.hbase.util.MultiThreadedAction.DefaultDataGenerator
Default implementation of LoadTestDataGenerator that uses LoadTestKVGenerator, fixed set of column families, and random number of columns in range.
org.apache.hadoop.hbase.client.example.MultiThreadedClientExample
Example on how to use HBase's Connection and Table in a multi-threaded environment.
org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.ReadExampleCallable
Class to show how to scan some rows starting at a random location.
org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.SingleWriteExampleCallable
Class to show how to send a single put.
org.apache.hadoop.hbase.client.example.MultiThreadedClientExample.WriteExampleCallable
Class that will show how to send batches of puts at the same time.
org.apache.hadoop.hbase.util.MultiThreadedReader
Creates multiple threads that read and verify previously written data
org.apache.hadoop.hbase.util.MultiThreadedReaderWithACL
A MultiThreadReader that helps to work with ACL
org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper<K2,V2>
Multithreaded implementation for @link org.apache.hbase.mapreduce.TableMapper
org.apache.hadoop.hbase.util.MultiThreadedUpdater
Creates multiple threads that write key/values into the
org.apache.hadoop.hbase.util.MultiThreadedUpdaterWithACL
A MultiThreadUpdater that helps to work with ACL
org.apache.hadoop.hbase.util.MultiThreadedWriter
Creates multiple threads that write key/values into the
org.apache.hadoop.hbase.util.MultiThreadedWriterBase
Creates multiple threads that write key/values into the
org.apache.hadoop.hbase.util.MultiThreadedWriterWithACL
MultiThreadedWriter that helps in testing ACL
org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
Manages the read/write consistency.
org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl.WriteEntry
Write number and whether write has completed given out at start of a write transaction.
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.regionserver.MutableOnlineRegions
Interface to Map of online regions.
org.apache.hadoop.hbase.regionserver.MutableSegment
A mutable segment in memstore, specifically the active segment.
org.apache.hadoop.hbase.client.Mutation
 
org.apache.hadoop.hbase.mapreduce.MutationSerialization
 
org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
Request object to be used by ring buffer use-cases.
org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
Response object to be sent by namedQueue service back to caller
org.apache.hadoop.hbase.namequeues.NamedQueuePayload
Base payload to be prepared by client to send various namedQueue events for in-memory ring buffer storage in either HMaster or RegionServer.
org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
 
org.apache.hadoop.hbase.namequeues.NamedQueueRecorder
NamedQueue recorder that maintains various named queues.
org.apache.hadoop.hbase.namequeues.NamedQueueService
In-memory Queue service provider for multiple use-cases.
org.apache.hadoop.hbase.namequeues.NamedQueueServiceChore
Chore to insert multiple accumulated slow/large logs to hbase:slowlog system table
org.apache.hadoop.hbase.namespace.NamespaceAuditor
The Class NamespaceAuditor performs checks to ensure operations like table creation and region splitting preserve namespace quota.
org.apache.hadoop.hbase.NamespaceDescriptor
Namespace POJO class.
org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
org.apache.hadoop.hbase.NamespaceExistException
Thrown when a namespace exists but should not
org.apache.hadoop.hbase.wal.NamespaceGroupingStrategy
A WAL grouping strategy based on namespace.
org.apache.hadoop.hbase.hbtop.mode.NamespaceModeStrategy
Implementation for ModeStrategy for Namespace Mode.
org.apache.hadoop.hbase.NamespaceNotFoundException
Thrown when a namespace can not be located
org.apache.hadoop.hbase.quotas.NamespaceQuotaSnapshotStore
QuotaSnapshotStore implementation for namespaces.
org.apache.hadoop.hbase.rest.NamespacesInstanceResource
Implements the following REST end points:
org.apache.hadoop.hbase.rest.NamespacesResource
Implements REST GET list of all namespaces.
org.apache.hadoop.hbase.replication.NamespaceTableCfWALEntryFilter
Filter a WAL Entry by the peer config according to the table and family which it belongs to.
org.apache.hadoop.hbase.wal.NettyAsyncFSWALConfigHelper
Helper class for passing netty event loop config to AsyncFSWALProvider.
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.security.NettyHBaseRpcConnectionHeaderHandler
Implement logic to deal with the rpc connection header.
org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClient
Implement SASL logic for netty rpc client.
org.apache.hadoop.hbase.security.NettyHBaseSaslRpcClientHandler
Implement SASL logic for netty rpc client.
org.apache.hadoop.hbase.ipc.NettyRpcClient
Netty client for the requests and responses.
org.apache.hadoop.hbase.ipc.NettyRpcClientConfigHelper
Helper class for passing config to NettyRpcClient.
org.apache.hadoop.hbase.ipc.NettyRpcServer
An RPC server with Netty4 implementation.
org.apache.hadoop.hbase.ipc.NettyRpcServerChannelWritabilityHandler
Handler to enforce writability protections on our server channels:
- Responds to channel writability events, which are triggered when the total pending bytes for a channel passes configured high and low watermarks.
org.apache.hadoop.hbase.util.NettyUnsafeUtils
Wraps some usages of netty's unsafe API, for ease of maintainability.
org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
A tracker both implementing ColumnTracker and DeleteTracker, used for mvcc-sensitive scanning.
org.apache.hadoop.hbase.http.NoCacheFilter
 
org.apache.hadoop.hbase.quotas.policies.NoInsertsViolationPolicyEnforcement
A SpaceViolationPolicyEnforcement which disallows any inserts to the table.
org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
This is a special ScannerContext subclass that is designed to be used globally when limits should not be enforced during invocations of InternalScanner.next(java.util.List) or InternalScanner.next(java.util.List).
org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
 
org.apache.hadoop.hbase.client.NonceGenerator
NonceGenerator interface.
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.io.encoding.NoneEncoder
 
org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
A "non-lazy" scanner which always does a real seek operation.
org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
A "non-reversed & non-lazy" scanner which does not support backward scanning and always does a real seek operation.
org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
Does not perform any kind of encoding/decoding.
org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder
Does not perform any kind of encoding/decoding.
org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
 
org.apache.hadoop.hbase.client.NoopPartialResultCoprocessorCallback<S,R>
 
org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
A RegionSizeStore implementation that stores nothing.
org.apache.hadoop.hbase.regionserver.NoRegionSplitRestriction
A RegionSplitRestriction implementation that does nothing.
org.apache.hadoop.hbase.client.NormalizeTableFilterParams
A collection of criteria used for table selection.
org.apache.hadoop.hbase.client.NormalizeTableFilterParams.Builder
Used to instantiate an instance of NormalizeTableFilterParams.
org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
Query matcher for normal user scan.
org.apache.hadoop.hbase.client.NoServerForRegionException
Thrown when no region server can be found for a region
org.apache.hadoop.hbase.regionserver.NoSuchColumnFamilyException
Thrown if request for nonexistent column family.
org.apache.hadoop.hbase.master.NoSuchProcedureException
 
org.apache.hadoop.hbase.regionserver.NoTagByteBufferChunkKeyValue
ByteBuffer based cell which has the chunkid at the 0th offset and with no tags
org.apache.hadoop.hbase.NoTagsByteBufferKeyValue
An extension of the ByteBufferKeyValue where the tags length is always 0
org.apache.hadoop.hbase.NoTagsKeyValue
An extension of the KeyValue where the tags length is always 0
org.apache.hadoop.hbase.NotAllMetaRegionsOnlineException
Thrown when an operation requires the root and all meta regions to be online
org.apache.hadoop.hbase.NotServingRegionException
Thrown by a region server if it is sent a request for a region it is not serving.
org.apache.hadoop.hbase.quotas.policies.NoWritesCompactionsViolationPolicyEnforcement
A SpaceViolationPolicyEnforcement implementation which disables all updates and compactions.
org.apache.hadoop.hbase.quotas.policies.NoWritesViolationPolicyEnforcement
A SpaceViolationPolicyEnforcement implementation which disables all writes flowing into HBase.
org.apache.hadoop.hbase.filter.NullComparator
A binary comparator which lexicographically compares against the specified byte array using Bytes.compareTo(byte[], byte[]).
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.coprocessor.ObserverContext<E extends org.apache.hadoop.hbase.CoprocessorEnvironment>
Carries the execution state for a given invocation of an Observer coprocessor (RegionObserver, MasterObserver, or WALObserver) method.
org.apache.hadoop.hbase.coprocessor.ObserverContextImpl<E extends org.apache.hadoop.hbase.CoprocessorEnvironment>
This is the only implementation of ObserverContext, which serves as the interface for third-party Coprocessor developers.
org.apache.hadoop.hbase.regionserver.OffheapChunk
An off heap chunk implementation.
org.apache.hadoop.hbase.master.OldWALsDirSizeChore
This chore is used to update the 'oldWALsDirSize' variable in MasterWalManager through the MasterWalManager.updateOldWALsDirSize() method.
org.apache.hadoop.hbase.regionserver.OnheapChunk
An on heap chunk implementation.
Slow/Large Log payload for hbase-client, to be used by Admin API get_slow_responses and get_large_responses
org.apache.hadoop.hbase.client.OnlineLogRecord.OnlineLogRecordBuilder
 
org.apache.hadoop.hbase.regionserver.OnlineRegions
Provides read-only access to the Regions presently online on the current RegionServer
org.apache.hadoop.hbase.util.OOMEChecker
 
org.apache.hadoop.hbase.client.Operation
Superclass for any type that maps to a potentially application-level query.
org.apache.hadoop.hbase.metrics.OperationMetrics
Container class for commonly collected metrics for most operations.
org.apache.hadoop.hbase.quotas.OperationQuota
Interface that allows to check the quota available for an operation.
org.apache.hadoop.hbase.quotas.OperationQuota.OperationType
 
org.apache.hadoop.hbase.regionserver.OperationStatus
This class stores the Operation status code and the exception message that occurs in case of failure of operations like put, delete, etc.
org.apache.hadoop.hbase.client.OperationWithAttributes
 
org.apache.hadoop.hbase.util.Order
Used to describe or modify the lexicographical sort order of a byte[].
org.apache.hadoop.hbase.types.OrderedBlob
A byte[] of variable-length.
org.apache.hadoop.hbase.types.OrderedBlobVar
An alternative to OrderedBlob for use by Struct fields that do not terminate the fields list.
org.apache.hadoop.hbase.util.OrderedBytes
Utility class that handles ordered byte arrays.
org.apache.hadoop.hbase.types.OrderedBytesBase<T>
Base class for data types backed by the OrderedBytes encoding implementations.
org.apache.hadoop.hbase.types.OrderedFloat32
A float of 32-bits using a fixed-length encoding.
org.apache.hadoop.hbase.types.OrderedFloat64
A double of 64-bits using a fixed-length encoding.
org.apache.hadoop.hbase.types.OrderedInt16
A short of 16-bits using a fixed-length encoding.
org.apache.hadoop.hbase.types.OrderedInt32
An int of 32-bits using a fixed-length encoding.
org.apache.hadoop.hbase.types.OrderedInt64
A long of 64-bits using a fixed-length encoding.
org.apache.hadoop.hbase.types.OrderedInt8
A byte of 8-bits using a fixed-length encoding.
org.apache.hadoop.hbase.types.OrderedNumeric
An Number of arbitrary precision and variable-length encoding.
org.apache.hadoop.hbase.types.OrderedString
A String of variable-length.
org.apache.hadoop.hbase.exceptions.OutOfOrderScannerNextException
Thrown by a RegionServer while doing next() calls on a ResultScanner.
org.apache.hadoop.hbase.metrics.PackageMarker
This is a dummy annotation that forces javac to produce output for otherwise empty package-info.java.
org.apache.hadoop.hbase.filter.PageFilter
Implementation of Filter interface that limits results to a specific page size.
org.apache.hadoop.hbase.hbtop.screen.top.Paging
Utility class for paging for the metrics.
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.filter.ParseConstants
ParseConstants holds a bunch of constants related to parsing Filter Strings Used by ParseFilter
org.apache.hadoop.hbase.filter.ParseFilter
This class allows a user to specify a filter via a string The string is parsed using the methods of this class and a filter object is constructed.
org.apache.hadoop.hbase.types.PBCell
An example for using protobuf objects with DataType API.
org.apache.hadoop.hbase.types.PBType<T extends org.apache.hbase.thirdparty.com.google.protobuf.Message>
A base-class for DataType implementations backed by protobuf.
org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
NonceGenerator implementation that uses client ID hash + random int as nonce group, and random numbers as nonces.
org.apache.hadoop.hbase.PerformanceEvaluation
Script used evaluating HBase performance and scalability.
org.apache.hadoop.hbase.PerformanceEvaluation.Counter
Enum for map metrics.
org.apache.hadoop.hbase.PerformanceEvaluation.EvaluationMapTask
MapReduce job that runs a performance evaluation client in each map task.
org.apache.hadoop.hbase.PerformanceEvaluation.RunResult
 
org.apache.hadoop.hbase.PerformanceEvaluationCommons
Code shared by PE tests.
org.apache.hadoop.hbase.PleaseHoldException
This exception is thrown by the master when a region server was shut down and restarted so fast that the master still hasn't processed the server shutdown of the first instance, or when master is initializing and client call admin operations, or when an operation is performed on a region server that is still starting.
org.apache.hadoop.hbase.PleaseRestartMasterException
Thrown if the master requires restart.
Abstract class template for defining a pluggable blocking queue implementation to be used by the 'pluggable' call queue type in the RpcExecutor.
org.apache.hadoop.hbase.ipc.PluggableRpcQueueNotFound
Internal runtime error type to indicate the RpcExecutor failed to execute a `pluggable` call queue type.
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.exceptions.PreemptiveFastFailException
Deprecated.
since 2.3.0, and will be removed in 4.0.0.
org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
 
org.apache.hadoop.hbase.regionserver.PrefetchExecutorNotifier
Class to submit requests for PrefetchExecutor depending on configuration change
org.apache.hadoop.hbase.filter.PrefixFilter
Pass results that have same row prefix.
org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
Compress key by storing size of common prefix with previous KeyValue and storing raw size of rest.
org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
A throughput controller which uses the follow schema to limit throughput If compaction pressure is greater than 1.0, no limitation. In off peak hours, use a fixed throughput limitation "hbase.hstore.compaction.throughput.offpeak" In normal hours, the max throughput is tuned between "hbase.hstore.compaction.throughput.lower.bound" and "hbase.hstore.compaction.throughput.higher.bound", using the formula "lower + (higer - lower) * compactionPressure", where compactionPressure is in range [0.0, 1.0]
org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
A throughput controller which uses the follow schema to limit throughput If flush pressure is greater than or equal to 1.0, no limitation. In normal case, the max throughput is tuned between "hbase.hstore.flush.throughput.lower.bound" and "hbase.hstore.flush.throughput.upper.bound", using the formula "lower + (upper - lower) * flushPressure", where flushPressure is in range [0.0, 1.0)
org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
org.apache.hadoop.hbase.util.PrettyPrinter
 
org.apache.hadoop.hbase.util.PrettyPrinter.Unit
 
org.apache.hadoop.hbase.io.hfile.PreviousBlockCompressionRatePredicator
This BlockCompressedSizePredicator implementation adjusts the block size limit based on the compression rate of the block contents read so far.
org.apache.hadoop.hbase.ipc.PriorityFunction
Function to figure priority of incoming request.
org.apache.hadoop.hbase.PrivateCellUtil
Utility methods helpful slinging Cell instances.
org.apache.hadoop.hbase.PrivateConstants
Constants intended to be used internally.
org.apache.hadoop.hbase.util.ProcessUtils
Process related utilities.
org.apache.hadoop.hbase.http.ProfileOutputServlet
Servlet to serve files generated by ProfileServlet
org.apache.hadoop.hbase.http.ProfileServlet
Servlet that runs async-profiler as web-endpoint.
org.apache.hadoop.hbase.http.ProfileServlet.DisabledServlet
 
org.apache.hadoop.hbase.http.prometheus.PrometheusHadoopServlet
 
org.apache.hadoop.hbase.conf.PropagatingConfigurationObserver
This extension to ConfigurationObserver allows the configuration to propagate to the children of the current ConfigurationObserver.
org.apache.hadoop.hbase.io.asyncfs.ProtobufDecoder
Modified based on io.netty.handler.codec.protobuf.ProtobufDecoder.
org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
Writer for protobuf-based WAL.
org.apache.hadoop.hbase.rest.ProtobufMessageHandler
Common interface for models capable of supporting protobuf marshalling and unmarshalling.
org.apache.hadoop.hbase.rest.ProtobufStreamingOutput
 
org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil
Protobufs utility.
org.apache.hadoop.hbase.regionserver.wal.ProtobufWALStreamReader
A one way stream reader for reading protobuf based WAL file.
org.apache.hadoop.hbase.regionserver.wal.ProtobufWALTailingReader
A WAL reader for replication.
org.apache.hadoop.hbase.http.ProxyUserAuthenticationFilter
This file has been copied directly (changing only the package name and and the ASF license text format, and adding the Yetus annotations) from Hadoop, as the Hadoop version that HBase depends on doesn't have it yet (as of 2020 Apr 24, there is no Hadoop release that has it either).
org.apache.hadoop.hbase.client.Put
Used to perform Put operations for a single row.
org.apache.hadoop.hbase.mapreduce.PutCombiner<K>
Combine Puts.
org.apache.hadoop.hbase.mapreduce.PutSortReducer
Emits sorted Puts.
org.apache.hadoop.hbase.ipc.QosPriority
Annotation which decorates RPC methods to denote the relative priority among other RPCs in the same server.
org.apache.hadoop.hbase.filter.QualifierFilter
This filter is used to filter based on the column qualifier.
org.apache.hadoop.hbase.client.Query
Base class for HBase read operations; e.g.
org.apache.hadoop.hbase.ipc.QueueBalancer
Interface for balancing requests across IPC queues
org.apache.hadoop.hbase.quotas.QuotaCache
Cache that keeps track of the quota settings for the users and tables that are interacting with it.
org.apache.hadoop.hbase.quotas.QuotaExceededException
Generic quota exceeded exception
org.apache.hadoop.hbase.quotas.QuotaFilter
Filter to use to filter the QuotaRetriever results.
org.apache.hadoop.hbase.quotas.QuotaLimiter
Internal interface used to interact with the user/table quota.
org.apache.hadoop.hbase.quotas.QuotaLimiterFactory
 
org.apache.hadoop.hbase.quotas.QuotaObserverChore
Reads the currently received Region filesystem-space use reports and acts on those which violate a defined quota.
org.apache.hadoop.hbase.quotas.QuotaRetriever
Scanner to iterate over the quota settings.
org.apache.hadoop.hbase.quotas.QuotaScope
Describe the Scope of the quota rules.
org.apache.hadoop.hbase.quotas.QuotaSettings
 
org.apache.hadoop.hbase.quotas.QuotaSettingsFactory
 
org.apache.hadoop.hbase.quotas.QuotaSnapshotStore<T>
A common interface for computing and storing space quota observance/violation for entities.
org.apache.hadoop.hbase.quotas.QuotaState
In-Memory state of table or namespace quotas
org.apache.hadoop.hbase.quotas.QuotaTableUtil
Helper class to interact with the quota table.
org.apache.hadoop.hbase.quotas.QuotaTableUtil.NamespaceQuotasVisitor
 
org.apache.hadoop.hbase.quotas.QuotaTableUtil.QuotasVisitor
 
org.apache.hadoop.hbase.quotas.QuotaTableUtil.TableQuotasVisitor
 
org.apache.hadoop.hbase.quotas.QuotaTableUtil.UserQuotasVisitor
 
org.apache.hadoop.hbase.quotas.QuotaType
Describe the Quota Type.
org.apache.hadoop.hbase.quotas.QuotaUtil
Helper class to interact with the quota table
org.apache.hadoop.hbase.master.RackManager
Wrapper over the rack resolution utility in Hadoop.
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.RandomDistribution
A class that generates random numbers that follow some distribution.
org.apache.hadoop.hbase.util.RandomDistribution.Binomial
Binomial distribution.
org.apache.hadoop.hbase.util.RandomDistribution.DiscreteRNG
Interface for discrete (integer) random distributions.
org.apache.hadoop.hbase.util.RandomDistribution.Flat
P(i)=1/(max-min)
org.apache.hadoop.hbase.util.RandomDistribution.Zipf
Zipf distribution.
org.apache.hadoop.hbase.ipc.RandomQueueBalancer
Queue balancer that just randomly selects a queue in the range [0, num queues).
org.apache.hadoop.hbase.filter.RandomRowFilter
A filter that includes rows based on a chance.
org.apache.hadoop.hbase.quotas.RateLimiter
Simple rate limiter.
org.apache.hadoop.hbase.types.RawByte
An DataType for interacting with values encoded using Bytes.putByte(byte[], int, byte).
org.apache.hadoop.hbase.types.RawBytes
An DataType for interacting with variable-length values encoded using Bytes.putBytes(byte[], int, byte[], int, int).
org.apache.hadoop.hbase.types.RawBytesFixedLength
An DataType that encodes fixed-length values encoded using Bytes.putBytes(byte[], int, byte[], int, int).
org.apache.hadoop.hbase.types.RawBytesTerminated
An DataType that encodes variable-length values encoded using Bytes.putBytes(byte[], int, byte[], int, int).
org.apache.hadoop.hbase.RawCell
An extended version of Cell that allows CPs manipulate Tags.
org.apache.hadoop.hbase.RawCellBuilder
Allows creating a cell with Tag An instance of this type can be acquired by using RegionCoprocessorEnvironment#getCellBuilder (for prod code) and RawCellBuilderFactory (for unit tests).
org.apache.hadoop.hbase.RawCellBuilderFactory
Factory for creating cells for CPs.
org.apache.hadoop.hbase.types.RawDouble
An DataType for interacting with values encoded using Bytes.putDouble(byte[], int, double).
org.apache.hadoop.hbase.types.RawFloat
An DataType for interacting with values encoded using Bytes.putFloat(byte[], int, float).
org.apache.hadoop.hbase.types.RawInteger
An DataType for interacting with values encoded using Bytes.putInt(byte[], int, int).
org.apache.hadoop.hbase.types.RawLong
An DataType for interacting with values encoded using Bytes.putLong(byte[], int, long).
org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
Query matcher for raw scan.
org.apache.hadoop.hbase.types.RawShort
An DataType for interacting with values encoded using Bytes.putShort(byte[], int, short).
org.apache.hadoop.hbase.types.RawString
An DataType for interacting with values encoded using Bytes.toBytes(String).
org.apache.hadoop.hbase.types.RawStringFixedLength
An DataType that encodes fixed-length values encoded using Bytes.toBytes(String).
org.apache.hadoop.hbase.types.RawStringTerminated
An DataType that encodes variable-length values encoded using Bytes.toBytes(String).
org.apache.hadoop.hbase.io.hfile.ReaderContext
Carries the information on some of the meta data about the HFile Reader
org.apache.hadoop.hbase.io.hfile.ReaderContext.ReaderType
 
org.apache.hadoop.hbase.io.hfile.ReaderContextBuilder
A builder that helps in building up the ReaderContext
org.apache.hadoop.hbase.util.ReadOnlyByteRangeException
Exception thrown when a read only byte range is modified
org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
Wraps a Configuration to make it read-only.
org.apache.hadoop.hbase.zookeeper.ReadOnlyZKClient
A very simple read only zookeeper implementation without watcher support.
org.apache.hadoop.hbase.regionserver.ReadPointCalculationLock
Lock to manage concurrency between RegionScanner and HRegion.getSmallestReadPoint().
org.apache.hadoop.hbase.regionserver.ReadPointCalculationLock.LockType
 
org.apache.hadoop.hbase.hbtop.Record
Represents a record of the metrics in the top screen.
org.apache.hadoop.hbase.hbtop.Record.Builder
 
org.apache.hadoop.hbase.hbtop.Record.Entry
 
org.apache.hadoop.hbase.hbtop.RecordFilter
Represents a filter that's filtering the metric Records.
org.apache.hadoop.hbase.hbtop.RecordFilter.FilterBuilder
 
org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
A zookeeper that can handle 'recoverable' errors.
org.apache.hadoop.hbase.util.RecoverLeaseFSUtils
Utility methods for recovering file lease for hdfs.
org.apache.hadoop.hbase.nio.RefCnt
Maintain an reference count integer inside to track life cycle of ByteBuff, if the reference count become 0, it'll call ByteBuffAllocator.Recycler.free() exactly once.
org.apache.hadoop.hbase.io.Reference
A reference to the top or bottom half of a store file where 'bottom' is the first half of the file containing the keys that sort lowest and 'top' is the second half of the file with keys that sort greater than those of the bottom half.
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.client.example.RefreshHFilesClient
This client class is for invoking the refresh HFile function deployed on the Region Server side via the RefreshHFilesService.
org.apache.hadoop.hbase.filter.RegexStringComparator
This comparator is for use with CompareFilter implementations, such as RowFilter, QualifierFilter, and ValueFilter, for filtering based on the value of a given column.
org.apache.hadoop.hbase.filter.RegexStringComparator.EngineType
Engine implementation type (default=JAVA)
org.apache.hadoop.hbase.regionserver.Region
Region is a subset of HRegion with operations required for the Coprocessors.
org.apache.hadoop.hbase.regionserver.Region.Operation
Operation enum is used in Region.startRegionOperation() and elsewhere to provide context for various checks.
org.apache.hadoop.hbase.regionserver.Region.RowLock
Row lock held by a given thread.
org.apache.hadoop.hbase.coprocessor.RegionCoprocessor
 
org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
 
org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
Implements the coprocessor environment and runtime support for coprocessors loaded within a Region.
org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
Represents a coprocessor service method execution against a single region.
org.apache.hadoop.hbase.RegionException
Thrown when something happens related to region handling.
org.apache.hadoop.hbase.wal.RegionGroupingProvider
A WAL Provider that returns a WAL per group of regions.
org.apache.hadoop.hbase.wal.RegionGroupingProvider.RegionGroupingStrategy
Map identifiers to a group number.
org.apache.hadoop.hbase.client.RegionInfo
Information about a region.
org.apache.hadoop.hbase.client.RegionInfoBuilder
 
org.apache.hadoop.hbase.client.RegionInfoDisplay
Utility used composing RegionInfo for 'display'; e.g.
org.apache.hadoop.hbase.client.RegionLoadStats
POJO representing region server load
org.apache.hadoop.hbase.RegionLocations
Container for holding a list of HRegionLocation's that correspond to the same range.
org.apache.hadoop.hbase.client.RegionLocator
Used to view region location information for a single HBase table.
org.apache.hadoop.hbase.RegionMetrics
Encapsulates per-region load metrics.
org.apache.hadoop.hbase.RegionMetricsBuilder
 
org.apache.hadoop.hbase.hbtop.mode.RegionModeStrategy
Implementation for ModeStrategy for Region Mode.
org.apache.hadoop.hbase.exceptions.RegionMovedException
Subclass if the server knows the region is now on another server.
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.coprocessor.RegionObserver
Coprocessors implement this interface to observe and mediate client actions on the region.
org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType
Mutation type for postMutationBeforeWAL hook
org.apache.hadoop.hbase.client.RegionOfflineException
Thrown when a table can not be located
org.apache.hadoop.hbase.exceptions.RegionOpeningException
Subclass if the server knows the region is now on another server.
org.apache.hadoop.hbase.master.RegionPlacementMaintainer
A tool that is used for manipulating and viewing favored nodes information for regions.
org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
Some algorithms for solving the assignment problem may traverse workers or jobs in linear order which may result in skewing the assignments of the first jobs in the matrix toward the last workers in the matrix if the costs are uniform.
org.apache.hadoop.hbase.master.RegionPlan
Stores the plan for the move of an individual region.
org.apache.hadoop.hbase.master.RegionPlan.RegionPlanComparator
 
org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationBufferManager
Manager the buffer size for all RegionReplicationSink.
org.apache.hadoop.hbase.regionserver.regionreplication.RegionReplicationSink
The class for replicating WAL edits to secondary replicas, one instance per region.
org.apache.hadoop.hbase.client.RegionReplicaUtil
Utility methods which contain the logic for regions and replicas.
org.apache.hadoop.hbase.regionserver.RegionScanner
RegionScanner describes iterators over rows in an HRegion.
org.apache.hadoop.hbase.regionserver.RegionServerAbortedException
Thrown by the region server when it is aborting.
org.apache.hadoop.hbase.regionserver.RegionServerAccounting
RegionServerAccounting keeps record of some basic real time information about the Region Server.
org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessor
 
org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
 
org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
 
org.apache.hadoop.hbase.client.RegionServerCoprocessorRpcChannelImpl
The implementation of a region server based coprocessor rpc channel.
org.apache.hadoop.hbase.master.RegionServerList
For storing the region server list.
org.apache.hadoop.hbase.hbtop.mode.RegionServerModeStrategy
Implementation for ModeStrategy for RegionServer Mode.
org.apache.hadoop.hbase.coprocessor.RegionServerObserver
Defines coprocessor hooks for interacting with operations on the HRegionServer process.
org.apache.hadoop.hbase.quotas.RegionServerRpcQuotaManager
Region Server Quota Manager.
org.apache.hadoop.hbase.regionserver.RegionServerRunningException
Thrown if the region server log directory exists (which indicates another region server is running at the same address)
org.apache.hadoop.hbase.regionserver.RegionServerServices
A curated subset of services provided by HRegionServer.
org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
Context for postOpenDeployTasks().
org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
 
org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
A manager for filesystem space quotas in the RegionServer.
org.apache.hadoop.hbase.regionserver.RegionServerStoppedException
Thrown by the region server when it is in shutting down state.
org.apache.hadoop.hbase.master.RegionServerTracker
Tracks the online region servers via ZK.
org.apache.hadoop.hbase.regionserver.RegionServicesForStores
Services a Store needs from a Region.
org.apache.hadoop.hbase.quotas.RegionSize
Interface that encapsulates optionally sending a Region's size to the master.
org.apache.hadoop.hbase.mapreduce.RegionSizeCalculator
Computes size of each region for given table and given column families.
org.apache.hadoop.hbase.quotas.RegionSizeImpl
An object encapsulating a Region's size and whether it's been reported to the master since the value last changed.
org.apache.hadoop.hbase.quotas.RegionSizeReportingChore
A Chore which sends the region size reports on this RegionServer to the Master.
org.apache.hadoop.hbase.quotas.RegionSizeStore
An interface for concurrently storing and updating the size of a Region.
org.apache.hadoop.hbase.quotas.RegionSizeStoreFactory
A factory class for creating implementations of RegionSizeStore.
org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
A RegionSizeStore implementation backed by a ConcurrentHashMap.
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.regionserver.RegionSplitPolicy
A split policy determines when a Region should be split.
org.apache.hadoop.hbase.regionserver.RegionSplitRestriction
A split restriction that restricts the pattern of the split point.
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.master.RegionsRecoveryChore
This chore, every time it runs, will try to recover regions with high store ref count by reopening them
org.apache.hadoop.hbase.master.RegionsRecoveryConfigManager
Config manager for RegionsRecovery Chore - Dynamically reload config and update chore accordingly
org.apache.hadoop.hbase.rest.RegionsResource
 
org.apache.hadoop.hbase.master.RegionState
State of a Region while undergoing transitions.
org.apache.hadoop.hbase.master.RegionState.State
 
org.apache.hadoop.hbase.RegionStateListener
The listener interface for receiving region state events.
org.apache.hadoop.hbase.client.RegionStatesCount
 
org.apache.hadoop.hbase.client.RegionStatesCount.RegionStatesCountBuilder
 
org.apache.hadoop.hbase.RegionTooBusyException
Thrown by a region server if it will block and wait to serve a request.
org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
A RemoteException with some extra information.
org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat
Helper class for storing replication barriers in family 'rep_barrier' of meta table.
org.apache.hadoop.hbase.replication.ReplicationBarrierFamilyFormat.ReplicationBarrierResult
 
org.apache.hadoop.hbase.util.hbck.ReplicationChecker
Check and fix undeleted replication queues for removed peerId.
org.apache.hadoop.hbase.replication.ReplicationEndpoint
ReplicationEndpoint is a plugin which implements replication to other HBase clusters, or other systems.
org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
 
org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
A context for ReplicationEndpoint.replicate(ReplicateContext) method.
org.apache.hadoop.hbase.replication.ReplicationException
An HBase Replication exception.
org.apache.hadoop.hbase.replication.ReplicationFactory
A factory class for instantiating replication objects that deal with replication state.
org.apache.hadoop.hbase.replication.ReplicationGroupOffset
 
org.apache.hadoop.hbase.replication.ReplicationListener
The replication listener interface can be implemented if a class needs to subscribe to events generated by the ReplicationTracker.
org.apache.hadoop.hbase.replication.ReplicationLoadSink
A HBase ReplicationLoad to present MetricsSink information
org.apache.hadoop.hbase.replication.ReplicationLoadSink.ReplicationLoadSinkBuilder
 
org.apache.hadoop.hbase.replication.ReplicationLoadSource
A HBase ReplicationLoad to present MetricsSource information
org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
 
org.apache.hadoop.hbase.replication.ReplicationOffsetUtil
 
org.apache.hadoop.hbase.replication.ReplicationPeer
ReplicationPeer manages enabled / disabled state for the peer.
org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
State of the peer, whether it is enabled or not
org.apache.hadoop.hbase.replication.ReplicationPeerConfig
A configuration for the replication peer cluster.
org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
For creating ReplicationPeerConfig.
org.apache.hadoop.hbase.replication.ReplicationPeerConfigListener
 
org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
Helper for TableCFs Operations.
org.apache.hadoop.hbase.replication.ReplicationPeerDescription
The POJO equivalent of ReplicationProtos.ReplicationPeerDescription.
org.apache.hadoop.hbase.replication.ReplicationPeerImpl
 
org.apache.hadoop.hbase.ReplicationPeerNotFoundException
Thrown when a replication peer can not be found
org.apache.hadoop.hbase.replication.ReplicationPeers
This provides an class for maintaining a set of peer clusters.
org.apache.hadoop.hbase.replication.ReplicationPeerStorage
Perform read/write to the replication peer storage.
org.apache.hadoop.hbase.replication.ReplicationPeerStorageType
Specify the implementations for ReplicationPeerStorage.
org.apache.hadoop.hbase.replication.ReplicationQueueData
Representing all the information for a replication queue.
org.apache.hadoop.hbase.replication.ReplicationQueueId
 
org.apache.hadoop.hbase.replication.ReplicationQueueInfo
This class is responsible for the parsing logic for a queue id representing a queue.
org.apache.hadoop.hbase.replication.ReplicationQueueStorage
Perform read/write to the replication queue storage.
org.apache.hadoop.hbase.regionserver.ReplicationService
Gateway to Cluster Replication.
org.apache.hadoop.hbase.regionserver.ReplicationSinkService
A sink for a replication stream has to expose this service.
org.apache.hadoop.hbase.replication.ReplicationSinkServiceImpl
 
org.apache.hadoop.hbase.regionserver.ReplicationSourceService
A source for a replication stream has to expose this service.
org.apache.hadoop.hbase.replication.ReplicationStorageFactory
Used to create replication storage(peer, queue) classes.
org.apache.hadoop.hbase.replication.ReplicationUtils
Helper class for replication.
org.apache.hadoop.hbase.client.RequestController
An interface for client request scheduling algorithm.
org.apache.hadoop.hbase.client.RequestController.Checker
Picks up the valid data.
org.apache.hadoop.hbase.client.RequestController.ReturnCode
 
org.apache.hadoop.hbase.client.RequestControllerFactory
A factory class that constructs an RequestController.
org.apache.hadoop.hbase.shaded.protobuf.RequestConverter
Helper utility to build protocol buffer requests, or build components for protocol buffer requests.
org.apache.hadoop.hbase.hbtop.mode.RequestCountPerSecond
Utility class for calculating request counts per second.
org.apache.hadoop.hbase.exceptions.RequestTooBigException
Thrown when the size of the rpc request received by the server is too large.
org.apache.hadoop.hbase.util.ReservoirSample<T>
The simple version of reservoir sampling implementation.
org.apache.hadoop.hbase.io.hfile.ResizableBlockCache
BlockCache which is resizable.
org.apache.hadoop.hbase.rest.ResourceBase
 
org.apache.hadoop.hbase.rest.client.Response
The HTTP result code, response headers, and body of an HTTP response.
org.apache.hadoop.hbase.shaded.protobuf.ResponseConverter
Helper utility to build protocol buffer responses, or retrieve data from protocol buffer responses.
org.apache.hadoop.hbase.http.jersey.ResponseEntityMapper
Generate a uniform response wrapper around the Entity returned from the resource.
org.apache.hadoop.hbase.rest.RESTDumpServlet
 
org.apache.hadoop.hbase.backup.RestoreDriver
Command-line entry point for restore operation
org.apache.hadoop.hbase.backup.RestoreJob
Restore operation job interface Concrete implementation is provided by backup provider, see BackupRestoreFactory
org.apache.hadoop.hbase.backup.RestoreRequest
POJO class for restore request
org.apache.hadoop.hbase.backup.RestoreRequest.Builder
 
org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
Thrown when a snapshot could not be restored due to a server-side error when restoring it.
org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
Helper to Restore/Clone a Snapshot
org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
Describe the set of operations needed to update hbase:meta after restore.
org.apache.hadoop.hbase.rest.RESTServer
Main class for launching REST gateway as a servlet hosted by Jetty.
org.apache.hadoop.hbase.rest.RESTServlet
Singleton class encapsulating global REST servlet state and functions.
org.apache.hadoop.hbase.rest.RESTServletContainer
REST servlet container.
org.apache.hadoop.hbase.rest.RestUtil
 
org.apache.hadoop.hbase.client.Result
Single row result of a Get or Scan query.
org.apache.hadoop.hbase.rest.ResultGenerator
 
org.apache.hadoop.hbase.client.ResultScanner
Interface for client-side scanning.
org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
org.apache.hadoop.hbase.client.ResultStatsUtil
Statistics update about a server/region
org.apache.hadoop.hbase.client.RetriesExhaustedException
Exception thrown by HTable methods when an attempt to do something (like commit changes) fails after a bunch of retries.
org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
Data structure that allows adding more info around Throwable incident.
org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
This subclass of RetriesExhaustedException is thrown when we have more information about which rows were causing which exceptions on what servers.
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.RetryImmediatelyException
 
org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec
Fixes an inefficiency in Hadoop's Gzip codec, allowing to reuse compression streams.
org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
A bridge that wraps around a DeflaterOutputStream to make it a CompressionOutputStream.
org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
ReversedKeyValueHeap is used for supporting reversed scanning.
org.apache.hadoop.hbase.regionserver.ReversedMobStoreScanner
ReversedMobStoreScanner extends from ReversedStoreScanner, and is used to support reversed scanning in both the memstore and the MOB store.
org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
ReversedStoreScanner extends from StoreScanner, and is used to support reversed scanning.
org.apache.hadoop.hbase.util.RollingStatCalculator
This class maintains mean and variation for any sequence of input provided to it.
org.apache.hadoop.hbase.rest.RootResource
 
org.apache.hadoop.hbase.util.RotateFile
A file storage which supports atomic update through two files, i.e, rotating.
org.apache.hadoop.hbase.mapreduce.RoundRobinTableInputFormat
Process the return from super-class TableInputFormat (TIF) so as to undo any clumping of InputSplits around RegionServers.
org.apache.hadoop.hbase.client.Row
Has a row.
org.apache.hadoop.hbase.client.RowAccess<T>
Provide a way to access the inner buffer.
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.mapred.RowCounter
A job with a map to count rows.
org.apache.hadoop.hbase.mapreduce.RowCounter
A job with a just a map phase to count rows.
org.apache.hadoop.hbase.filter.RowFilter
This filter is used to filter based on the key.
org.apache.hadoop.hbase.io.encoding.RowIndexCodecV1
Store cells following every row's start offset, so we can binary search to a row's cells.
org.apache.hadoop.hbase.io.encoding.RowIndexEncoderV1
 
org.apache.hadoop.hbase.io.encoding.RowIndexSeekerV1
 
org.apache.hadoop.hbase.client.RowMutations
Performs multiple mutations atomically on a single row.
org.apache.hadoop.hbase.util.RowPrefixFixedLengthBloomContext
Handles ROWPREFIX bloom related context.
org.apache.hadoop.hbase.rest.RowResource
 
org.apache.hadoop.hbase.rest.RowResultGenerator
 
org.apache.hadoop.hbase.rest.RowSpec
Parses a path based row/column/timestamp specification into its component elements.
org.apache.hadoop.hbase.client.RowTooBigException
Gets or Scans throw this exception if running without in-row scan flag set and row size appears to exceed max configured size (configurable via hbase.table.max.rowsize).
org.apache.hadoop.hbase.regionserver.RowTooBigException
Deprecated.
since 0.99.0.
org.apache.hadoop.hbase.ipc.RpcCall
Interface of all necessary to carry out a RPC method invocation on the server.
org.apache.hadoop.hbase.ipc.RpcCallback
Denotes a callback action that has to be executed at the end of an Rpc Call.
org.apache.hadoop.hbase.ipc.RpcCallContext
Interface of all necessary to carry out a RPC service invocation on the server.
org.apache.hadoop.hbase.ipc.RpcClient
Interface for RpcClient implementations so ConnectionManager can handle it.
org.apache.hadoop.hbase.ipc.RpcClientFactory
Factory to create a RpcClient
org.apache.hadoop.hbase.ipc.RpcConnectionConstants
Constants to be used by RPC connection based utilities.
org.apache.hadoop.hbase.client.RpcConnectionRegistry
Rpc based connection registry.
org.apache.hadoop.hbase.client.RpcConnectionRegistryURIFactory
Connection registry creator implementation for creating RpcConnectionRegistry.
org.apache.hadoop.hbase.ipc.RpcControllerFactory
Factory to create a HBaseRpcController
org.apache.hadoop.hbase.ipc.RpcExecutor
Runs the CallRunners passed here via RpcExecutor.dispatch(CallRunner).
org.apache.hadoop.hbase.ipc.RpcHandler
Thread to handle rpc call.
org.apache.hadoop.hbase.namequeues.RpcLogDetails
RpcCall details that would be passed on to ring buffer of slow log responses
org.apache.hadoop.hbase.quotas.RpcQuotaManager
 
org.apache.hadoop.hbase.ipc.RpcScheduler
An interface for RPC request scheduling algorithm.
org.apache.hadoop.hbase.ipc.RpcScheduler.Context
Exposes runtime information of a RpcServer that a RpcScheduler may need.
org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory
A factory class that constructs an RpcScheduler.
org.apache.hadoop.hbase.ipc.RpcServer
An RPC server that hosts protobuf described Services.
org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
Datastructure for passing a BlockingService and its associated class of protobuf service interface.
org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup
 
org.apache.hadoop.hbase.ipc.RpcServerFactory
 
org.apache.hadoop.hbase.ipc.RpcServerInterface
 
org.apache.hadoop.hbase.quotas.RpcThrottleStorage
ZK based rpc throttle storage.
org.apache.hadoop.hbase.quotas.RpcThrottlingException
Describe the throttling result.
org.apache.hadoop.hbase.quotas.RpcThrottlingException.Type
 
org.apache.hadoop.hbase.regionserver.http.RSDumpServlet
 
org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
Deprecated.
Keep it here only for tests, using Admin instead.
org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
Deprecated.
Keep it here only for compatibility with old client, all the logics have been moved into core of HBase.
org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
GroupBasedLoadBalancer, used when Region Server Grouping is configured (HBase-6721) It does region balance based on a table's group membership.
org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Stores the group information of region server groups.
org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
Interface used to manage RSGroupInfo storage.
org.apache.hadoop.hbase.rsgroup.RSGroupMajorCompactionTTL
This script takes an rsgroup as argument and compacts part/all of regions of that table based on the table's TTL.
org.apache.hadoop.hbase.rsgroup.RSGroupUtil
Helper class for RSGroup implementation
org.apache.hadoop.hbase.mob.RSMobFileCleanerChore
The class RSMobFileCleanerChore for running cleaner regularly to remove the obsolete (files which have no active references to) mob files that were referenced from the current RS.
org.apache.hadoop.hbase.regionserver.RSRpcServices
Implements the regionserver RPC services.
org.apache.hadoop.hbase.regionserver.RSSnapshotVerifier
Used by SnapshotVerifyProcedure to verify if the region info and store file info in RegionManifest are intact.
org.apache.hadoop.hbase.regionserver.http.RSStatusServlet
 
org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
RPC Executor that uses different queues for reads and writes.
org.apache.hadoop.hbase.mapreduce.SampleUploader
Sample Uploader MapReduce
org.apache.hadoop.hbase.security.SaslChallengeDecoder
Decode the sasl challenge sent by RpcServer.
org.apache.hadoop.hbase.security.SaslStatus
 
org.apache.hadoop.hbase.security.SaslUnwrapHandler
Unwrap sasl messages.
org.apache.hadoop.hbase.security.SaslUnwrapHandler.Unwrapper
 
org.apache.hadoop.hbase.security.SaslUtil
 
org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
 
org.apache.hadoop.hbase.security.SaslWrapHandler
wrap sasl messages.
org.apache.hadoop.hbase.security.SaslWrapHandler.Wrapper
 
org.apache.hadoop.hbase.client.Scan
Used to perform Scan operations.
org.apache.hadoop.hbase.client.Scan.ReadType
 
org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
This class is responsible for the tracking and enforcement of Deletes during the course of a Scan operation.
org.apache.hadoop.hbase.regionserver.ScanInfo
Immutable information for scans over a store.
org.apache.hadoop.hbase.regionserver.ScannerContext
ScannerContext instances encapsulate limit tracking AND progress towards those limits during invocations of InternalScanner.next(java.util.List) and InternalScanner.next(java.util.List).
org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
 
org.apache.hadoop.hbase.regionserver.ScannerContext.LimitScope
The various scopes where a limit can be enforced.
org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
The possible states a scanner may be in following a call to InternalScanner.next(List)
org.apache.hadoop.hbase.regionserver.ScannerIdGenerator
Generate a new style scanner id to prevent collision with previous started server or other RSs.
org.apache.hadoop.hbase.rest.ScannerInstanceResource
 
org.apache.hadoop.hbase.exceptions.ScannerResetException
Thrown when the server side has received an Exception, and asks the Client to reset the scanner state by closing the current region scanner, and reopening from the start of last seen row.
org.apache.hadoop.hbase.rest.ScannerResource
 
org.apache.hadoop.hbase.rest.ScannerResultGenerator
 
org.apache.hadoop.hbase.regionserver.ScanOptions
This class gives you the ability to change the max versions and TTL options before opening a scanner for a Store.
org.apache.hadoop.hbase.ScanPerformanceEvaluation
A simple performance evaluation tool for single client and MR scans and snapshot scans.
org.apache.hadoop.hbase.ScanPerformanceEvaluation.MyMapper<KEYOUT,VALUEOUT>
 
org.apache.hadoop.hbase.ScanPerformanceEvaluation.ScanCounter
 
org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
A query matcher that is specifically designed for the scan case.
org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
ScanQueryMatcher.match(org.apache.hadoop.hbase.ExtendedCell) return codes.
org.apache.hadoop.hbase.client.ScanResultConsumer
Receives Result for an asynchronous scan.
org.apache.hadoop.hbase.client.ScanResultConsumerBase
The base interface for scan result consumer.
org.apache.hadoop.hbase.regionserver.ScanType
Enum to distinguish general scan types.
org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
Keeps track of the columns for a scan if they are not explicitly specified
org.apache.hadoop.hbase.ScheduledChore
ScheduledChore is a task performed on a period in hbase.
org.apache.hadoop.hbase.rest.SchemaResource
 
org.apache.hadoop.hbase.replication.ScopeWALEntryFilter
Keeps KVs that are scoped other than local
org.apache.hadoop.hbase.hbtop.screen.Screen
This dispatches key presses and timers to the current ScreenView.
org.apache.hadoop.hbase.hbtop.terminal.impl.ScreenBuffer
Represents a buffer of the terminal screen for double-buffering.
org.apache.hadoop.hbase.hbtop.screen.ScreenView
An interface for a screen view that handles key presses and timers.
org.apache.hadoop.hbase.regionserver.SecureBulkLoadManager
Bulk loads in secure mode.
org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
A WALCellCodec that encrypts the WALedits.
org.apache.hadoop.hbase.client.security.SecurityCapability
Available security capabilities
org.apache.hadoop.hbase.security.SecurityConstants
SecurityConstants holds a bunch of kerberos-related constants
org.apache.hadoop.hbase.http.SecurityHeadersFilter
 
org.apache.hadoop.hbase.security.SecurityInfo
Maps RPC protocol interfaces to required configuration
org.apache.hadoop.hbase.ipc.SecurityNotEnabledException
Will be thrown when server received a security preamble call for asking the server principal but security is not enabled for this server.
org.apache.hadoop.hbase.security.SecurityUtil
Security related generic utility methods.
org.apache.hadoop.hbase.regionserver.Segment
This is an abstraction of a segment maintained in a memstore, e.g., the active cell set or its snapshot.
org.apache.hadoop.hbase.regionserver.SegmentFactory
A singleton store segment factory.
org.apache.hadoop.hbase.regionserver.SegmentScanner
A scanner of a single memstore segment.
org.apache.hadoop.hbase.regionserver.SequenceId
Interface which abstracts implementations on log sequenceId assignment
org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting
Accounting of sequence ids per region and then by column family.
org.apache.hadoop.hbase.Server
Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).
org.apache.hadoop.hbase.ipc.ServerCall<T extends org.apache.hadoop.hbase.ipc.ServerRpcConnection>
Datastructure that holds all necessary to a method invocation and then afterward, carries the result.
org.apache.hadoop.hbase.util.ServerCommandLine
Base class for command lines that start up various HBase daemons.
org.apache.hadoop.hbase.http.ServerConfigurationKeys
This interface contains constants for configuration keys used in the hbase http server code.
org.apache.hadoop.hbase.master.ServerListener
Get notification of server registration events.
org.apache.hadoop.hbase.master.ServerManager
The ServerManager class manages info about region servers.
org.apache.hadoop.hbase.master.ServerManager.ServerLiveState
 
org.apache.hadoop.hbase.ServerMetrics
This class is used for exporting current state of load on a RegionServer.
org.apache.hadoop.hbase.ServerMetricsBuilder
 
org.apache.hadoop.hbase.ServerName
Name of a particular incarnation of an HBase Server.
org.apache.hadoop.hbase.regionserver.ServerNonceManager
Implementation of nonce manager that stores nonces in a hash map and cleans them up after some time; if nonce group/client ID is supplied, nonces are stored by client ID.
org.apache.hadoop.hbase.ipc.ServerNotRunningYetException
 
org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
Similar to RegionReplicaUtil but for the server side
org.apache.hadoop.hbase.ipc.ServerRpcController
Used for server-side protobuf RPC service invocations.
org.apache.hadoop.hbase.client.backoff.ServerStatistics
Track the statistics for a single region
org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
 
org.apache.hadoop.hbase.client.ServerStatisticTracker
Tracks the statistics for multiple regions
org.apache.hadoop.hbase.ServerTask
Information about active monitored server tasks
org.apache.hadoop.hbase.ServerTask.State
Task state
org.apache.hadoop.hbase.ServerTaskBuilder
Builder for information about active monitored server tasks
org.apache.hadoop.hbase.ipc.ServerTooBusyException
Throw this in RPC call if there are too many pending requests for one region server
org.apache.hadoop.hbase.client.ServerType
Select server type i.e destination for RPC request associated with ring buffer.
org.apache.hadoop.hbase.client.ServiceCaller<S,R>
Delegate to a protobuf rpc call.
org.apache.hadoop.hbase.ServiceNotRunningException
 
org.apache.hadoop.hbase.client.SharedAsyncConnection
Wraps a AsyncConnection to make it can't be closed.
org.apache.hadoop.hbase.client.SharedConnection
Wraps a Connection to make it can't be closed or aborted.
org.apache.hadoop.hbase.io.hfile.SharedMemHFileBlock
The ByteBuffAllocator won't allocate pooled heap ByteBuff now; at the same time, if allocate an off-heap ByteBuff from allocator, then it must be a pooled one.
org.apache.hadoop.hbase.regionserver.Shipper
This interface denotes a scanner as one which can ship cells.
org.apache.hadoop.hbase.regionserver.ShipperListener
Implementors of this interface are the ones who needs to do some action when the Shipper.shipped() is called
org.apache.hadoop.hbase.regionserver.ShutdownHook
Manage regionserver shutdown hooks.
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.ipc.SimpleRpcScheduler
The default scheduler.
org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
Constructs a SimpleRpcScheduler.
org.apache.hadoop.hbase.ipc.SimpleRpcServer
Deprecated.
org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner<VALUE>
A partitioner that takes start and end keys and uses bigdecimal to figure which reduce a key belongs to.
org.apache.hadoop.hbase.nio.SingleByteBuff
An implementation of ByteBuff where a single BB backs the BBI.
org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
A Filter that checks a single column value, but does not emit the tested column.
org.apache.hadoop.hbase.filter.SingleColumnValueFilter
This filter is used to filter cells based on value.
org.apache.hadoop.hbase.client.SingleResponse
Class for single action response
org.apache.hadoop.hbase.client.SingleResponse.Entry
 
org.apache.hadoop.hbase.Size
It is used to represent the size with different units.
org.apache.hadoop.hbase.Size.Unit
 
org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
This Cell is an implementation of ByteBufferExtendedCell where the data resides in off heap/ on heap ByteBuffer
org.apache.hadoop.hbase.SizeCachedKeyValue
This class is an extension to KeyValue where rowLen and keyLen are cached.
org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
This Cell is an implementation of ByteBufferExtendedCell where the data resides in off heap/ on heap ByteBuffer
org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
This class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.
org.apache.hadoop.hbase.io.SizedExtendedCellScanner
A CellScanner that knows its size in memory in bytes.
org.apache.hadoop.hbase.filter.SkipFilter
A wrapper filter that filters an entire row if any of the Cell checks do not pass.
org.apache.hadoop.hbase.util.Sleeper
Sleeper for current thread.
org.apache.hadoop.hbase.client.SlowLogParams
SlowLog params object that contains detailed info as params and region name : to be used for filter purpose
org.apache.hadoop.hbase.namequeues.SlowLogPersistentService
Persistent service provider for Slow/LargeLog events
org.apache.hadoop.hbase.namequeues.impl.SlowLogQueueService
In-memory Queue service provider for Slow/LargeLog events
org.apache.hadoop.hbase.slowlog.SlowLogTableAccessor
Slowlog Accessor to record slow/large RPC log identified at each RegionServer RpcServer level.
org.apache.hadoop.hbase.metrics.Snapshot
A statictical sample of histogram values.
org.apache.hadoop.hbase.snapshot.SnapshotCreationException
Thrown when a snapshot could not be created due to a server-side error when taking the snapshot.
org.apache.hadoop.hbase.client.SnapshotDescription
The POJO equivalent of HBaseProtos.SnapshotDescription
org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
Utility class to help manage SnapshotDesriptions.
org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter
Filter that only accepts completed snapshot directories
org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
Thrown when the server is looking for a snapshot, but can't find the snapshot on the filesystem.
org.apache.hadoop.hbase.snapshot.SnapshotExistsException
Thrown when a snapshot exists, but should not.
org.apache.hadoop.hbase.snapshot.SnapshotInfo
Tool for dumping snapshot information.
org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Statistics about the snapshot How many store files and logs are in the archive How many store files and logs are shared with the table Total store files and logs size and shared amount
org.apache.hadoop.hbase.snapshot.SnapshotManifest
Utility class to help read/write the Snapshot Manifest.
org.apache.hadoop.hbase.snapshot.SnapshotManifestV1
DO NOT USE DIRECTLY.
org.apache.hadoop.hbase.snapshot.SnapshotManifestV2
DO NOT USE DIRECTLY.
org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
Used internally for reading meta and constructing datastructures that are then queried, for things like regions to regionservers, table to regions, etc.
org.apache.hadoop.hbase.quotas.SnapshotQuotaObserverChore
A Master-invoked Chore that computes the size of each snapshot which was created from a table which has a space quota.
org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
Utility methods for interacting with the snapshot referenced files.
org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil.SnapshotVisitor
 
org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil.StoreFileVisitor
 
org.apache.hadoop.hbase.regionserver.SnapshotRegionCallable
 
org.apache.hadoop.hbase.regionserver.SnapshotSegmentScanner
A basic SegmentScanner used against an ImmutableScanner snapshot Used flushing where we do a single pass, no reverse scanning or inserts happening.
org.apache.hadoop.hbase.master.SnapshotSentinel
Watch the current snapshot under process
org.apache.hadoop.hbase.snapshot.SnapshotTTLExpiredException
Thrown when a snapshot could not be restored/cloned because the ttl for snapshot has already expired
org.apache.hadoop.hbase.client.SnapshotType
POJO representing the snapshot type
org.apache.hadoop.hbase.regionserver.SnapshotVerifyCallable
 
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.quotas.SpaceLimitingException
An Exception that is thrown when a space quota is in violation.
org.apache.hadoop.hbase.quotas.SpaceQuotaRefresherChore
A ScheduledChore which periodically updates the RegionServerSpaceQuotaManager with information from the hbase:quota.
org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot
A point-in-time view of a space quota on a table.
org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot.SpaceQuotaStatus
Encapsulates the state of a quota on a table.
org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifier
An interface which abstract away the action taken to enable or disable a space quota violation policy across the HBase cluster.
org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotNotifierFactory
Factory for creating SpaceQuotaSnapshotNotifier implementations.
org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView
A point-in-time view of a space quota on a table, read only.
org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshotView.SpaceQuotaStatusView
Encapsulates the state of a quota on a table.
org.apache.hadoop.hbase.quotas.SpaceViolationPolicy
Enumeration that represents the action HBase will take when a space quota is violated.
org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
RegionServer implementation of SpaceViolationPolicy.
org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementFactory
A factory class for instantiating SpaceViolationPolicyEnforcement instances.
org.apache.hadoop.hbase.SplitLogCounters
Deprecated.
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALManager
org.apache.hadoop.hbase.master.SplitLogManager
Deprecated.
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALManager.
org.apache.hadoop.hbase.master.SplitLogManager.ResubmitDirective
 
org.apache.hadoop.hbase.master.SplitLogManager.Task
in memory state of an active task.
org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
Keeps track of the batch of tasks submitted together by a caller in splitLogDistributed().
org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
 
org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
Deprecated.
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALManager
org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
Detail class that shares data between coordination and split log manager
org.apache.hadoop.hbase.SplitLogTask
Deprecated.
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALManager
org.apache.hadoop.hbase.SplitLogTask.Done
 
org.apache.hadoop.hbase.SplitLogTask.Err
 
org.apache.hadoop.hbase.SplitLogTask.Owned
 
org.apache.hadoop.hbase.SplitLogTask.Resigned
 
org.apache.hadoop.hbase.SplitLogTask.Unassigned
 
org.apache.hadoop.hbase.regionserver.SplitLogWorker
Deprecated.
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALRemoteProcedure
org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor
Objects implementing this interface actually do the task that has been acquired by a SplitLogWorker.
org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
 
org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
Deprecated.
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter, see SplitWALManager
org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination.SplitTaskDetails
Interface for log-split tasks Used to carry implementation details in encapsulated way through Handlers to the coordination API.
org.apache.hadoop.hbase.master.SplitOrMergeStateStore
Tracks the switch of split and merge states.
org.apache.hadoop.hbase.regionserver.SplitWALCallable
This callable is used to do the real split WAL task.
org.apache.hadoop.hbase.regionserver.SplitWALCallable.ErrorWALSplitException
 
org.apache.hadoop.hbase.regionserver.SplitWALCallable.PreemptedWALSplitException
 
org.apache.hadoop.hbase.regionserver.SplitWALCallable.ResignedWALSplitException
 
org.apache.hadoop.hbase.master.SplitWALManager
Create SplitWALProcedure for each WAL which need to split.
org.apache.hadoop.hbase.exceptions.SSLContextException
 
org.apache.hadoop.hbase.SslRMIClientSocketFactorySecure
Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
org.apache.hadoop.hbase.SslRMIServerSocketFactorySecure
Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
org.apache.hadoop.hbase.StartMiniClusterOption
Deprecated.
since 3.0.0, will be removed in 4.0.0.
org.apache.hadoop.hbase.StartMiniClusterOption.Builder
Builder pattern for creating an StartMiniClusterOption.
org.apache.hadoop.hbase.http.lib.StaticUserWebFilter
Provides a servlet filter that pretends to authenticate a fake user (Dr.Who) so that the web UI is usable for a secure cluster without authentication.
org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
 
org.apache.hadoop.hbase.client.StatisticTrackable
Parent interface for an object to get updates about per-region statistics.
org.apache.hadoop.hbase.util.StealJobQueue<T>
This queue allows a ThreadPoolExecutor to steal jobs from another ThreadPoolExecutor.
org.apache.hadoop.hbase.regionserver.SteppingSplitPolicy
 
org.apache.hadoop.hbase.Stoppable
Implementers are Stoppable.
org.apache.hadoop.hbase.ipc.StoppedRpcClientException
 
org.apache.hadoop.hbase.rest.StorageClusterStatusResource
 
org.apache.hadoop.hbase.rest.StorageClusterVersionResource
 
org.apache.hadoop.hbase.regionserver.Store
Interface for objects that hold a column family in a Region.
org.apache.hadoop.hbase.regionserver.StoreConfigInformation
A more restricted interface for HStore.
org.apache.hadoop.hbase.regionserver.StoreContext
This carries the immutable information and references on some of the meta data about the HStore.
org.apache.hadoop.hbase.regionserver.StoreContext.Builder
 
org.apache.hadoop.hbase.regionserver.StoreEngine<SF extends org.apache.hadoop.hbase.regionserver.StoreFlusher,CP extends org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy,C extends org.apache.hadoop.hbase.regionserver.compactions.Compactor<?>,SFM extends org.apache.hadoop.hbase.regionserver.StoreFileManager>
StoreEngine is a factory that can create the objects necessary for HStore to operate.
org.apache.hadoop.hbase.regionserver.StoreFile
An interface to describe a store data file.
org.apache.hadoop.hbase.regionserver.StoreFileInfo
Describe a StoreFile (hfile, reference, link)
org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileListFilePrettyPrinter
 
org.apache.hadoop.hbase.regionserver.StoreFileManager
Manages the store files and basic metadata about that that determines the logical structure (e.g.
org.apache.hadoop.hbase.regionserver.StoreFileReader
Reader for a StoreFile.
org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
A chore for refreshing the store files for secondary regions hosted in the region server.
org.apache.hadoop.hbase.regionserver.StoreFileScanner
KeyValueScanner adaptor over the Reader.
org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
An interface to define how we track the store files for a give store.
org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory
Factory method for creating store file tracker.
org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerFactory.Trackers
Maps between configuration names for trackers and implementation classes.
org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerValidationUtils
 
org.apache.hadoop.hbase.regionserver.StoreFileWriter
A StoreFile writer.
org.apache.hadoop.hbase.regionserver.StoreFileWriter.Builder
 
org.apache.hadoop.hbase.regionserver.throttle.StoreHotnessProtector
StoreHotnessProtector is designed to help limit the concurrency of puts with dense columns, it does best-effort to avoid exhausting all RS's handlers.
org.apache.hadoop.hbase.regionserver.StoreScanner
Scanner scans both the memstore and the Store.
org.apache.hadoop.hbase.regionserver.StoreUtils
Utility functions for region server storage layer.
org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
Class for monitor the wal file flush performance.
org.apache.hadoop.hbase.io.util.StreamUtils
 
org.apache.hadoop.hbase.util.Strings
Utility for Strings.
org.apache.hadoop.hbase.regionserver.querymatcher.StripeCompactionScanQueryMatcher
Query matcher for stripe compaction if range drop deletes is used.
org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
Base class for cell sink that separates the provided cells into multiple files for stripe compaction.
org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
MultiWriter that separates the cells based on fixed row-key boundaries.
org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
MultiWriter that separates the cells based on target cell number per file and file count.
org.apache.hadoop.hbase.regionserver.StripeStoreConfig
Configuration class for stripe store and compactions.
org.apache.hadoop.hbase.regionserver.StripeStoreEngine
The storage engine that implements the stripe-based store/compaction scheme.
org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
Stripe implementation of StoreFileManager.
org.apache.hadoop.hbase.regionserver.StripeStoreFlusher
Stripe implementation of StoreFlusher.
org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.BoundaryStripeFlushRequest
Stripe flush request wrapper based on boundaries.
org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.SizeStripeFlushRequest
Stripe flush request wrapper based on size.
org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.StripeFlushRequest
Stripe flush request wrapper that writes a non-striped file.
org.apache.hadoop.hbase.types.Struct
Struct is a simple DataType for implementing "compound rowkey" and "compound qualifier" schema design strategies.
org.apache.hadoop.hbase.types.StructBuilder
A helper for building Struct instances.
org.apache.hadoop.hbase.types.StructIterator
An Iterator over encoded Struct members.
org.apache.hadoop.hbase.filter.SubstringComparator
This comparator is for use with SingleColumnValueFilter, for filtering based on the value of a given column.
org.apache.hadoop.hbase.hbtop.screen.top.Summary
Represents the summary of the metrics.
org.apache.hadoop.hbase.security.Superusers
Keeps lists of superusers and super groups loaded from HBase configuration, checks if certain user is regarded as superuser.
org.apache.hadoop.hbase.http.jersey.SupplierFactoryAdapter<T>
Use a Supplier of type T as a Factory that provides instances of T.
org.apache.hadoop.hbase.regionserver.wal.SyncFutureCache
A cache of SyncFutures.
org.apache.hadoop.hbase.replication.SyncReplicationState
Used by synchronous replication.
org.apache.hadoop.hbase.mapreduce.SyncTable
 
org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper
 
org.apache.hadoop.hbase.mapreduce.SyncTable.SyncMapper.Counter
 
org.apache.hadoop.hbase.replication.SystemTableWALEntryFilter
Skips WAL edits for all System tables including hbase:meta except hbase:acl.
org.apache.hadoop.hbase.client.Table
Used to communicate with a single HBase table.
org.apache.hadoop.hbase.client.Table.CheckAndMutateBuilder
Deprecated.
Since 3.0.0, will be removed in 4.0.0.
org.apache.hadoop.hbase.client.Table.CheckAndMutateWithFilterBuilder
Deprecated.
Since 3.0.0, will be removed in 4.0.0.
org.apache.hadoop.hbase.client.TableBuilder
For creating Table instance.
org.apache.hadoop.hbase.client.replication.TableCFs
Used by Admin.listReplicatedTableCFs().
org.apache.hadoop.hbase.client.TableDescriptor
TableDescriptor contains the details about an HBase table such as the descriptors of all the column families, is the table a catalog table, hbase:meta , if the table is read only, the maximum size of the memstore, when the region split should occur, coprocessors associated with it etc...
org.apache.hadoop.hbase.client.TableDescriptorBuilder
Convenience class for composing an instance of TableDescriptor.
org.apache.hadoop.hbase.util.TableDescriptorChecker
Only used for master to sanity check TableDescriptor.
org.apache.hadoop.hbase.TableDescriptors
Get, remove and modify table descriptors.
org.apache.hadoop.hbase.client.TableDescriptorUtils
 
org.apache.hadoop.hbase.client.TableDescriptorUtils.TableDescriptorDelta
 
org.apache.hadoop.hbase.TableExistsException
Thrown when a table exists but should not.
org.apache.hadoop.hbase.TableInfoMissingException
Failed to find .tableinfo file under the table directory.
org.apache.hadoop.hbase.mapred.TableInputFormat
Convert HBase tabular data into a format that is consumable by Map/Reduce.
org.apache.hadoop.hbase.mapreduce.TableInputFormat
Convert HBase tabular data into a format that is consumable by Map/Reduce.
org.apache.hadoop.hbase.mapred.TableInputFormatBase
A Base for TableInputFormats.
org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
A base for TableInputFormats.
org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
This interface provides callbacks for handling particular table integrity invariant violations.
org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
Simple implementation of TableIntegrityErrorHandler.
org.apache.hadoop.hbase.mapred.TableMap<K extends org.apache.hadoop.io.WritableComparable<? super K>,V>
Scan an HBase table to sort by a specified sort column.
org.apache.hadoop.hbase.mapreduce.TableMapper<KEYOUT,VALUEOUT>
Extends the base Mapper class to add the required input key and value classes.
org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Utility for TableMap and TableReduce
org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Utility for TableMapper and TableReducer
org.apache.hadoop.hbase.hbtop.mode.TableModeStrategy
Implementation for ModeStrategy for Table Mode.
org.apache.hadoop.hbase.TableName
Immutable POJO class for representing a table name.
org.apache.hadoop.hbase.master.TableNamespaceManager
This is a helper class used internally to manage the namespace metadata that is stored in the ns family in meta table.
org.apache.hadoop.hbase.TableNotDisabledException
Thrown if a table should be offline but is not.
org.apache.hadoop.hbase.TableNotEnabledException
Thrown if a table should be enabled but is not.
org.apache.hadoop.hbase.TableNotFoundException
Thrown when a table cannot be located.
org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
Construct Span instances originating from "table operations" -- the verbs in our public API that interact with data in tables.
org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
Small committer class that does not do anything.
org.apache.hadoop.hbase.mapred.TableOutputFormat
Convert Map/Reduce output and write it to an HBase table
org.apache.hadoop.hbase.mapreduce.TableOutputFormat<KEY>
Convert Map/Reduce output and write it to an HBase table.
org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
Convert Reduce output (key, value) to (HStoreKey, KeyedDataArrayWritable) and write to an HBase table.
org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
Thrown if a table should be online/offline, but is partially open.
org.apache.hadoop.hbase.quotas.TableQuotaSnapshotStore
QuotaSnapshotStore for tables.
org.apache.hadoop.hbase.mapred.TableRecordReader
Iterate over an HBase table data, return (Text, RowResult) pairs
org.apache.hadoop.hbase.mapreduce.TableRecordReader
Iterate over an HBase table data, return (ImmutableBytesWritable, Result) pairs.
org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
Iterate over an HBase table data, return (Text, RowResult) pairs
org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Iterate over an HBase table data, return (ImmutableBytesWritable, Result) pairs.
org.apache.hadoop.hbase.mapred.TableReduce<K extends org.apache.hadoop.io.WritableComparable,V>
Write a table, sorting by the input key
org.apache.hadoop.hbase.mapreduce.TableReducer<KEYIN,VALUEIN,KEYOUT>
Extends the basic Reducer class to add the required key and value input/output classes.
org.apache.hadoop.hbase.replication.TableReplicationQueueStorage
HBase table based replication queue storage.
org.apache.hadoop.hbase.rest.TableResource
 
org.apache.hadoop.hbase.rest.TableScanResource
 
org.apache.hadoop.hbase.rest.TableScanResource.CellSetModelStream
 
org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
 
org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
 
org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
Hadoop MR API-agnostic implementation for mapreduce over table snapshots.
org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
Implementation class for InputSplit logic common between mapred and mapreduce.
org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
Implementation class for RecordReader logic common between mapred and mapreduce.
org.apache.hadoop.hbase.client.TableSnapshotScanner
A Scanner which performs a scan over snapshot files.
org.apache.hadoop.hbase.quotas.TableSpaceQuotaSnapshotNotifier
A SpaceQuotaSnapshotNotifier which uses the hbase:quota table.
org.apache.hadoop.hbase.client.trace.TableSpanBuilder
Construct Span instances involving data tables.
org.apache.hadoop.hbase.mapred.TableSplit
A table split corresponds to a key range [low, high)
org.apache.hadoop.hbase.mapreduce.TableSplit
A table split corresponds to a key range (low, high) and an optional scanner.
org.apache.hadoop.hbase.client.TableState
Represents table state.
org.apache.hadoop.hbase.client.TableState.State
 
org.apache.hadoop.hbase.master.TableStateManager
This is a helper class used to manage table states.
org.apache.hadoop.hbase.Tag
Tags are part of cells and helps to add metadata about them.
org.apache.hadoop.hbase.TagBuilder
Builder implementation to create Tag Call setTagValue(byte[]) method to create ArrayBackedTag
org.apache.hadoop.hbase.TagBuilderFactory
Factory to create Tags.
org.apache.hadoop.hbase.io.TagCompressionContext
Context that holds the dictionary for Tag compression and doing the compress/uncompress.
org.apache.hadoop.hbase.TagType
 
org.apache.hadoop.hbase.TagUtil
 
org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
A bounded thread pool server customized for HBase.
org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer.Args
 
org.apache.hadoop.hbase.hbtop.terminal.Terminal
The terminal interface that is an abstraction of terminal screen.
org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalImpl
An implementation of the Terminal interface for normal display mode.
org.apache.hadoop.hbase.hbtop.terminal.TerminalPrinter
The interface responsible for printing to the terminal.
org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
An implementation of the TerminalPrinter interface for normal display mode.
org.apache.hadoop.hbase.hbtop.terminal.TerminalSize
Terminal dimensions in 2-d space, measured in number of rows and columns.
org.apache.hadoop.hbase.types.TerminatedWrapper<T>
Wraps an existing DataType implementation as a terminated version of itself.
org.apache.hadoop.hbase.testing.TestingHBaseCluster
A mini hbase cluster used for testing.
org.apache.hadoop.hbase.testing.TestingHBaseClusterOption
Options for starting up a mini testing cluster TestingHBaseCluster (including an hbase, dfs and zookeeper clusters) in test.
org.apache.hadoop.hbase.testing.TestingHBaseClusterOption.Builder
Builder pattern for creating an TestingHBaseClusterOption.
org.apache.hadoop.hbase.mapreduce.TextSortReducer
Emits Sorted KeyValues.
org.apache.hadoop.hbase.thrift.THBaseThreadPoolExecutor
A ThreadPoolExecutor customized for working with HBase thrift to update metrics before and after the execution of a task.
org.apache.hadoop.hbase.util.Threads
Thread Utility
org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
The HBaseServiceHandler is a glue object that connects Thrift RPC calls to the HBase client API primarily defined in the Admin and Table objects.
org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.IOErrorWithCause
 
org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler.ResultScannerWrapper
 
org.apache.hadoop.hbase.thrift.ThriftHttpServlet
Thrift Http Servlet is used for performing Kerberos authentication if security is enabled and also used for setting the user specified in "doAs" parameter.
org.apache.hadoop.hbase.thrift.ThriftMetrics
This class is for maintaining the various statistics of thrift server and publishing them through the metrics interfaces.
org.apache.hadoop.hbase.thrift.ThriftMetrics.ThriftServerType
 
org.apache.hadoop.hbase.thrift.ThriftServer
ThriftServer- this class starts up a Thrift server which implements the Hbase API specified in the Hbase.thrift IDL file.
org.apache.hadoop.hbase.thrift.ThriftUtilities
 
org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
The ThrottleInputStream provides bandwidth throttling on a specified InputStream.
org.apache.hadoop.hbase.quotas.ThrottleSettings
 
org.apache.hadoop.hbase.quotas.ThrottleType
Describe the Throttle Type.
org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
A utility that constrains the total throughput of one or more simultaneous flows by sleeping when necessary.
org.apache.hadoop.hbase.regionserver.throttle.ThroughputControlUtil
Helper methods for throttling
org.apache.hadoop.hbase.quotas.TimeBasedLimiter
Simple time based limiter that checks the quota Throttle
org.apache.hadoop.hbase.util.TimeMeasurable<T>
Methods that implement this interface can be measured elapsed time.
org.apache.hadoop.hbase.errorhandling.TimeoutException
Exception for timeout of a task.
org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
Time a given process/operation and report a failure if the elapsed time exceeds the max allowed time.
org.apache.hadoop.hbase.exceptions.TimeoutIOException
Exception thrown when a blocking operation times out.
org.apache.hadoop.hbase.metrics.Timer
A metric which encompasses a Histogram and Meter.
org.apache.hadoop.hbase.io.TimeRange
Represents an interval of version timestamps.
org.apache.hadoop.hbase.regionserver.TimeRangeTracker
Stores minimum and maximum timestamp values, it is [minimumTimestamp, maximumTimestamp] in interval notation.
org.apache.hadoop.hbase.regionserver.TimeRangeTracker.NonSyncTimeRangeTracker
 
org.apache.hadoop.hbase.regionserver.TimeRangeTracker.SyncTimeRangeTracker
 
org.apache.hadoop.hbase.regionserver.TimeRangeTracker.Type
 
org.apache.hadoop.hbase.filter.TimestampsFilter
Filter that returns only cells whose timestamp (version) is in the specified list of timestamps (versions).
org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
A block cache that is memory-aware using HeapSize, memory bounded using the W-TinyLFU eviction algorithm, and concurrent.
org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
The data and business logic for the top screen.
org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
The presentation logic for the top screen.
org.apache.hadoop.hbase.hbtop.screen.top.TopScreenView
The screen that provides a dynamic real-time view for the HBase metrics.
org.apache.hadoop.hbase.util.Triple<A,B,C>
Utility class to manage a triple.
org.apache.hadoop.hbase.exceptions.TrustManagerException
 
org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
Write table content out to files in hdfs.
org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
Write table content out to map output files.
org.apache.hadoop.hbase.io.hfile.UncompressedBlockSizePredicator
This BlockCompressedSizePredicator implementation doesn't actually performs any predicate and simply returns true on shouldFinishBlock.
org.apache.hadoop.hbase.exceptions.UnexpectedStateException
 
org.apache.hadoop.hbase.types.Union2<A,B>
The Union family of DataTypes encode one of a fixed set of Objects.
org.apache.hadoop.hbase.types.Union3<A,B,C>
The Union family of DataTypes encode one of a fixed collection of Objects.
org.apache.hadoop.hbase.types.Union4<A,B,C,D>
The Union family of DataTypes encode one of a fixed collection of Objects.
org.apache.hadoop.hbase.exceptions.UnknownProtocolException
An error requesting an RPC protocol that the server is not serving.
org.apache.hadoop.hbase.UnknownRegionException
Thrown when we are asked to operate on a region we know nothing about.
org.apache.hadoop.hbase.UnknownScannerException
Thrown if a region server is passed an unknown scanner ID.
org.apache.hadoop.hbase.ipc.UnknownServiceException
 
org.apache.hadoop.hbase.snapshot.UnknownSnapshotException
Exception thrown when we get a request for a snapshot we don't recognize.
org.apache.hadoop.hbase.util.UnsafeAccess
 
org.apache.hadoop.hbase.ipc.UnsupportedCellCodecException
 
org.apache.hadoop.hbase.ipc.UnsupportedCompressionCodecException
 
org.apache.hadoop.hbase.ipc.UnsupportedCryptoException
 
org.apache.hadoop.hbase.security.User
Wrapper to abstract out usage of user and group information in HBase.
org.apache.hadoop.hbase.security.User.SecureHadoopUser
Bridges User invocations to underlying calls to UserGroupInformation for secure Hadoop 0.20 and versions 0.21 and above.
org.apache.hadoop.hbase.security.User.TestingGroups
 
Encapsulates per-user load metrics.
org.apache.hadoop.hbase.UserMetrics.ClientMetrics
 
org.apache.hadoop.hbase.UserMetricsBuilder
 
org.apache.hadoop.hbase.UserMetricsBuilder.ClientMetricsImpl
 
org.apache.hadoop.hbase.hbtop.mode.UserModeStrategy
Implementation for ModeStrategy for User Mode.
org.apache.hadoop.hbase.security.UserProvider
Provide an instance of a user.
org.apache.hadoop.hbase.quotas.UserQuotaState
In-Memory state of the user quotas
org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
Query matcher for user scan.
org.apache.hadoop.hbase.filter.ValueFilter
This filter is used to filter based on column value.
org.apache.hadoop.hbase.replication.VerifyWALEntriesReplicationEndpoint
A dummy ReplicationEndpoint that replicates nothing.
org.apache.hadoop.hbase.regionserver.VersionedSegmentsList
A list of segment managers coupled with the version of the memstore (version at the time it was created).
org.apache.hadoop.hbase.util.VersionInfo
This class finds the Version information for HBase.
org.apache.hadoop.hbase.client.VersionInfoUtil
Class to help with parsing the version info.
org.apache.hadoop.hbase.client.VersionInfoUtil.ServiceCallFunction<T1,T2,R,E extends Throwable>
We intend to use the local version for service call shortcut(s), so we use an interface compatible with a typical service call, with 2 args, return type, and an exception type.
org.apache.hadoop.hbase.rest.VersionResource
Implements REST software version reporting
org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver
Interface to convert visibility expressions into Tags for storing along with Cells in HFiles.
org.apache.hadoop.hbase.wal.WAL
A Write Ahead Log (WAL) provides service for reading, writing waledits.
org.apache.hadoop.hbase.wal.WAL.Entry
Utility class that lets us keep track of the edit with it's key.
org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
Get notification of WAL events.
org.apache.hadoop.hbase.regionserver.wal.WALActionsListener.RollRequestReason
The reason for the log roll request.
org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
Compression in this class is lifted off Compressor/KeyValueCompression.
org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.ByteStringCompressor
 
org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.ByteStringUncompressor
 
org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.EnsureKvEncoder
 
org.apache.hadoop.hbase.replication.WALCellFilter
A filter for WAL entry cells before being sent over to replication.
org.apache.hadoop.hbase.regionserver.wal.WALClosedException
Thrown when LogRoller try to roll writer but the WAL already was closed.
org.apache.hadoop.hbase.coprocessor.WALCoprocessor
WALCoprocessor don't support loading services using Coprocessor.getServices().
org.apache.hadoop.hbase.coprocessor.WALCoprocessorEnvironment
 
org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
Implements the coprocessor environment and runtime support for coprocessors loaded within a WAL.
org.apache.hadoop.hbase.wal.WALEdit
Used in HBase's transaction log (WAL) to represent a collection of edits (Cell/KeyValue objects) that came in as a single transaction.
org.apache.hadoop.hbase.wal.WALEditInternalHelper
A helper class so we can call some package private methods of WALEdit from other packages.
org.apache.hadoop.hbase.replication.WALEntryFilter
A Filter for WAL entries before being sent over to replication.
org.apache.hadoop.hbase.regionserver.wal.WALEventTrackerListener
 
org.apache.hadoop.hbase.regionserver.wal.WALEventTrackerListener.WalState
 
org.apache.hadoop.hbase.namequeues.WALEventTrackerPayload
 
org.apache.hadoop.hbase.namequeues.WALEventTrackerQueueService
 
org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
 
org.apache.hadoop.hbase.wal.WALFactory
Entry point for users of the Write Ahead Log.
org.apache.hadoop.hbase.regionserver.wal.WALHeaderEOFException
A special EOFException to indicate that the EOF happens when we read the header of a WAL file.
org.apache.hadoop.hbase.mapreduce.WALInputFormat
Simple InputFormat for WAL files.
org.apache.hadoop.hbase.wal.WALKey
Key for WAL Entry.
org.apache.hadoop.hbase.wal.WALKeyImpl
Default implementation of Key for an Entry in the WAL.
org.apache.hadoop.hbase.io.WALLink
WALLink describes a link to a WAL.
org.apache.hadoop.hbase.coprocessor.WALObserver
It's provided to have a way for coprocessors to observe, rewrite, or skip WALEdits as they are being written to the WAL.
org.apache.hadoop.hbase.wal.WALPerformanceEvaluation
This class runs performance benchmarks for WAL.
org.apache.hadoop.hbase.util.WALPerformanceEvaluationUtil
This class contains code copied from HBaseTestingUtil and its super classes required by WALPerformanceEvaluation.
org.apache.hadoop.hbase.mapreduce.WALPlayer
A tool to replay WAL files as a M/R job.
org.apache.hadoop.hbase.mapreduce.WALPlayer.Counter
Enum for map metrics.
org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
A mapper that writes out Mutation to be directly applied to a running HBase instance.
org.apache.hadoop.hbase.wal.WALPrettyPrinter
WALPrettyPrinter prints the contents of a given WAL with a variety of options affecting formatting and extent of content.
org.apache.hadoop.hbase.wal.WALProvider
The Write Ahead Log (WAL) stores all durable edits to the HRegion.
org.apache.hadoop.hbase.wal.WALProvider.AsyncWriter
 
org.apache.hadoop.hbase.wal.WALProvider.Writer
 
org.apache.hadoop.hbase.wal.WALProvider.WriterBase
 
org.apache.hadoop.hbase.wal.WALSplitter
Split RegionServer WAL files.
org.apache.hadoop.hbase.wal.WALSplitter.PipelineController
Contains some methods to control WAL-entries producer / consumer interactions
org.apache.hadoop.hbase.wal.WALSplitUtil
This class provides static methods to support WAL splitting related works
org.apache.hadoop.hbase.wal.WALSplitUtil.MutationReplay
A struct used by getMutationsFromWALEntry
org.apache.hadoop.hbase.wal.WALStreamReader
A one way WAL reader, without reset and seek support.
org.apache.hadoop.hbase.regionserver.wal.WALSyncTimeoutIOException
Thrown when WAL.sync() timeout.
org.apache.hadoop.hbase.wal.WALTailingReader
A WAL reader which is designed for be able to tailing the WAL file which is currently being written.
org.apache.hadoop.hbase.wal.WALTailingReader.Result
 
org.apache.hadoop.hbase.wal.WALTailingReader.State
 
org.apache.hadoop.hbase.regionserver.wal.WALUtil
Helper methods to ease Region Server integration with the Write Ahead Log (WAL).
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.filter.WhileMatchFilter
A wrapper filter that returns true from WhileMatchFilter.filterAllRemaining() as soon as the wrapped filters Filter.filterRowKey(Cell), Filter.filterCell(org.apache.hadoop.hbase.Cell), Filter.filterRow() or Filter.filterAllRemaining() methods returns true.
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.master.WorkerAssigner
help assign and release a worker for each remote task.
org.apache.hadoop.hbase.io.asyncfs.WrapperAsyncFSOutput
An AsyncFSOutput wraps a FSDataOutputStream.
org.apache.hadoop.hbase.util.Writables
Utility class with methods for manipulating Writable objects
org.apache.hadoop.hbase.io.WritableWithSize
An optional interface to 'size' writables.
org.apache.hadoop.hbase.regionserver.WrongRegionException
Thrown when a request contains a key which is not part of this region
org.apache.hadoop.hbase.client.WrongRowIOException
 
org.apache.hadoop.hbase.ipc.WrongVersionException
 
org.apache.hadoop.hbase.exceptions.X509Exception
This file has been copied from the Apache ZooKeeper project.
org.apache.hadoop.hbase.io.crypto.tls.X509Util
Utility code for X509 handling Default cipher suites: Performance testing done by Facebook engineers shows that on Intel x86_64 machines, Java9 performs better with GCM and Java8 performs better with CBC, so these seem like reasonable defaults.
org.apache.hadoop.hbase.io.crypto.tls.X509Util.ClientAuth
Enum specifying the client auth requirement of server-side TLS sockets created by this X509Util.
org.apache.hadoop.hbase.util.YammerHistogramUtils
Utility functions for working with Yammer Metrics.
org.apache.hadoop.hbase.YouAreDeadException
This exception is thrown by the master when a region server reports and is already being processed as dead.
org.apache.hadoop.hbase.zookeeper.ZKAclReset
You may add the jaas.conf option -Djava.security.auth.login.config=/PATH/jaas.conf You may also specify -D to set options "hbase.zookeeper.quorum" (it should be in hbase-site.xml) "zookeeper.znode.parent" (it should be in hbase-site.xml) Use -set-acls to set the ACLs, no option to erase ACLs
org.apache.hadoop.hbase.zookeeper.ZKAuthentication
Provides ZooKeeper authentication services for both client and server processes.
org.apache.hadoop.hbase.zookeeper.ZKClusterId
Publishes and synchronizes a unique identifier specific to a given HBase cluster.
org.apache.hadoop.hbase.zookeeper.ZKConfig
Utility methods for reading, and building the ZooKeeper configuration.
org.apache.hadoop.hbase.zookeeper.ZKConfig.ZKClusterKey
 
org.apache.hadoop.hbase.client.ZKConnectionRegistryURIFactory
Connection registry creator implementation for creating ZKConnectionRegistry.
org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
Deprecated.
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based distributed WAL splitter (see SplitWALManager) which doesn't use this zk-based coordinator.
org.apache.hadoop.hbase.zookeeper.ZKDump
Builds a string containing everything in ZooKeeper.
org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
Deprecated.
Not used
org.apache.hadoop.hbase.zookeeper.ZKListener
Base class for internal listeners of ZooKeeper events.
org.apache.hadoop.hbase.zookeeper.ZKMainServer
Tool for running ZookeeperMain from HBase by reading a ZooKeeper server from HBase XML configuration.
org.apache.hadoop.hbase.zookeeper.ZKMetadata
The metadata append to the start of data on zookeeper.
org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
Tracks the availability and value of a single ZooKeeper node.
org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
ZK based replication peer storage.
org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration
Just retain a small set of the methods for the old zookeeper based replication queue storage, for migrating.
org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.MigrationIterator<T>
 
org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.ZkLastPushedSeqId
 
org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.ZkReplicationQueueData
 
org.apache.hadoop.hbase.replication.ZKReplicationStorageBase
This is a base class for maintaining replication related data,for example, peer, queue, etc, in zookeeper.
org.apache.hadoop.hbase.zookeeper.ZKServerTool
Tool for reading ZooKeeper servers from HBase XML configuration and producing a line-by-line list for use by bash scripts.
org.apache.hadoop.hbase.zookeeper.ZKSplitLog
Deprecated.
since 2.4.0 and 3.0.0 replaced by procedure-based WAL splitting; see SplitWALManager.
org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
ZooKeeper based implementation of SplitLogManagerCoordination
org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher
SplitLogManager can use objects implementing this interface to finish off a partially done task by SplitLogWorker.
org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.TaskFinisher.Status
status that can be returned finish()
org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
ZooKeeper based implementation of SplitLogWorkerCoordination It listen for changes in ZooKeeper and
org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
When ZK-based implementation wants to complete the task, it needs to know task znode and current znode cversion (needed for subsequent update operation).
org.apache.hadoop.hbase.zookeeper.ZKUtil
Internal HBase utility class for ZooKeeper.
org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
Deprecated.
Unused
org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
Represents an action taken by ZKUtil, e.g.
org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
ZKUtilOp representing createAndFailSilent in ZooKeeper (attempt to create node, ignore error if already exists)
org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.DeleteNodeFailSilent
ZKUtilOp representing deleteNodeFailSilent in ZooKeeper (attempt to delete node, ignore error if node doesn't exist)
org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
ZKUtilOp representing setData in ZooKeeper
org.apache.hadoop.hbase.zookeeper.ZKWatcher
Acts as the single ZooKeeper Watcher.
org.apache.hadoop.hbase.ZNodeClearer
Contains a set of methods for the collaboration between the start/stop scripts and the servers.
org.apache.hadoop.hbase.zookeeper.ZNodePaths
Class that hold all the paths of znode for HBase.
org.apache.hadoop.hbase.ZooKeeperConnectionException
Thrown if the client can't connect to ZooKeeper.
org.apache.hadoop.hbase.zookeeper.ZooKeeperHelper
Methods that help working with ZooKeeper