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
HFile and HFile
BlockCache . |
org.apache.hadoop.hbase.io.hfile.bucket |
Provides
BucketCache , an implementation of
BlockCache . |
org.apache.hadoop.hbase.quotas | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.util | |
org.apache.hadoop.hbase.wal |
Modifier and Type | Interface and Description |
---|---|
interface |
Cell
The unit of storage in HBase consisting of the following fields:
|
interface |
ExtendedCell
Extension to
Cell with server side required functions. |
interface |
RawCell
An extended version of cell that gives more power to CPs
|
Modifier and Type | Class and Description |
---|---|
class |
ByteBufferExtendedCell
This class is a server side extension to the
Cell interface. |
class |
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). |
class |
ByteBufferKeyValue
This Cell is an implementation of
ByteBufferExtendedCell where the data resides in
off heap/ on heap ByteBuffer |
class |
IndividualBytesFieldCell |
class |
KeyValue
An HBase Key/Value.
|
static class |
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.
|
class |
NoTagsByteBufferKeyValue
An extension of the ByteBufferKeyValue where the tags length is always 0
|
class |
NoTagsKeyValue
An extension of the KeyValue where the tags length is always 0
|
private static class |
PrivateCellUtil.EmptyByteBufferExtendedCell
These cells are used in reseeks/seeks to improve the read performance.
|
private static class |
PrivateCellUtil.EmptyCell
These 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.TagRewriteCell
This 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 |
SizeCachedKeyValue
This class is an extension to KeyValue where rowLen and keyLen are cached.
|
class |
SizeCachedNoTagsKeyValue
This class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.
|
Modifier and Type | Class and Description |
---|---|
class |
Append
Performs Append operations on a single row.
|
class |
Delete
Used to perform Delete operations on a single row.
|
class |
Increment
Used to perform Increment operations on a single row.
|
class |
Mutation |
private static class |
Mutation.CellWrapper |
class |
Put
Used to perform Put operations for a single row.
|
Modifier and Type | Class and Description |
---|---|
(package private) static class |
KeyOnlyFilter.KeyOnlyByteBufferExtendedCell |
(package private) static class |
KeyOnlyFilter.KeyOnlyCell |
Modifier and Type | Interface and Description |
---|---|
interface |
SizedCellScanner
A CellScanner that knows its size in memory in bytes.
|
Modifier and Type | Class and Description |
---|---|
protected static class |
BufferedDataBlockEncoder.OffheapDecodedExtendedCell |
protected static class |
BufferedDataBlockEncoder.OnheapDecodedCell
Copies 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 |
Cacheable
Cacheable is an interface that allows for an object to be cached.
|
Modifier and Type | Class and Description |
---|---|
class |
BlockCacheKey
Cache Key for use with implementations of
BlockCache |
class |
CombinedBlockCache
CombinedBlockCache is an abstraction layer that combines
LruBlockCache and BucketCache . |
class |
HFileBlock
Cacheable Blocks of an
HFile version 2 file. |
(package private) static class |
HFileBlockIndex.BlockIndexReader
The reader will always hold the root level index in the memory.
|
(package private) static class |
HFileBlockIndex.ByteArrayKeyBlockIndexReader
An 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.CellBasedKeyBlockIndexReader
An 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 |
HFileContext
This carries the information on some of the meta data about the HFile.
|
class |
InclusiveCombinedBlockCache |
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.
|
Modifier and Type | Class and Description |
---|---|
class |
BucketCache
BucketCache uses
BucketAllocator to 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 | Interface and Description |
---|---|
interface |
RegionSize
Interface that encapsulates optionally sending a Region's size to the master.
|
interface |
RegionSizeStore
An interface for concurrently storing and updating the size of a Region.
|
Modifier and Type | Class and Description |
---|---|
class |
NoOpRegionSizeStore
A
RegionSizeStore implementation that stores nothing. |
class |
RegionSizeImpl
An object encapsulating a Region's size and whether it's been reported to the master since
the value last changed.
|
class |
RegionSizeStoreImpl
A
RegionSizeStore implementation backed by a ConcurrentHashMap. |
Modifier and Type | Class and Description |
---|---|
class |
ByteBufferChunkKeyValue
ByteBuffer based cell which has the chunkid at the 0th offset
|
class |
HMobStore
The store implementation to save MOBs (medium objects), it extends the HStore.
|
class |
HRegion
Regions store data for a certain region of a table.
|
class |
HStore
A Store holds a column family in a Region.
|
class |
NoTagByteBufferChunkKeyValue
ByteBuffer based cell which has the chunkid at the 0th offset and with no tags
|
Modifier and Type | Class and Description |
---|---|
class |
MapReduceExtendedCell
A wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers.
|
Modifier and Type | Class and Description |
---|---|
class |
WALEdit
Used 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.RegionEntryBuffer
A buffer of some number of edits for a given region.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.