Uses of Interface
org.apache.hadoop.hbase.io.HeapSize
Package
Description
Provides HBase Client
Provides row-level filters applied to HRegion scan results during calls to
ResultScanner.next()
.Provides implementations of
HFile
and HFile
BlockCache
.Provides
BucketCache
, an implementation of
BlockCache
.-
Uses of HeapSize in org.apache.hadoop.hbase
Modifier and TypeInterfaceDescriptioninterface
The unit of storage in HBase consisting of the following fields:interface
Extension toCell
with server side required functions.interface
An extended version of Cell that allows CPs manipulate Tags.Modifier and TypeClassDescriptionclass
This class is a server side extension to theCell
interface.class
This is a key only Cell implementation which is identical toKeyValue.KeyOnlyKeyValue
with respect to key serialization but have its data in the form of Byte buffer (onheap and offheap).class
This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferclass
class
An HBase Key/Value.static class
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
An extension of the ByteBufferKeyValue where the tags length is always 0class
An extension of the KeyValue where the tags length is always 0private static class
These cells are used in reseeks/seeks to improve the read performance.private static class
These cells are used in reseeks/seeks to improve the read performance.private static class
private static class
private static class
private static class
private static class
private static class
private static class
private static class
private static class
private static class
private static class
(package private) static class
(package private) static class
This can be used when a Cell has to change with addition/removal of one or more tags.(package private) static class
(package private) static class
class
This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferclass
This class is an extension to KeyValue where rowLen and keyLen are cached.class
This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferclass
This class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell. -
Uses of HeapSize in org.apache.hadoop.hbase.client
Modifier and TypeClassDescriptionclass
Performs Append operations on a single row.class
Used to perform Delete operations on a single row.class
Used to perform Increment operations on a single row.class
private static final class
class
Used to perform Put operations for a single row. -
Uses of HeapSize in org.apache.hadoop.hbase.filter
Modifier and TypeClassDescription(package private) static class
(package private) static class
-
Uses of HeapSize in org.apache.hadoop.hbase.io
Modifier and TypeInterfaceDescriptioninterface
A CellScanner that knows its size in memory in bytes. -
Uses of HeapSize in org.apache.hadoop.hbase.io.encoding
Modifier and TypeClassDescriptionprotected static class
protected static class
Copies only the key part of the keybuffer by doing a deep copy and passes the seeker state members for taking a clone. -
Uses of HeapSize in org.apache.hadoop.hbase.io.hfile
Modifier and TypeInterfaceDescriptioninterface
Cacheable is an interface that allows for an object to be cached.interface
In-memory BlockCache that may be backed by secondary layer(s).static interface
Modifier and TypeClassDescriptionclass
Cache Key for use with implementations ofBlockCache
class
CombinedBlockCache is an abstraction layer that combinesFirstLevelBlockCache
andBucketCache
.class
TheByteBuffAllocator
won't allocate pooled heapByteBuff
now; at the same time, if allocate an off-heapByteBuff
from allocator, then it must be a pooled one.class
Cacheable Blocks of anHFile
version 2 file.(package private) static class
The reader will always hold the root level index in the memory.(package private) static class
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
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(package private) static class
class
Read-only HFile Context Information.class
class
An on heap block cache implementation extended LruBlockCache and only cache index block.class
This realisation improve performance of classical LRU cache up to 3 times via reduce GC job.class
A block cache implementation that is memory-aware usingHeapSize
, memory-bound using an LRU eviction algorithm, and concurrent: backed by aConcurrentHashMap
and 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
Represents an entry in theLruBlockCache
.class
A memory-bound queue that will grow until an element brings total size >= maxSize.protected static class
class
TheByteBuffAllocator
won't allocate pooled heapByteBuff
now; at the same time, if allocate an off-heapByteBuff
from allocator, then it must be a pooled one.final class
A block cache that is memory-aware usingHeapSize
, memory bounded using the W-TinyLFU eviction algorithm, and concurrent. -
Uses of HeapSize in org.apache.hadoop.hbase.io.hfile.bucket
Modifier and TypeClassDescriptionclass
BucketCache usesBucketAllocator
to allocate/free blocks, and uses BucketCache#ramCache and BucketCache#backingMap in order to determine if a given element is in the cache. -
Uses of HeapSize in org.apache.hadoop.hbase.quotas
Modifier and TypeInterfaceDescriptioninterface
Interface that encapsulates optionally sending a Region's size to the master.interface
An interface for concurrently storing and updating the size of a Region.Modifier and TypeClassDescriptionfinal class
ARegionSizeStore
implementation that stores nothing.class
An object encapsulating a Region's size and whether it's been reported to the master since the value last changed.class
ARegionSizeStore
implementation backed by a ConcurrentHashMap. -
Uses of HeapSize in org.apache.hadoop.hbase.regionserver
Modifier and TypeClassDescriptionclass
ByteBuffer based cell which has the chunkid at the 0th offsetclass
The store implementation to save MOBs (medium objects), it extends the HStore.class
Regions store data for a certain region of a table.class
A Store holds a column family in a Region.class
ByteBuffer based cell which has the chunkid at the 0th offset and with no tagsfinal class
This carries the immutable information and references on some of the meta data about the HStore. -
Uses of HeapSize in org.apache.hadoop.hbase.util
Modifier and TypeClassDescriptionclass
A wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers. -
Uses of HeapSize in org.apache.hadoop.hbase.wal
Modifier and TypeClassDescriptionstatic class
A buffer of some number of edits for a given region.class
Used in HBase's transaction log (WAL) to represent a collection of edits (Cell/KeyValue objects) that came in as a single transaction.