|
||||||||||
PREV PACKAGE NEXT PACKAGE | FRAMES NO FRAMES |
Interface Summary | |
---|---|
BloomFilter | Defines the general behavior of a bloom filter. |
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. |
FSVisitor.LogFileVisitor | |
FSVisitor.RecoveredEditsVisitor | |
FSVisitor.RegionVisitor | |
FSVisitor.StoreFileVisitor | |
HBaseFsck.ErrorReporter | |
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 Summary | |
---|---|
AbstractHBaseTool | Common base class used for HBase command-line tools. |
BloomFilterFactory | Handles Bloom filter initialization based on configuration and serialized
metadata in the reader and writer of StoreFile . |
BoundedConcurrentLinkedQueue<T> | A ConcurrentLinkedQueue that enforces a maximum queue size. |
ByteBloomFilter | Implements a Bloom filter, as defined by Bloom in 1970. |
CollectionBackedScanner | Utility scanner that wraps a sortable collection and serves as a KeyValueScanner. |
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. |
CompoundBloomFilterBase | |
CompoundBloomFilterWriter | Adds methods required for writing a compound Bloom filter to the data
section of an HFile to the
CompoundBloomFilter class. |
CompressionTest | Compression validation test. |
ConfigurationUtil | Utilities for storing more complex collection types in
Configuration instances. |
ConfigUtil | Some configuration related utilities |
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. |
FSTableDescriptorMigrationToSubdir | Deprecated. will be removed for the major release after 0.96. |
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.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 |
HFileV1Detector | Tool to detect presence of any HFileV1 in the given directory. |
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 |
InfoServer | Create a Jetty embedded server to answer http requests. |
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. |
MapreduceDependencyClasspathTool | Generate a classpath string containing any jars required by mapreduce jobs. |
Merge | Utility that can merge any two regions in the same table: adjacent, overlapping or disjoint. |
MetaUtils | Contains utility methods for manipulating HBase meta tables. |
ModifyRegionUtils | Utility methods for interacting with the regions. |
MultiHConnection | Provides ability to create multiple HConnection instances and allows to process a batch of actions using HConnection.processBatchCallback() |
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". |
ProtoUtil | |
RegionSizeCalculator | Computes size of each region for given table and given column families. |
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. |
ServerCommandLine | Base class for command lines that start up various HBase daemons. |
ShutdownHookManager | This class provides ShutdownHookManager shims for HBase to interact with the Hadoop 1.0.x and the Hadoop 2.0+ series. |
SortedCopyOnWriteSet<E> | Simple SortedSet implementation that uses an internal
TreeSet to provide ordering. |
SortedList<E> | Simple sorted list implementation that uses ArrayList as
the underlying collection so we can support RandomAccess. |
YammerHistogramUtils | Utility functions for working with Yammer Metrics. |
ZKDataMigrator | Tool to migrate zookeeper data of older hbase versions(<0.95.0) to PB. |
Enum Summary | |
---|---|
HBaseFsck.ErrorReporter.ERROR_CODE |
Exception Summary | |
---|---|
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. |
|
||||||||||
PREV PACKAGE NEXT PACKAGE | FRAMES NO FRAMES |