| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.filter | Provides row-level filters applied to HRegion scan results during calls to
  ResultScanner.next(). | 
| org.apache.hadoop.hbase.io | |
| org.apache.hadoop.hbase.io.encoding | |
| org.apache.hadoop.hbase.io.hfile | Provides implementations of  HFileand HFileBlockCache. | 
| org.apache.hadoop.hbase.io.hfile.bucket | Provides  BucketCache, an implementation ofBlockCache. | 
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.util | |
| org.apache.hadoop.hbase.wal | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | ExtendedCellExtension to  Cellwith server side required functions. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ByteBufferExtendedCellThis class is a server side extension to the  Cellinterface. | 
| class  | ByteBufferKeyOnlyKeyValueThis is a key only Cell implementation which is identical to  KeyValue.KeyOnlyKeyValuewith respect to key serialization but have its data in the form of Byte buffer
 (onheap and offheap). | 
| class  | ByteBufferKeyValueThis Cell is an implementation of  ByteBufferExtendedCellwhere the data resides in
 off heap/ on heap ByteBuffer | 
| class  | IndividualBytesFieldCell | 
| class  | KeyValueAn HBase Key/Value. | 
| static class  | KeyValue.KeyOnlyKeyValueA 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. | 
| class  | NoTagsByteBufferKeyValueAn extension of the ByteBufferKeyValue where the tags length is always 0 | 
| class  | NoTagsKeyValueAn extension of the KeyValue where the tags length is always 0 | 
| private static class  | PrivateCellUtil.EmptyByteBufferExtendedCellThese cells are used in reseeks/seeks to improve the read performance. | 
| private static class  | PrivateCellUtil.EmptyCellThese cells are used in reseeks/seeks to improve the read performance. | 
| private static class  | PrivateCellUtil.FirstOnRowByteBufferExtendedCell | 
| private static class  | PrivateCellUtil.FirstOnRowCell | 
| private static class  | PrivateCellUtil.FirstOnRowColByteBufferExtendedCell | 
| private static class  | PrivateCellUtil.FirstOnRowColCell | 
| private static class  | PrivateCellUtil.FirstOnRowColTSByteBufferExtendedCell | 
| private static class  | PrivateCellUtil.FirstOnRowColTSCell | 
| private static class  | PrivateCellUtil.FirstOnRowDeleteFamilyCell | 
| private static class  | PrivateCellUtil.LastOnRowByteBufferExtendedCell | 
| private static class  | PrivateCellUtil.LastOnRowCell | 
| private static class  | PrivateCellUtil.LastOnRowColByteBufferExtendedCell | 
| private static class  | PrivateCellUtil.LastOnRowColCell | 
| (package private) static class  | PrivateCellUtil.TagRewriteByteBufferExtendedCell | 
| (package private) static class  | PrivateCellUtil.TagRewriteCellThis can be used when a Cell has to change with addition/removal of one or more tags. | 
| (package private) static class  | PrivateCellUtil.ValueAndTagRewriteByteBufferExtendedCell | 
| (package private) static class  | PrivateCellUtil.ValueAndTagRewriteCell | 
| class  | SizeCachedKeyValueThis class is an extension to KeyValue where rowLen and keyLen are cached. | 
| class  | SizeCachedNoTagsKeyValueThis class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AppendPerforms Append operations on a single row. | 
| class  | DeleteUsed to perform Delete operations on a single row. | 
| class  | IncrementUsed to perform Increment operations on a single row. | 
| class  | Mutation | 
| private static class  | Mutation.CellWrapper | 
| class  | PutUsed to perform Put operations for a single row. | 
| Modifier and Type | Class and Description | 
|---|---|
| (package private) static class  | KeyOnlyFilter.KeyOnlyByteBufferExtendedCell | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | SizedCellScannerA CellScanner that knows its size in memory in bytes. | 
| Modifier and Type | Class and Description | 
|---|---|
| protected static class  | BufferedDataBlockEncoder.OffheapDecodedExtendedCell | 
| protected static class  | BufferedDataBlockEncoder.OnheapDecodedCellCopies only the key part of the keybuffer by doing a deep copy and passes the
 seeker state members for taking a clone. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | CacheableCacheable is an interface that allows for an object to be cached. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BlockCacheKeyCache Key for use with implementations of  BlockCache | 
| class  | CombinedBlockCacheCombinedBlockCache is an abstraction layer that combines
  LruBlockCacheandBucketCache. | 
| class  | HFileBlockCacheable Blocks of an  HFileversion 2 file. | 
| (package private) static class  | HFileBlockIndex.BlockIndexReaderThe reader will always hold the root level index in the memory. | 
| (package private) static class  | HFileBlockIndex.ByteArrayKeyBlockIndexReaderAn implementation of the BlockIndexReader that deals with block keys which are plain
 byte[] like MetaBlock or the Bloom Block for ROW bloom. | 
| (package private) static class  | HFileBlockIndex.CellBasedKeyBlockIndexReaderAn implementation of the BlockIndexReader that deals with block keys which are the key
 part of a cell like the Data block index or the ROW_COL bloom blocks
 This needs a comparator to work with the Cells | 
| class  | HFileContextThis carries the information on some of the meta data about the HFile. | 
| class  | InclusiveCombinedBlockCache | 
| class  | LruBlockCacheA block cache implementation that is memory-aware using  HeapSize,
 memory-bound using an LRU eviction algorithm, and concurrent: backed by aConcurrentHashMapand with a non-blocking eviction thread giving
 constant-timeLruBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable, boolean)andLruBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean)operations. | 
| class  | LruCachedBlockRepresents an entry in the  LruBlockCache. | 
| class  | LruCachedBlockQueueA memory-bound queue that will grow until an element brings
 total size >= maxSize. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BucketCacheBucketCache uses  BucketAllocatorto allocate/free blocks, and uses
 BucketCache#ramCache and BucketCache#backingMap in order to
 determine if a given element is in the cache. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ByteBufferChunkKeyValueByteBuffer based cell which has the chunkid at the 0th offset | 
| class  | HMobStoreThe store implementation to save MOBs (medium objects), it extends the HStore. | 
| class  | HRegionRegions store data for a certain region of a table. | 
| class  | HStoreA Store holds a column family in a Region. | 
| class  | NoTagByteBufferChunkKeyValueByteBuffer based cell which has the chunkid at the 0th offset and with no tags | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MapReduceExtendedCellA wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | WALEditUsed in HBase's transaction log (WAL) to represent a collection of edits (Cell/KeyValue objects)
 that came in as a single transaction. | 
| static class  | WALSplitter.RegionEntryBufferA buffer of some number of edits for a given region. | 
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.