Interface | Description |
---|---|
BloomFilter |
Implements a Bloom filter, as defined by Bloom in 1970.
|
BloomFilterBase |
Common methods Bloom filter methods required at read and write time.
|
BloomFilterWriter |
Specifies methods needed to add elements to a Bloom filter and serialize the
resulting Bloom filter as a sequence of bytes.
|
CancelableProgressable |
Similar interface as
Progressable but returns
a boolean to support canceling the operation. |
FileStatusFilter | |
FSVisitor.StoreFileVisitor | |
HBaseFsck.ErrorReporter | |
JSONBean.Writer |
Use dumping out mbeans as JSON.
|
KeyRange |
A key range use in split coverage.
|
ModifyRegionUtils.RegionEditTask | |
ModifyRegionUtils.RegionFillTask | |
RegionSplitter.SplitAlgorithm |
A generic interface for the RegionSplitter code to use for all it's
functionality.
|
Class | Description |
---|---|
AbstractFileStatusFilter |
Typical base class for file status filter.
|
BloomContext |
The bloom context that is used by the StorefileWriter to add the bloom details
per cell
|
BloomFilterChunk |
The basic building block for the
CompoundBloomFilter |
BloomFilterFactory |
Handles Bloom filter initialization based on configuration and serialized
metadata in the reader and writer of
StoreFile . |
BloomFilterUtil |
Utility methods related to BloomFilters
|
BoundedPriorityBlockingQueue<E> |
A generic bounded blocking Priority-Queue.
|
CollectionBackedScanner |
Utility scanner that wraps a sortable collection and serves as a KeyValueScanner.
|
CompressionTest |
Compression validation test.
|
ConfigurationUtil |
Utilities for storing more complex collection types in
Configuration instances. |
ConnectionCache |
A utility to store user specific HConnections in memory.
|
DirectMemoryUtils |
Utilities for interacting with and monitoring DirectByteBuffer allocations.
|
EncryptionTest | |
FSHDFSUtils |
Implementation for hdfs
|
FSMapRUtils |
MapR implementation.
|
FSTableDescriptors |
Implementation of
TableDescriptors that reads descriptors from the
passed filesystem. |
FSUtils |
Utility methods for interacting with the underlying file system.
|
FSUtils.BlackListDirFilter |
Directory filter that doesn't include any of the directories in the specified blacklist
|
FSUtils.DirFilter |
A
PathFilter that only allows directories. |
FSUtils.FamilyDirFilter |
Filter for all dirs that are legal column family names.
|
FSUtils.HFileFilter |
Filter for HFiles that excludes reference files.
|
FSUtils.HFileLinkFilter |
Filter for HFileLinks (StoreFiles and HFiles not included).
|
FSUtils.ReferenceFileFilter | |
FSUtils.RegionDirFilter |
Filter for all dirs that don't start with '.'
|
FSUtils.UserTableDirFilter |
A
PathFilter that returns usertable directories. |
FSVisitor |
Utility methods for interacting with the hbase.root file system.
|
GetJavaProperty |
A generic way for querying Java properties.
|
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.
|
HBaseConfTool |
Tool that prints out a configuration.
|
HBaseFsck |
HBaseFsck (hbck) is a tool for checking and repairing region consistency and
table integrity problems in a corrupted HBase.
|
HBaseFsck.HbckInfo |
Maintain information about a particular region.
|
HBaseFsckRepair |
This class contains helper methods that repair parts of hbase's filesystem
contents.
|
HFileArchiveUtil |
Helper class for all utilities related to archival/retrieval of HFiles
|
HttpServerUtil |
HttpServer utility.
|
IdLock |
Allows multiple concurrent clients to lock on a numeric id with a minimal
memory overhead.
|
IdLock.Entry |
An entry returned to the client as a lock object
|
IdReadWriteLock |
Allows multiple concurrent clients to lock on a numeric id with ReentrantReadWriteLock.
|
JSONBean |
Utility for doing JSON and MBeans.
|
JSONMetricUtil | |
JVMClusterUtil |
Utility used running a cluster all in the one JVM.
|
JVMClusterUtil.MasterThread |
Datastructure to hold Master Thread and Master instance
|
JVMClusterUtil.RegionServerThread |
Datastructure to hold RegionServer Thread and RegionServer instance
|
JvmPauseMonitor |
Class which sets up a simple thread which runs in a loop sleeping
for a short interval of time.
|
JvmVersion |
Certain JVM versions are known to be unstable with HBase.
|
ManualEnvironmentEdge |
An environment edge that uses a manually set value.
|
ModifyRegionUtils |
Utility methods for interacting with the regions.
|
MultiHConnection |
Provides ability to create multiple Connection instances and allows to process a batch of
actions using CHTable.doBatchWithCallback()
|
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".
|
NettyEventLoopGroupConfig |
Event loop group related config.
|
ProtoUtil | |
RegionMover |
Tool for loading/unloading regions to/from given regionserver This tool can be run from Command
line directly as a utility.
|
RegionMover.RegionMoverBuilder |
Builder for Region mover.
|
RegionSplitCalculator<R extends KeyRange> |
This is a generic region split calculator.
|
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. |
RegionSplitter.HexStringSplit |
HexStringSplit is a well-known
RegionSplitter.SplitAlgorithm for choosing region
boundaries. |
RegionSplitter.UniformSplit |
A SplitAlgorithm that divides the space of possible keys evenly.
|
RollingStatCalculator |
This class maintains mean and variation for any sequence of input provided to it.
|
RowBloomContext |
Handles ROW bloom related context.
|
RowColBloomContext |
Handles ROWCOL bloom related context.
|
ServerCommandLine |
Base class for command lines that start up various HBase daemons.
|
ServerRegionReplicaUtil |
Similar to
RegionReplicaUtil but for the server side |
ShutdownHookManager |
This class provides ShutdownHookManager shims for HBase to interact with the Hadoop 1.0.x and the
Hadoop 2.0+ series.
|
SortedList<E> |
Simple sorted list implementation that uses
ArrayList as
the underlying collection so we can support RandomAccess. |
StealJobQueue<T> |
This queue allows a ThreadPoolExecutor to steal jobs from another ThreadPoolExecutor.
|
YammerHistogramUtils |
Utility functions for working with Yammer Metrics.
|
ZKDataMigrator |
utlity method to migrate zookeeper data across HBase versions.
|
Enum | Description |
---|---|
HBaseFsck.ErrorReporter.ERROR_CODE | |
IdReadWriteLock.ReferenceType |
Exception | Description |
---|---|
HBaseFsck.RegionRepairException |
Exception thrown when a integrity repair operation fails in an
unresolvable way.
|
LeaseNotRecoveredException |
Thrown when the lease was expected to be recovered,
but the file can't be opened.
|
Copyright © 2007–2017 The Apache Software Foundation. All rights reserved.