Modifier and Type | Interface and Description |
---|---|
interface |
Abortable
Interface to support the aborting of a given server or client.
|
class |
CellComparator
Compare two HBase cells.
|
interface |
CellScannable
Implementer can return a CellScanner over its Cell content.
|
interface |
CellScanner
An interface for iterating through a sequence of cells.
|
class |
Chore
Chore is a task performed on a period in hbase.
|
class |
ClusterId
The identifier for this cluster.
|
class |
CompoundConfiguration
Do a shallow merge of multiple KV configuration pools.
|
interface |
Coprocessor
Coprocessor interface.
|
interface |
CoprocessorEnvironment
Coprocessor environment state.
|
class |
HDFSBlocksDistribution
Data structure to describe the distribution of HDFS blocks amount hosts.
|
interface |
InterProcessLock
An interface for an application-specific lock.
|
interface |
InterProcessReadWriteLock
An interface for a distributed reader-writer lock.
|
class |
KeyValue
An HBase Key/Value.
|
class |
KeyValueTestUtil |
class |
KeyValueUtil
static convenience methods for dealing with KeyValues and collections of KeyValues
|
class |
RegionTransition
Current state of a region in transition.
|
class |
RemoteExceptionHandler
An immutable class which contains a static method for handling
org.apache.hadoop.ipc.RemoteException exceptions.
|
interface |
Server
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
class |
SplitLogCounters
Counters kept by the distributed WAL split log process.
|
class |
SplitLogTask
State of a WAL log split during distributed splitting.
|
interface |
Stoppable
Implementers are Stoppable.
|
interface |
TableDescriptors
Get, remove and modify table descriptors.
|
class |
Tag
Tags are part of cells and helps to add metadata about the KVs.
|
class |
TagType |
interface |
VersionAnnotation
A package attribute that captures the version of hbase that was compiled.
|
class |
ZKNamespaceManager
Class servers two purposes:
1.
|
Modifier and Type | Method and Description |
---|---|
Map<String,RegionState> |
ClusterStatus.getRegionsInTransition() |
Modifier and Type | Class and Description |
---|---|
class |
TableHFileArchiveTracker
Track HFile archiving state changes in ZooKeeper.
|
class |
ZKTableArchiveClient
Example class for how to use the table archiving coordinated via zookeeper
|
Modifier and Type | Class and Description |
---|---|
class |
CatalogTracker
Tracks the availability of the catalog tables
hbase:meta . |
class |
MetaEditor
Writes region and assignment information to
hbase:meta . |
class |
MetaReader
Reads region and assignment information from
hbase:meta . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractClientScanner
Helper class for custom client scanners.
|
class |
Action<R>
A Get, Put, Increment, Append, or Delete associated with it's region.
|
class |
ClientSideRegionScanner
A client scanner for a region opened for read-only on the client side.
|
class |
ConnectionUtils
Utility used by client connections.
|
class |
CoprocessorHConnection
Connection to an HTable from within a Coprocessor.
|
class |
HConnectable<T>
This class makes it convenient for one to execute a command in the context
of a
HConnection instance based on the given Configuration . |
class |
HTablePool
Deprecated.
as of 0.98.1. See
HConnection.getTable(String) . |
class |
HTableUtil
Utility class for HTable.
|
class |
MetaScanner
Scanner class that contains the
hbase:meta table scanning logic. |
class |
MultiAction<R>
Container for Actions (i.e.
|
class |
MultiResponse
A container for Result objects, grouped by regionName.
|
interface |
NonceGenerator
NonceGenerator interface.
|
class |
PerClientRandomNonceGenerator
NonceGenerator implementation that uses client ID hash + random int as nonce group,
and random numbers as nonces.
|
class |
RegionCoprocessorServiceExec
Represents a coprocessor service method execution against a single region.
|
class |
RegionServerCallable<T>
Implementations call a RegionServer and implement
Callable.call() . |
interface |
RetryingCallable<T>
A Callable
|
class |
RpcRetryingCaller<T>
Runs an rpc'ing
RetryingCallable . |
class |
ScannerCallable
Scanner operations such as create, next, etc.
|
Modifier and Type | Method and Description |
---|---|
static <T> T |
HConnectionManager.execute(HConnectable<T> connectable)
This convenience method invokes the given
HConnectable.connect(org.apache.hadoop.hbase.client.HConnection)
implementation using a HConnection instance that lasts just for the
duration of the invocation. |
protected ScannerCallable |
ClientScanner.getScannerCallable(byte[] localStartKey,
int nbRows) |
Modifier and Type | Class and Description |
---|---|
class |
AggregationClient
This client class is for invoking the aggregate functions deployed on the
Region Server side via the AggregateService.
|
class |
BigDecimalColumnInterpreter
ColumnInterpreter for doing Aggregation's with BigDecimal columns.
|
class |
LongColumnInterpreter
a concrete column interpreter implementation.
|
class |
SecureBulkLoadClient
Client proxy for SecureBulkLoadProtocol
used in conjunction with SecureBulkLoadEndpoint
|
Modifier and Type | Class and Description |
---|---|
class |
ScanMetrics
Provides client-side metrics related to scan operations
The data can be passed to mapreduce framework or other systems.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseDecoder
TODO javadoc
|
class |
BaseEncoder
TODO javadoc
|
class |
CodecException
Thrown when problems in the codec whether setup or context.
|
Modifier and Type | Class and Description |
---|---|
class |
PrefixTreeBlockMeta
Information about the block.
|
class |
PrefixTreeCodec
This class is created via reflection in DataBlockEncoding enum.
|
class |
PrefixTreeSeeker
These methods have the same definition as any implementation of the EncodedSeeker.
|
Modifier and Type | Class and Description |
---|---|
class |
ArraySearcherPool
Pools PrefixTreeArraySearcher objects.
|
class |
DecoderFactory
Static wrapper class for the ArraySearcherPool.
|
class |
PrefixTreeArrayReversibleScanner
Methods for going backwards through a PrefixTree block.
|
class |
PrefixTreeArrayScanner
Extends PtCell and manipulates its protected fields.
|
class |
PrefixTreeArraySearcher
Searcher extends the capabilities of the Scanner + ReversibleScanner to add the ability to
position itself on a requested Cell without scanning through cells before it.
|
class |
PrefixTreeCell
As the PrefixTreeArrayScanner moves through the tree bytes, it changes the values in the fields
of this class so that Cell logic can be applied, but without allocating new memory for every Cell
iterated through.
|
Modifier and Type | Class and Description |
---|---|
class |
ColumnNodeReader |
class |
ColumnReader
Position one of these appropriately in the data block and you can call its methods to retrieve
the family or qualifier at the current position.
|
Modifier and Type | Class and Description |
---|---|
class |
RowNodeReader
Position one of these appropriately in the data block and you can call its methods to retrieve
information necessary to decode the cells in the row.
|
Modifier and Type | Class and Description |
---|---|
class |
MvccVersionDecoder
Given a block and its blockMeta, this will decode the MvccVersion for the i-th Cell in the block.
|
class |
TimestampDecoder
Given a block and its blockMeta, this will decode the timestamp for the i-th Cell in the block.
|
Modifier and Type | Class and Description |
---|---|
class |
EncoderFactory
Retrieve PrefixTreeEncoders from this factory which handles pooling them and preparing the
ones retrieved from the pool for usage.
|
interface |
EncoderPool |
class |
PrefixTreeEncoder
This is the primary class for converting a CellOutputStream into an encoded byte[].
|
class |
ThreadLocalEncoderPool
Pool to enable reusing the Encoder objects which can consist of thousands of smaller objects and
would be more garbage than the data in the block.
|
Modifier and Type | Class and Description |
---|---|
class |
ColumnNodeWriter
Column nodes can be either family nodes or qualifier nodes, as both sections encode similarly.
|
class |
ColumnSectionWriter
Takes the tokenized family or qualifier data and flattens it into a stream of bytes.
|
Modifier and Type | Class and Description |
---|---|
class |
CellTypeEncoder
Detect if every KV has the same KeyValue.Type, in which case we don't need to store it for each
KV.
|
class |
ColumnNodeType
Specifies the type of columnnode writer.
|
class |
LongEncoder
Used to de-duplicate, sort, minimize/diff, and serialize timestamps and mvccVersions from a
collection of Cells.
|
Modifier and Type | Class and Description |
---|---|
class |
RowNodeWriter
Serializes the fields comprising one node of the row trie, which can be a branch, nub, or leaf.
|
class |
RowSectionWriter
Most of the complexity of the PrefixTree is contained in the "row section".
|
Modifier and Type | Class and Description |
---|---|
class |
TokenDepthComparator
Determines order of nodes in the output array.
|
class |
Tokenizer
Data structure used in the first stage of PrefixTree encoding:
accepts a sorted stream of ByteRanges
splits them into a set of tokens, each held by a
TokenizerNode
connects the TokenizerNodes via standard java references
keeps a pool of TokenizerNodes and a reusable byte[] for holding all token content |
class |
TokenizerNode
Individual node in a Trie structure.
|
class |
TokenizerRowSearchPosition
Warning: currently unused, but code is valid.
|
class |
TokenizerRowSearchResult
for recursively searching a PtBuilder
|
Modifier and Type | Class and Description |
---|---|
class |
CellScannerPosition
An indicator of the state of the scanner after an operation such as nextCell() or
positionAt(..).
|
interface |
CellSearcher
Methods for seeking to a random
Cell inside a sorted collection of cells. |
interface |
ReversibleCellScanner
An extension of CellScanner indicating the scanner supports iterating backwards through cells.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseConstraint
Base class to use when actually implementing a
Constraint . |
interface |
Constraint
Apply a
Constraint (in traditional database terminology) to a HTable. |
class |
ConstraintException
Exception that a user defined constraint throws on failure of a
Put . |
class |
ConstraintProcessor
Processes multiple
Constraints on a given table. |
class |
Constraints
Utilities for adding/removing constraints from a table.
|
Modifier and Type | Class and Description |
---|---|
class |
AggregateImplementation<T,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,R extends com.google.protobuf.Message>
A concrete AggregateProtocol implementation.
|
class |
ColumnInterpreter<T,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,R extends com.google.protobuf.Message>
Defines how value for specific column is interpreted and provides utility
methods like compare, add, multiply etc for them.
|
Modifier and Type | Class and Description |
---|---|
class |
ForeignExceptionDispatcher
The dispatcher acts as the state holding entity for foreign error handling.
|
interface |
ForeignExceptionListener
The ForeignExceptionListener is an interface for objects that can receive a ForeignException.
|
interface |
ForeignExceptionSnare
This is an interface for a cooperative exception throwing mechanism.
|
class |
TimeoutExceptionInjector
Time a given process/operation and report a failure if the elapsed time exceeds the max allowed
time.
|
Modifier and Type | Class and Description |
---|---|
class |
DeserializationException
Failed deserialization.
|
class |
HBaseException
Base checked exception in HBase.
|
class |
OutOfOrderScannerNextException
Thrown by a RegionServer while doing next() calls on a ResultScanner.
|
class |
RegionMovedException
Subclass if the server knows the region is now on another server.
|
class |
RegionOpeningException
Subclass if the server knows the region is now on another server.
|
Modifier and Type | Class and Description |
---|---|
class |
EventHandler
Abstract base class for all HBase event handlers.
|
class |
EventType
List of all HBase event handler types.
|
class |
ExecutorService
This is a generic executor service.
|
class |
ExecutorType
The following is a list of all executor types, both those that run in the
master and those that run in the regionserver.
|
Modifier and Type | Class and Description |
---|---|
class |
FilterBase
Abstract base class to help you implement new Filters.
|
class |
FilterWrapper
This is a Filter wrapper class which is used in the server side.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CellOutputStream
Accepts a stream of Cells.
|
class |
DataInputInputStream
An InputStream that wraps a DataInput.
|
class |
DataOutputOutputStream
OutputStream implementation that wraps a DataOutput.
|
class |
DoubleOutputStream
An output stream that writes to two streams on each operation.
|
class |
FileLink
The FileLink is a sort of hardlink, that allows access to a file given a set of locations.
|
class |
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. |
interface |
HeapSize
Implementations can be asked for an estimate of their size in bytes.
|
class |
HFileLink
HFileLink describes a link to an hfile.
|
class |
HLogLink
HLogLink describes a link to a WAL.
|
class |
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.
|
interface |
SizedCellScanner
A CellScanner that knows its size in memory in bytes.
|
class |
TagCompressionContext
Context that holds the dictionary for Tag compression and doing the compress/uncompress.
|
interface |
WritableWithSize
An optional interface to 'size' writables.
|
Modifier and Type | Class and Description |
---|---|
class |
Compression
Compression related stuff.
|
class |
ReusableStreamGzipCodec
Fixes an inefficiency in Hadoop's Gzip codec, allowing to reuse compression
streams.
|
Modifier and Type | Class and Description |
---|---|
class |
AES
AES-128, provided by the JCE
|
class |
AESDecryptor |
class |
AESEncryptor |
Modifier and Type | Class and Description |
---|---|
class |
CopyKeyDataBlockEncoder
Just copy data, do not do any kind of compression.
|
interface |
DataBlockEncoder
Encoding of KeyValue.
|
class |
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
- ...
|
class |
EncodedDataBlock
Encapsulates a data block compressed using a particular encoding algorithm.
|
class |
EncoderBufferTooSmallException
Internal error which indicates a bug in a data block encoding algorithm.
|
class |
FastDiffDeltaEncoder
Encoder similar to
DiffKeyDeltaEncoder but supposedly faster. |
interface |
HFileBlockDecodingContext
A decoding context that is created by a reader's encoder, and is shared
across the reader's all read operations.
|
class |
HFileBlockDefaultDecodingContext
A default implementation of
HFileBlockDecodingContext . |
class |
HFileBlockDefaultEncodingContext
A default implementation of
HFileBlockEncodingContext . |
interface |
HFileBlockEncodingContext
An encoding context that is created by a writer's encoder, and is shared
across the writer's whole lifetime.
|
class |
PrefixKeyDeltaEncoder
Compress key by storing size of common prefix with previous KeyValue
and storing raw size of rest.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractHFileReader
Common functionality needed by all versions of
HFile readers. |
class |
AbstractHFileWriter
Common functionality needed by all versions of
HFile writers. |
interface |
BlockCache
Block cache interface.
|
class |
BlockCacheKey
Cache Key for use with implementations of
BlockCache |
class |
BlockCacheUtil
Utilty for aggregating counts in CachedBlocks and toString/toJSON CachedBlocks and BlockCaches.
|
class |
BlockType
Various types of HFile blocks.
|
interface |
Cacheable
Cacheable is an interface that allows for an object to be cached.
|
interface |
CacheableDeserializer<T extends Cacheable>
Interface for a deserializer.
|
class |
CacheableDeserializerIdManager
This class is used to manage the identifiers for
CacheableDeserializer |
class |
CacheConfig
Stores all of the cache objects and configuration for a single HFile.
|
interface |
CachedBlock |
class |
CacheStats
Class that implements cache metrics.
|
class |
CombinedBlockCache
CombinedBlockCache is an abstraction layer that combines
LruBlockCache and BucketCache . |
class |
CorruptHFileException
This exception is thrown when attempts to read an HFile fail due to corruption or truncation
issues.
|
class |
DoubleBlockCache
Deprecated.
As of 1.0, replaced by
BucketCache . |
class |
FixedFileTrailer
The
HFile has a fixed trailer which contains offsets to other
variable parts of the file. |
class |
HFile
File format for hbase.
|
class |
HFileBlock
Reading
HFile version 1 and 2 blocks, and writing version 2 blocks. |
class |
HFileBlockIndex
Provides functionality to write (
HFileBlockIndex.BlockIndexWriter ) and read
(HFileBlockIndex.BlockIndexReader ) single-level and multi-level block indexes. |
class |
HFileContext
This carries the information on some of the meta data about the HFile.
|
class |
HFileContextBuilder
A builder that helps in building up the HFileContext
|
interface |
HFileDataBlockEncoder
Controls what kind of data block encoding is used.
|
class |
HFileDataBlockEncoderImpl
Do different kinds of data block encoding according to column family
options.
|
class |
HFileReaderV2
HFile reader for version 2. |
class |
HFileReaderV3
HFile reader for version 3. |
interface |
HFileScanner
A scanner allows you to position yourself within a HFile and
scan through it.
|
class |
HFileWriterV2
Writes HFile format version 2.
|
class |
HFileWriterV3
HFile writer for version 3. |
interface |
InlineBlockWriter
A way to write "inline" blocks into an
HFile . |
class |
InvalidHFileException
Thrown when an invalid HFile format is detected
|
class |
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. |
class |
LruCachedBlock
Represents an entry in the
LruBlockCache . |
class |
LruCachedBlockQueue
A memory-bound queue that will grow until an element brings
total size >= maxSize.
|
class |
NoOpDataBlockEncoder
Does not perform any kind of encoding/decoding.
|
Modifier and Type | Class and Description |
---|---|
class |
BucketAllocator
This class is used to allocate a block with specified size and free the block
when evicting.
|
class |
BucketAllocatorException
Thrown by
BucketAllocator |
class |
BucketCache
BucketCache uses
BucketAllocator to allocate/free block, and use
BucketCache.ramCache and BucketCache.backingMap in order to
determine if a given element is in the cache. |
class |
BucketCacheStats
Class that implements cache metrics for bucket cache.
|
class |
ByteBufferIOEngine
IO engine that stores data on the memory using an array of ByteBuffers
ByteBufferArray |
class |
CachedEntryQueue
A memory-bound queue that will grow until an element brings total size larger
than maxSize.
|
class |
CacheFullException
Thrown by
BucketAllocator.allocateBlock(int) when cache is full for
the requested size |
class |
FileIOEngine
IO engine that stores data to a file on the local file system.
|
interface |
IOEngine
A class implementing IOEngine interface could support data services for
BucketCache . |
class |
UniqueIndexMap<T>
Map from type T to int and vice-versa.
|
Modifier and Type | Class and Description |
---|---|
class |
SingleSizeCache
Deprecated.
As of 1.0, replaced by
BucketCache . |
class |
SlabCache
Deprecated.
As of 1.0, replaced by
BucketCache . |
Modifier and Type | Interface and Description |
---|---|
interface |
Dictionary
Dictionary interface
Dictionary indexes should be either bytes or shorts, only positive.
|
class |
LRUDictionary
WALDictionary using an LRU eviction algorithm.
|
class |
StreamUtils |
Modifier and Type | Class and Description |
---|---|
class |
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. |
class |
CallRunner
The request processing logic, which is usually executed in thread pools provided by an
RpcScheduler . |
interface |
Delayable
A call whose response can be delayed by the server.
|
interface |
HBaseRPCErrorHandler
An interface for calling out of RPC for error conditions.
|
class |
MasterCoprocessorRpcChannel
Provides clients with an RPC connection to call coprocessor endpoint
Service s
against the active master. |
class |
MetricsHBaseServer |
class |
PayloadCarryingRpcController
Optionally carries Cells across the proxy/service interface down into ipc.
|
class |
RegionCoprocessorRpcChannel
Provides clients with an RPC connection to call coprocessor endpoint
Service s
against a given table region. |
class |
RequestContext
Represents client information (authenticated username, remote address, protocol)
for the currently executing request.
|
class |
RpcClient
Does RPC against a cluster.
|
class |
RpcExecutor |
Modifier and Type | Method and Description |
---|---|
com.google.protobuf.Message |
CoprocessorRpcChannel.callBlockingMethod(com.google.protobuf.Descriptors.MethodDescriptor method,
com.google.protobuf.RpcController controller,
com.google.protobuf.Message request,
com.google.protobuf.Message responsePrototype) |
void |
CoprocessorRpcChannel.callMethod(com.google.protobuf.Descriptors.MethodDescriptor method,
com.google.protobuf.RpcController controller,
com.google.protobuf.Message request,
com.google.protobuf.Message responsePrototype,
com.google.protobuf.RpcCallback<com.google.protobuf.Message> callback) |
Modifier and Type | Class and Description |
---|---|
class |
DefaultVisibilityExpressionResolver
This implementation creates tags by expanding expression using label ordinal.
|
class |
JobUtil
Utility methods to interact with a job.
|
class |
TableSnapshotInputFormatImpl
API-agnostic implementation for mapreduce over table snapshots.
|
Modifier and Type | Class and Description |
---|---|
class |
ActiveMasterManager
Handles everything on master-side related to master election.
|
class |
AssignCallable
A callable object that invokes the corresponding action that needs to be
taken for assignment of a region in transition.
|
interface |
AssignmentListener
Get notification of assignment events.
|
class |
AssignmentManager
Manages and performs region assignment.
|
class |
AssignmentVerificationReport
Helper class that is used by
RegionPlacementMaintainer to print
information for favored nodes |
class |
BulkAssigner
Base class used bulk assigning and unassigning regions.
|
class |
BulkReOpen
Performs bulk reopen of the list of regions provided to it.
|
class |
CatalogJanitor
A janitor for the catalog tables.
|
class |
ClusterStatusPublisher
Class to publish the cluster status to the client.
|
class |
DeadServer
Class to hold dead servers list and utility querying dead server list.
|
class |
GeneralBulkAssigner
Run bulk assign.
|
class |
HMaster
HMaster is the "master server" for HBase.
|
class |
HMasterCommandLine |
interface |
LoadBalancer
Makes decisions about the placement and movement of Regions across
RegionServers.
|
class |
MasterCoprocessorHost
Provides the coprocessor framework and environment for master oriented
operations.
|
class |
MasterDumpServlet |
class |
MasterFileSystem
This class abstracts a bunch of operations the HMaster needs to interact with
the underlying file system, including splitting log files, checking file
system status, etc.
|
interface |
MasterServices
Services Master supplies
|
class |
MasterStatusServlet
The servlet responsible for rendering the index page of the
master.
|
class |
MetricsMaster
This class is for maintaining the various master statistics
and publishing them through the metrics interfaces.
|
class |
MetricsMasterSourceImpl
Hadoop1 implementation of MetricsMasterSource.
|
class |
MetricsMasterWrapperImpl
Impl for exposing HMaster Information through JMX
|
class |
OfflineCallback
Callback handler for creating unassigned offline znodes
used during bulk assign, async setting region to offline.
|
class |
RackManager
Wrapper over the rack resolution utility in Hadoop.
|
class |
RegionPlacementMaintainer
A tool that is used for manipulating and viewing favored nodes information
for regions.
|
class |
RegionState
State of a Region while undergoing transitions.
|
class |
RegionStates
Region state accountant.
|
class |
RegionStateStore
A helper to persist region state in meta.
|
interface |
ServerListener
Get notification of server events.
|
class |
ServerManager
The ServerManager class manages info about region servers.
|
class |
SnapshotOfRegionAssignmentFromMeta
Used internally for reading meta and constructing datastructures that are
then queried, for things like regions to regionservers, table to regions, etc.
|
interface |
SnapshotSentinel
Watch the current snapshot under process
|
class |
SplitLogManager
Distributes the task of log splitting to the available region servers.
|
class |
TableLockManager
A manager for distributed table level locks.
|
static class |
TableLockManager.NullTableLockManager
A null implementation
|
static interface |
TableLockManager.TableLock
A distributed lock for a table.
|
class |
TableNamespaceManager
This is a helper class used to manage the namespace
metadata that is stored in TableName.NAMESPACE_TABLE_NAME
It also mirrors updates to the ZK store by forwarding updates to
ZKNamespaceManager |
class |
UnAssignCallable
A callable object that invokes the corresponding action that needs to be
taken for unassignment of a region in transition.
|
Modifier and Type | Class and Description |
---|---|
class |
BalancerChore
Chore that will call HMaster.balance
HMaster.balance() when
needed. |
class |
ClusterStatusChore
Chore that will feed the balancer the cluster status.
|
class |
FavoredNodeAssignmentHelper
Helper class for
FavoredNodeLoadBalancer that has all the intelligence
for racks, meta scans, etc. |
class |
FavoredNodesPlan
This class contains the mapping information between each region and
its favored region server list.
|
class |
LoadBalancerFactory
The class that creates a load balancer from a conf.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseHFileCleanerDelegate
Base class for the hfile cleaning function inside the master.
|
class |
BaseLogCleanerDelegate
Base class for the log cleaning function inside the master.
|
interface |
FileCleanerDelegate
General interface for cleaning files from a folder (generally an archive or
backup folder).
|
class |
HFileCleaner
This Chore, every time it runs, will clear the HFiles in the hfile archive
folder that are deletable for each HFile cleaner in the chain.
|
class |
LogCleaner
This Chore, every time it runs, will attempt to delete the HLogs in the old logs folder.
|
Modifier and Type | Class and Description |
---|---|
class |
ClosedRegionHandler
Handles CLOSED region event on Master.
|
class |
CreateTableHandler
Handler to create a table.
|
class |
DeleteTableHandler |
class |
DisableTableHandler
Handler to run disable of a table.
|
class |
DispatchMergingRegionHandler
Handles MERGE regions request on master: move the regions together(on the
same regionserver) and send MERGE RPC to regionserver.
|
class |
EnableTableHandler
Handler to run enable of a table.
|
class |
LogReplayHandler
Handle logReplay work from SSH.
|
class |
MetaServerShutdownHandler
Shutdown handler for the server hosting
hbase:meta |
class |
ModifyTableHandler |
class |
OpenedRegionHandler
Handles OPENED region event on Master.
|
class |
ServerShutdownHandler
Process server shutdown.
|
class |
TableAddFamilyHandler
Handles adding a new family to an existing table.
|
class |
TableDeleteFamilyHandler
Handles adding a new family to an existing table.
|
class |
TableEventHandler
Base class for performing operations against tables.
|
class |
TableModifyFamilyHandler
Handles adding a new family to an existing table.
|
interface |
TotesHRegionInfo
Implementors tote an HRegionInfo instance.
|
Modifier and Type | Class and Description |
---|---|
class |
CloneSnapshotHandler
Handler to Clone a snapshot.
|
class |
DisabledTableSnapshotHandler
Take a snapshot of a disabled table.
|
class |
EnabledTableSnapshotHandler
Handle the master side of taking a snapshot of an online table, regardless of snapshot type.
|
class |
MasterSnapshotVerifier
General snapshot verification on the master.
|
class |
RestoreSnapshotHandler
Handler to Restore a snapshot.
|
class |
SnapshotFileCache
Intelligently keep track of all the files for all the snapshots.
|
class |
TakeSnapshotHandler
A handler for taking snapshots from the master.
|
Modifier and Type | Class and Description |
---|---|
class |
MetricsMBeanBase
Deprecated.
|
class |
MetricsRate
Deprecated.
|
class |
MetricsString
Deprecated.
|
class |
PersistentMetricsTimeVaryingRate
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
LogMonitoring
Utility functions for reading the log4j logs that are
being written by HBase.
|
class |
MemoryBoundedLogMessageBuffer
A size-bounded repository of alerts, which are kept
in a linked list.
|
interface |
MonitoredRPCHandler
A MonitoredTask implementation optimized for use with RPC Handlers
handling frequent, short duration tasks.
|
class |
MonitoredRPCHandlerImpl
A MonitoredTask implementation designed for use with RPC Handlers
handling frequent, short duration tasks.
|
interface |
MonitoredTask |
class |
StateDumpServlet |
class |
TaskMonitor
Singleton which keeps track of tasks going on in this VM.
|
class |
ThreadMonitoring |
Modifier and Type | Class and Description |
---|---|
class |
MasterProcedureManager
A life-cycle management interface for globally barriered procedures on master.
|
class |
Procedure
A globally-barriered distributed procedure.
|
class |
ProcedureCoordinator
This is the master side of a distributed complex procedure execution.
|
interface |
ProcedureCoordinatorRpcs
RPCs for the coordinator to run a barriered procedure with subprocedures executed at
distributed members.
|
class |
ProcedureManager |
class |
ProcedureManagerHost<E extends ProcedureManager>
Provides the common setup framework and runtime services for globally
barriered procedure invocation from HBase services.
|
class |
ProcedureMember
Process to kick off and manage a running
Subprocedure on a member. |
interface |
ProcedureMemberRpcs
This is the notification interface for Procedures that encapsulates message passing from
members to a coordinator.
|
class |
RegionServerProcedureManager
A life-cycle management interface for globally barriered procedures on
region servers.
|
interface |
SubprocedureFactory
Task builder to build instances of a
ProcedureMember 's Subprocedure s. |
class |
ZKProcedureCoordinatorRpcs
ZooKeeper based
ProcedureCoordinatorRpcs for a ProcedureCoordinator |
class |
ZKProcedureMemberRpcs
ZooKeeper based controller for a procedure member.
|
class |
ZKProcedureUtil
This is a shared ZooKeeper-based znode management utils for distributed procedure.
|
Modifier and Type | Class and Description |
---|---|
class |
ReplicationProtbufUtil |
class |
RequestConverter
Helper utility to build protocol buffer requests,
or build components for protocol buffer requests.
|
class |
ResponseConverter
Helper utility to build protocol buffer responses,
or retrieve data from protocol buffer responses.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ChangedReadersObserver
If set of MapFile.Readers in Store change, implementors are notified.
|
class |
ColumnCount
Simple wrapper for a byte buffer and a counter.
|
interface |
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.
|
interface |
CompactionRequestor |
class |
CompactSplitThread
Compact region on request and then run split if appropriate
|
class |
DefaultStoreFlusher
Default implementation of StoreFlusher.
|
interface |
DeleteTracker
This interface is used for the tracking and enforcement of Deletes
during the course of a Get or Scan operation.
|
class |
DelimitedKeyPrefixRegionSplitPolicy
A custom RegionSplitPolicy implementing a SplitPolicy that groups
rows by a prefix of the row-key with a delimiter.
|
class |
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.
|
interface |
FlushRequester
Request a flush.
|
class |
HRegion
HRegion stores data for a certain region of a table.
|
class |
HRegionFileSystem
View to an on-disk Region.
|
class |
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
class |
HRegionServerCommandLine
Class responsible for parsing the command line and starting the
RegionServer.
|
class |
HStore
A Store holds a column family in a Region.
|
class |
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.
|
interface |
InternalScanner
Internal scanners differ from client-side scanners in that they operate on
HStoreKeys and byte[] instead of RowResults.
|
class |
KeyPrefixRegionSplitPolicy
A custom RegionSplitPolicy implementing a SplitPolicy that groups
rows by a prefix of the row-key
This ensures that a region is not split "inside" a prefix of a row key.
|
class |
KeyValueHeap
Implements a heap merge across any number of KeyValueScanners.
|
interface |
KeyValueScanner
Scanner that returns the next KeyValue.
|
class |
KeyValueSkipListSet
|
interface |
LastSequenceId
Last flushed sequence Ids for the regions on region server
|
interface |
LeaseListener
LeaseListener is an interface meant to be implemented by users of the Leases
class.
|
class |
Leases
Leases
There are several server classes in HBase that need to track external
clients that occasionally send heartbeats.
|
class |
LruHashMap<K extends HeapSize,V extends HeapSize>
The LruHashMap is a memory-aware HashMap with a configurable maximum
memory footprint.
|
class |
MemStore
The MemStore holds in-memory modifications to the Store.
|
class |
MemStoreChunkPool
A pool of
MemStoreLAB.Chunk instances. |
class |
MemStoreLAB
A memstore-local allocation buffer.
|
class |
MetricsRegion
This is the glue between the HRegion and whatever hadoop shim layer
is loaded (hbase-hadoop1-compat or hbase-hadoop2-compat).
|
class |
MetricsRegionServer
This class is for maintaining the various regionserver statistics
and publishing them through the metrics interfaces.
|
class |
MetricsRegionWrapperImpl |
class |
MiniBatchOperationInProgress<T>
Wraps together the mutations which are applied as a batch to the region and their operation
status and WALEdits.
|
class |
MultiVersionConsistencyControl
Manages the read/write consistency within memstore.
|
class |
NonLazyKeyValueScanner
A "non-lazy" scanner which always does a real seek operation.
|
class |
NonReversedNonLazyKeyValueScanner
A "non-reversed & non-lazy" scanner which does not support backward scanning
and always does a real seek operation.
|
class |
OperationStatus
This class stores the Operation status code and the exception message
that occurs in case of failure of operations like put, delete, etc.
|
class |
RegionMergeTransaction
Executes region merge as a "transaction".
|
class |
RegionOpeningState |
interface |
RegionScanner
RegionScanner describes iterators over rows in an HRegion.
|
class |
RegionServerAccounting
RegionServerAccounting keeps record of some basic real time information about
the Region Server.
|
interface |
RegionServerServices
Services provided by
HRegionServer |
interface |
ReplicationService
Gateway to Cluster Replication.
|
interface |
ReplicationSinkService
A sink for a replication stream has to expose this service.
|
interface |
ReplicationSourceService
A source for a replication stream has to expose this service.
|
class |
ReversedKeyValueHeap
ReversedKeyValueHeap is used for supporting reversed scanning.
|
class |
RSDumpServlet |
class |
RSStatusServlet |
class |
ScanDeleteTracker
This class is responsible for the tracking and enforcement of Deletes
during the course of a Scan operation.
|
class |
ScanInfo
Immutable information for scans over a store.
|
class |
ScanQueryMatcher
A query matcher that is specifically designed for the scan case.
|
class |
ScanType
Enum to distinguish general scan types.
|
class |
ScanWildcardColumnTracker
Keeps track of the columns for a scan if they are not explicitly specified
|
class |
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.
|
class |
ShutdownHook
Manage regionserver shutdown hooks.
|
class |
SplitLogWorker
This worker is spawned in every regionserver (should we also spawn one in
the master?).
|
class |
SplitTransaction
Executes region split as a "transaction".
|
interface |
Store
Interface for objects that hold a column family in a Region.
|
interface |
StoreConfigInformation
A more restricted interface for HStore.
|
class |
StoreEngine<SF extends org.apache.hadoop.hbase.regionserver.StoreFlusher,CP extends CompactionPolicy,C extends Compactor,SFM extends StoreFileManager>
StoreEngine is a factory that can create the objects necessary for HStore to operate.
|
class |
StoreFileInfo
Describe a StoreFile (hfile, reference, link)
|
interface |
StoreFileManager
Manages the store files and basic metadata about that that determines the logical structure
(e.g.
|
class |
StoreScanner
Scanner scans both the memstore and the Store.
|
class |
StoreUtils
Utility functions for region server storage layer.
|
class |
StripeMultiFileWriter
Base class for cell sink that separates the provided cells into multiple files.
|
class |
StripeStoreConfig
Configuration class for stripe store and compactions.
|
class |
StripeStoreFileManager
Stripe implementation of StoreFileManager.
|
class |
StripeStoreFlusher
Stripe implementation of StoreFlusher.
|
class |
TimeRangeTracker
Stores the minimum and maximum timestamp values (both are inclusive).
|
Modifier and Type | Class and Description |
---|---|
class |
CompactionConfiguration
Compaction configuration for a particular instance of HStore.
|
class |
CompactionContext
This class holds all "physical" details necessary to run a compaction,
and abstracts away the details specific to a particular compaction.
|
class |
CompactionPolicy
A compaction policy determines how to select files for compaction,
how to compact them, and how to generate the compacted files.
|
class |
CompactionProgress
This class holds information relevant for tracking the progress of a
compaction.
|
class |
Compactor
A compactor is a compaction algorithm associated a given policy.
|
class |
CurrentHourProvider |
class |
DefaultCompactor
Compact passed set of files.
|
class |
ExploringCompactionPolicy
Class to pick which files if any to compact together.
|
class |
OffPeakHours |
class |
RatioBasedCompactionPolicy
The default algorithm for selecting files for compaction.
|
class |
StripeCompactionPolicy
Stripe store implementation of compaction policy.
|
class |
StripeCompactor
This is the placeholder for stripe compactor.
|
Modifier and Type | Class and Description |
---|---|
class |
CloseMetaHandler
Handles closing of the root region on a region server.
|
class |
CloseRegionHandler
Handles closing of a region on a region server.
|
class |
HLogSplitterHandler
Handles log splitting a wal
|
class |
OpenMetaHandler
Handles opening of a meta region on a region server.
|
class |
OpenRegionHandler
Handles opening of a region on a region server.
|
class |
ParallelSeekHandler
Handler to seek storefiles in parallel.
|
Modifier and Type | Class and Description |
---|---|
class |
FlushSnapshotSubprocedure
This online snapshot implementation uses the distributed procedure framework to force a
store flush and then records the hfiles.
|
Modifier and Type | Class and Description |
---|---|
class |
Compressor
A set of static functions for running our custom WAL compression/decompression.
|
interface |
HLog |
class |
HLogFactory |
class |
HLogKey
A Key for an entry in the change log.
|
class |
HLogSplitter
This class is responsible for splitting up a bunch of regionserver commit log
files that are no longer being written to, into new files, one per region for
region to replay on startup.
|
class |
HLogUtil |
class |
MetricsWAL
Class used to push numbers about the WAL into the metrics subsystem.
|
class |
MetricsWALEditsReplay
Class used to push numbers about WAL edits replay into the metrics subsystem.
|
class |
OrphanHLogAfterSplitException |
class |
SecureWALCellCodec
A WALCellCodec that encrypts the WALedits.
|
interface |
WALActionsListener
Get notification of
FSHLog /WAL log events. |
class |
WALCoprocessorHost
Implements the coprocessor environment and runtime support for coprocessors
loaded within a
FSHLog . |
class |
WALEdit
WALEdit: Used in HBase's transaction log (WAL) to represent
the collection of edits (KeyValue objects) corresponding to a
single transaction.
|
class |
WALEditsReplaySink
This class is responsible for replaying the edits coming from a failed region server.
|
class |
WriterBase
Context used by our wal dictionary compressor.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ReplicationListener
The replication listener interface can be implemented if a class needs to subscribe to events
generated by the ReplicationTracker.
|
class |
ReplicationPeer
This class acts as a wrapper for all the objects used to identify and
communicate with remote peers and is responsible for answering to expired
sessions and re-establishing the ZK connections.
|
interface |
ReplicationPeers
This provides an interface for maintaining a set of peer clusters.
|
interface |
ReplicationQueues
This provides an interface for maintaining a region server's replication queues.
|
interface |
ReplicationTracker
This is the interface for a Replication Tracker.
|
Modifier and Type | Class and Description |
---|---|
class |
MetricsSink
This class is for maintaining the various replication statistics for a sink and publishing them
through the metrics interfaces.
|
class |
MetricsSource
This class is for maintaining the various replication statistics for a source and publishing them
through the metrics interfaces.
|
class |
Replication
Gateway to Replication.
|
class |
ReplicationHLogReaderManager
Wrapper class around HLog to help manage the implementation details
such as compression.
|
class |
ReplicationSink
This class is responsible for replicating the edits coming
from another cluster.
|
class |
ReplicationSource
Class that handles the source of a replication stream.
|
interface |
ReplicationSourceInterface
Interface that defines a replication source
|
class |
ReplicationSourceManager
This class is responsible to manage all the replication
sources.
|
class |
ReplicationThrottler
Per-peer per-node throttling controller for replication: enabled if
bandwidth > 0, a cycle = 100ms, by throttling we guarantee data pushed
to peer within each cycle won't exceed 'bandwidth' bytes
|
Modifier and Type | Class and Description |
---|---|
class |
ExistsResource |
class |
MetricsREST |
class |
MultiRowResource |
interface |
ProtobufMessageHandler
Common interface for models capable of supporting protobuf marshalling
and unmarshalling.
|
class |
RegionsResource |
class |
ResourceBase |
class |
ResourceConfig |
class |
RESTServer
Main class for launching REST gateway as a servlet hosted by Jetty.
|
class |
RESTServlet
Singleton class encapsulating global REST servlet state and functions.
|
class |
RESTServletContainer
REST servlet container.
|
class |
ResultGenerator |
class |
RootResource |
class |
RowResource |
class |
RowResultGenerator |
class |
RowSpec
Parses a path based row/column/timestamp specification into its component
elements.
|
class |
ScannerInstanceResource |
class |
ScannerResource |
class |
ScannerResultGenerator |
class |
SchemaResource |
class |
StorageClusterStatusResource |
class |
StorageClusterVersionResource |
class |
TableResource |
class |
TableScanResource |
class |
VersionResource
Implements REST software version reporting
|
Modifier and Type | Class and Description |
---|---|
class |
GZIPRequestStream |
class |
GZIPRequestWrapper |
class |
GZIPResponseStream |
class |
GZIPResponseWrapper |
Modifier and Type | Class and Description |
---|---|
class |
CellModel
Representation of a cell.
|
class |
CellSetModel
Representation of a grouping of cells.
|
class |
ColumnSchemaModel
Representation of a column family schema.
|
class |
RowModel
Representation of a row.
|
class |
ScannerModel
A representation of Scanner parameters.
|
class |
StorageClusterStatusModel
Representation of the status of a storage cluster:
|
class |
StorageClusterVersionModel
Simple representation of the version of the storage cluster
|
class |
TableInfoModel
Representation of a list of table regions.
|
class |
TableListModel
Simple representation of a list of table names.
|
class |
TableModel
Simple representation of a table name.
|
class |
TableRegionModel
Representation of a region of a table and its current location on the
storage cluster.
|
class |
TableSchemaModel
A representation of HBase table descriptors.
|
class |
VersionModel
A representation of the collection of versions of the REST gateway software
components.
|
Modifier and Type | Class and Description |
---|---|
class |
JAXBContextResolver
Plumbing for hooking up Jersey's JSON entity body encoding and decoding
support to JAXB.
|
Modifier and Type | Class and Description |
---|---|
class |
ProtobufMessageBodyConsumer
Adapter for hooking up Jersey content processing dispatch to
ProtobufMessageHandler interface capable handlers for decoding protobuf input.
|
Modifier and Type | Class and Description |
---|---|
class |
PlainTextMessageBodyProducer
An adapter between Jersey and Object.toString().
|
class |
ProtobufMessageBodyProducer
An adapter between Jersey and ProtobufMessageHandler implementors.
|
Modifier and Type | Class and Description |
---|---|
class |
AuthMethod
Authentication method
|
class |
EncryptionUtil
Some static utility methods for encryption uses in hbase-client.
|
class |
HBasePolicyProvider
Implementation of secure Hadoop policy provider for mapping
protocol interfaces to hbase-policy.xml entries.
|
class |
HBaseSaslRpcClient
A utility class that encapsulates SASL logic for RPC client.
|
class |
HBaseSaslRpcServer
A utility class for dealing with SASL on RPC server
|
class |
SaslStatus |
class |
SaslUtil |
class |
SecureBulkLoadUtil |
class |
SecurityInfo
Maps RPC protocol interfaces to required configuration
|
class |
SecurityUtil
Security related generic utility methods.
|
class |
User
Wrapper to abstract out usage of user and group information in HBase.
|
class |
UserProvider
Provide an instance of a user.
|
Modifier and Type | Class and Description |
---|---|
class |
AccessControlLists
Maintains lists of permission grants to users and groups to allow for
authorization checks by
AccessController . |
class |
AuthResult
Represents the result of an authorization check for logging and error
reporting.
|
class |
SecureBulkLoadEndpoint
Coprocessor service for bulk loads in secure mode.
|
class |
TableAuthManager
Performs authorization checks for a given user's assigned permissions
|
class |
TablePermission
Represents an authorization for access for the given actions, optionally
restricted to the given column family or column qualifier, over the
given table.
|
class |
UserPermission
Represents an authorization for access over the given table, column family
plus qualifier, for the given user.
|
class |
ZKPermissionWatcher
Handles synchronization of access control list entries and updates
throughout all nodes in the cluster.
|
Modifier and Type | Class and Description |
---|---|
class |
AuthenticationKey
Represents a secret key used for signing and verifying authentication tokens
by
AuthenticationTokenSecretManager . |
class |
AuthenticationTokenIdentifier
Represents the identity information stored in an HBase authentication token.
|
class |
AuthenticationTokenSecretManager
Manages an internal list of secret keys used to sign new authentication
tokens as they are generated, and to valid existing tokens used for
authentication.
|
class |
AuthenticationTokenSelector |
class |
FsDelegationToken
Helper class to obtain a filesystem delegation token.
|
class |
TokenProvider
Provides a service for obtaining authentication tokens via the
AuthenticationProtos AuthenticationService coprocessor service. |
class |
TokenUtil
Utility methods for obtaining authentication tokens.
|
class |
ZKSecretWatcher
Synchronizes token encryption keys across cluster nodes.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultScanLabelGenerator
This is the default implementation for ScanLabelGenerator.
|
class |
DefaultVisibilityLabelServiceImpl |
class |
EnforcingScanLabelGenerator
This ScanLabelGenerator enforces a set of predefined authorizations for a
given user, the set defined by the admin using the VisibilityClient admin
interface or the set_auths shell command.
|
class |
ExpressionExpander |
class |
ExpressionParser |
class |
ParseException |
class |
SimpleScanLabelGenerator
This is a simple implementation for ScanLabelGenerator.
|
class |
VisibilityConstants |
interface |
VisibilityLabelOrdinalProvider |
class |
VisibilityLabelsCache
Maintains the cache for visibility labels and also uses the zookeeper to update the labels in the
system.
|
class |
VisibilityLabelServiceManager
Manages singleton instance of
VisibilityLabelService |
class |
VisibilityLabelsValidator
A simple validator that validates the labels passed
|
class |
VisibilityScanDeleteTracker
Similar to ScanDeletTracker but tracks the visibility expression also before
deciding if a Cell can be considered deleted
|
class |
VisibilityUtils
Utility method to support visibility
|
class |
ZKVisibilityLabelWatcher
A zk watcher that watches the labels table znode.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ExpressionNode |
class |
LeafExpressionNode |
class |
NonLeafExpressionNode |
class |
Operator |
Modifier and Type | Class and Description |
---|---|
class |
ClientSnapshotDescriptionUtils
Class to help with dealing with a snapshot description on the client side.
|
class |
RestoreSnapshotHelper
Helper to Restore/Clone a Snapshot
|
class |
SnapshotManifest
Utility class to help read/write the Snapshot Manifest.
|
class |
SnapshotManifestV1
DO NOT USE DIRECTLY.
|
class |
SnapshotManifestV2
DO NOT USE DIRECTLY.
|
class |
SnapshotReferenceUtil
Utility methods for interacting with the snapshot referenced files.
|
Modifier and Type | Class and Description |
---|---|
class |
CallQueue
A BlockingQueue reports waiting time in queue and queue length to
ThriftMetrics.
|
class |
HbaseHandlerMetricsProxy
Converts a Hbase.Iface using InvocationHandler so that it reports process
time of each call to ThriftMetrics.
|
class |
HThreadedSelectorServerArgs
A TThreadedSelectorServer.Args that reads hadoop configuration
|
class |
TBoundedThreadPoolServer
A bounded thread pool server customized for HBase.
|
class |
ThriftMetrics
This class is for maintaining the various statistics of thrift server
and publishing them through the metrics interfaces.
|
class |
ThriftServer
ThriftServer- this class starts up a Thrift server which implements the
Hbase API specified in the Hbase.thrift IDL file.
|
class |
ThriftServerRunner
ThriftServerRunner - this class starts up a Thrift server which implements
the Hbase API specified in the Hbase.thrift IDL file.
|
class |
ThriftUtilities |
Modifier and Type | Class and Description |
---|---|
class |
ThriftHBaseServiceHandler
This class is a glue object that connects Thrift RPC calls to the HBase client API primarily
defined in the HTableInterface.
|
class |
ThriftServer
ThriftServer - this class starts up a Thrift server which implements the HBase API specified in the
HbaseClient.thrift IDL file.
|
class |
ThriftUtilities |
Modifier and Type | Class and Description |
---|---|
class |
AbstractHBaseTool
Common base class used for HBase command-line tools.
|
class |
Addressing
Utility for network addresses, resolving and naming.
|
class |
ArrayUtils
A set of array utility functions that return reasonable values in cases where an array is
allocated or if it is null
|
interface |
BloomFilter
Defines the general behavior of a bloom filter.
|
interface |
BloomFilterBase
Common methods Bloom filter methods required at read and write time.
|
class |
BloomFilterFactory
Handles Bloom filter initialization based on configuration and serialized
metadata in the reader and writer of
StoreFile . |
interface |
BloomFilterWriter
Specifies methods needed to add elements to a Bloom filter and serialize the
resulting Bloom filter as a sequence of bytes.
|
class |
ByteBloomFilter
Implements a Bloom filter, as defined by Bloom in 1970.
|
class |
ByteBufferArray
This class manages an array of ByteBuffers with a default size 4MB.
|
interface |
CancelableProgressable
Similar interface as
Progressable but returns
a boolean to support canceling the operation. |
class |
Classes
Utilities for class manipulation.
|
class |
ClassLoaderBase
Base class loader that defines couple shared constants used
by sub-classes.
|
class |
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
|
class |
CollectionBackedScanner
Utility scanner that wraps a sortable collection and serves
as a KeyValueScanner.
|
class |
CollectionUtils
Utility methods for dealing with Collections, including treating null collections as empty.
|
class |
CompoundBloomFilter
A Bloom filter implementation built on top of
ByteBloomFilter ,
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. |
class |
CompoundBloomFilterBase |
class |
CompoundBloomFilterWriter
Adds methods required for writing a compound Bloom filter to the data
section of an
HFile to the
CompoundBloomFilter class. |
class |
ConcurrentIndex<K,V>
A simple concurrent map of sets.
|
class |
ConfigUtil
Some configuration related utilities
|
class |
ConnectionCache
A utility to store user specific HConnections in memory.
|
class |
CoprocessorClassLoader
ClassLoader used to load classes for Coprocessor instances.
|
class |
DefaultEnvironmentEdge
Default implementation of an environment edge.
|
class |
DirectMemoryUtils
Utilities for interacting with and monitoring DirectByteBuffer allocations.
|
class |
DrainBarrier
A simple barrier that can be used by classes that need to wait for some operations to
finish before stopping/closing/etc.
|
class |
DynamicClassLoader
This is a class loader that can load classes dynamically from new
jar files under a configured folder.
|
interface |
EnvironmentEdge
Has some basic interaction with the environment.
|
class |
EnvironmentEdgeManager
Manages a singleton instance of the environment edge.
|
class |
FSHDFSUtils
Implementation for hdfs
|
class |
FSMapRUtils
MapR implementation.
|
class |
FSTableDescriptors
Implementation of
TableDescriptors that reads descriptors from the
passed filesystem. |
class |
FSUtils
Utility methods for interacting with the underlying file system.
|
class |
FSVisitor
Utility methods for interacting with the hbase.root file system.
|
class |
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.
|
class |
HasThread
Abstract class which contains a Thread and delegates the common Thread
methods to that instance.
|
class |
HBaseConfTool
Tool that prints out a configuration.
|
class |
HBaseFsckRepair
This class contains helper methods that repair parts of hbase's filesystem
contents.
|
class |
IdLock
Allows multiple concurrent clients to lock on a numeric id with a minimal
memory overhead.
|
class |
IncrementingEnvironmentEdge
Uses an incrementing algorithm instead of the default.
|
class |
InfoServer
Create a Jetty embedded server to answer http requests.
|
class |
IterableUtils
Utility methods for Iterable including null-safe handlers.
|
class |
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.
|
class |
JVMClusterUtil
Utility used running a cluster all in the one JVM.
|
class |
JvmPauseMonitor
Class which sets up a simple thread which runs in a loop sleeping
for a short interval of time.
|
class |
JvmVersion
Certain JVM versions are known to be unstable with HBase.
|
class |
KeyLocker<K extends Comparable<? super K>>
A utility class to manage a set of locks.
|
interface |
KeyRange
A key range use in split coverage.
|
class |
ManualEnvironmentEdge
An environment edge that uses a manually set value.
|
class |
MetaUtils
Contains utility methods for manipulating HBase meta tables.
|
class |
Methods |
class |
ModifyRegionUtils
Utility methods for interacting with the regions.
|
class |
MultiHConnection
Provides ability to create multiple HConnection instances and allows to process a batch of
actions using HConnection.processBatchCallback()
|
class |
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".
|
class |
PoolMap<K,V>
The
PoolMap maps a key to a collection of values, the elements
of which are managed by a pool. |
class |
ProtoUtil |
class |
ReflectionUtils |
class |
RegionSizeCalculator
Computes size of each region for given table and given column families.
|
class |
RegionSplitCalculator<R extends KeyRange>
This is a generic region split calculator.
|
class |
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. |
class |
RetryCounter |
class |
RetryCounterFactory |
class |
ServerCommandLine
Base class for command lines that start up various HBase daemons.
|
class |
Sleeper
Sleeper for current thread.
|
class |
SortedCopyOnWriteSet<E>
|
class |
Strings
Utility for Strings.
|
class |
Threads
Thread Utility
|
class |
Triple<A,B,C>
Utility class to manage a triple.
|
class |
Writables
Utility class with methods for manipulating Writable objects
|
Modifier and Type | Class and Description |
---|---|
class |
ByteRangeSet
Performance oriented class for de-duping and storing arbitrary byte[]'s arriving in non-sorted
order.
|
Modifier and Type | Class and Description |
---|---|
class |
ByteRangeHashSet
This is probably the best implementation of ByteRangeSet at the moment, though a HashMap produces
garbage when adding a new element to it.
|
class |
ByteRangeTreeSet
Not currently used in production, but here as a benchmark comparison against ByteRangeHashSet.
|
Modifier and Type | Class and Description |
---|---|
class |
HFileCorruptionChecker
This class marches through all of the region's hfiles and verifies that
they are all valid files.
|
Modifier and Type | Class and Description |
---|---|
class |
LoadTestKVGenerator
A generator of random keys and values for load testing.
|
class |
RedundantKVGenerator
Generate list of key values which are very useful to test data block encoding
and compression.
|
Modifier and Type | Class and Description |
---|---|
class |
UFIntTool
UFInt is an abbreviation for Unsigned Fixed-width Integer.
|
class |
UVIntTool
Simple Variable Length Integer encoding.
|
class |
UVLongTool
Simple Variable Length Integer encoding.
|
Modifier and Type | Class and Description |
---|---|
class |
ClusterStatusTracker
Tracker on cluster settings up in zookeeper.
|
class |
DeletionListener
A ZooKeeper watcher meant to detect deletions of ZNodes.
|
class |
DrainingServerTracker
Tracks the list of draining region servers via ZK.
|
class |
EmptyWatcher
An empty ZooKeeper watcher
|
class |
LoadBalancerTracker
Tracks the load balancer state up in ZK
|
class |
MasterAddressTracker
Manages the location of the current active Master for the RegionServer.
|
class |
MetaRegionTracker
Tracks the meta region server location node in zookeeper.
|
class |
RecoverableZooKeeper
A zookeeper that can handle 'recoverable' errors.
|
class |
RecoveringRegionWatcher
Watcher used to be notified of the recovering region coming out of recovering state
|
class |
RegionServerTracker
Tracks the online region servers via ZK.
|
class |
ZKAssign
Utility class for doing region assignment in ZooKeeper.
|
class |
ZKClusterId
Publishes and synchronizes a unique identifier specific to a given HBase
cluster.
|
class |
ZKConfig
Utility methods for reading, and building the ZooKeeper configuration.
|
class |
ZKLeaderManager
Deprecated.
Not used
|
class |
ZKSplitLog
Common methods and attributes used by
SplitLogManager and SplitLogWorker
running distributed splitting of WAL logs. |
class |
ZKTable
Helper class for table state tracking for use by AssignmentManager.
|
class |
ZKTableReadOnly
Non-instantiable class that provides helper functions for
clients other than AssignmentManager for reading the
state of a table in ZK.
|
class |
ZKUtil
Internal HBase utility class for ZooKeeper.
|
class |
ZooKeeperListener
Base class for internal listeners of ZooKeeper events.
|
class |
ZooKeeperNodeTracker
Tracks the availability and value of a single ZooKeeper node.
|
class |
ZooKeeperWatcher
Acts as the single ZooKeeper Watcher.
|
Modifier and Type | Class and Description |
---|---|
class |
ZKInterProcessLockBase
ZooKeeper based HLock implementation.
|
class |
ZKInterProcessReadLock
ZooKeeper based read lock: does not exclude other read locks, but excludes
and is excluded by write locks.
|
class |
ZKInterProcessReadWriteLock
ZooKeeper based implementation of
InterProcessReadWriteLock . |
class |
ZKInterProcessWriteLock
ZooKeeper based write lock:
|
Modifier and Type | Class and Description |
---|---|
class |
MetricMutableQuantiles
Watches a stream of long values, maintaining online estimates of specific quantiles with provably
low error bounds.
|
Modifier and Type | Class and Description |
---|---|
class |
MetricQuantile
Specifies a quantile (with error bounds) to be watched by a
MetricSampleQuantiles object. |
class |
MetricSampleQuantiles
Implementation of the Cormode, Korn, Muthukrishnan, and Srivastava algorithm
for streaming calculation of targeted high-percentile epsilon-approximate
quantiles.
|
Copyright © 2014 The Apache Software Foundation. All rights reserved.