Uses of Interface
org.apache.hadoop.hbase.io.HeapSize
Package
Description
Provides HBase Client
Provides implementations of
HFile
and HFile
BlockCache
.-
Uses of org.apache.hadoop.hbase.io.HeapSize in org.apache.hadoop.hbase
Modifier and TypeInterfaceDescriptioninterface
org.apache.hadoop.hbase.Cell
The unit of storage in HBase consisting of the following fields:interface
org.apache.hadoop.hbase.ExtendedCell
Extension toCell
with server side required functions.interface
org.apache.hadoop.hbase.RawCell
An extended version of Cell that allows CPs manipulate Tags.Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.ByteBufferExtendedCell
This class is a server side extension to theCell
interface.class
org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
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
org.apache.hadoop.hbase.ByteBufferKeyValue
This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferclass
org.apache.hadoop.hbase.IndividualBytesFieldCell
class
org.apache.hadoop.hbase.KeyValue
An HBase Key/Value.static class
org.apache.hadoop.hbase.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
org.apache.hadoop.hbase.NoTagsByteBufferKeyValue
An extension of the ByteBufferKeyValue where the tags length is always 0class
org.apache.hadoop.hbase.NoTagsKeyValue
An extension of the KeyValue where the tags length is always 0class
org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferclass
org.apache.hadoop.hbase.SizeCachedKeyValue
This class is an extension to KeyValue where rowLen and keyLen are cached.class
org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferclass
org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
This class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell. -
Uses of org.apache.hadoop.hbase.io.HeapSize in org.apache.hadoop.hbase.client
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.client.Append
Performs Append operations on a single row.class
org.apache.hadoop.hbase.client.Delete
Used to perform Delete operations on a single row.class
org.apache.hadoop.hbase.client.Increment
Used to perform Increment operations on a single row.class
org.apache.hadoop.hbase.client.Mutation
class
org.apache.hadoop.hbase.client.Put
Used to perform Put operations for a single row. -
Uses of org.apache.hadoop.hbase.io.HeapSize in org.apache.hadoop.hbase.io
Modifier and TypeInterfaceDescriptioninterface
org.apache.hadoop.hbase.io.SizedExtendedCellScanner
A CellScanner that knows its size in memory in bytes. -
Uses of org.apache.hadoop.hbase.io.HeapSize in org.apache.hadoop.hbase.io.hfile
Modifier and TypeInterfaceDescriptioninterface
org.apache.hadoop.hbase.io.hfile.Cacheable
Cacheable is an interface that allows for an object to be cached.interface
org.apache.hadoop.hbase.io.hfile.FirstLevelBlockCache
In-memory BlockCache that may be backed by secondary layer(s).static interface
org.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder.EncodedSeeker
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.io.hfile.BlockCacheKey
Cache Key for use with implementations ofBlockCache
class
org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
CombinedBlockCache is an abstraction layer that combinesFirstLevelBlockCache
andBucketCache
.class
org.apache.hadoop.hbase.io.hfile.ExclusiveMemHFileBlock
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
org.apache.hadoop.hbase.io.hfile.HFileBlock
Cacheable Blocks of anHFile
version 2 file.class
org.apache.hadoop.hbase.io.hfile.HFileContext
Read-only HFile Context Information.class
org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
class
org.apache.hadoop.hbase.io.hfile.IndexOnlyLruBlockCache
An on heap block cache implementation extended LruBlockCache and only cache index block.class
org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
This realisation improve performance of classical LRU cache up to 3 times via reduce GC job.class
org.apache.hadoop.hbase.io.hfile.LruBlockCache
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
org.apache.hadoop.hbase.io.hfile.LruCachedBlock
Represents an entry in theLruBlockCache
.class
org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
A memory-bound queue that will grow until an element brings total size >= maxSize.protected static class
org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
class
org.apache.hadoop.hbase.io.hfile.SharedMemHFileBlock
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
org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
A block cache that is memory-aware usingHeapSize
, memory bounded using the W-TinyLFU eviction algorithm, and concurrent. -
Uses of org.apache.hadoop.hbase.io.HeapSize in org.apache.hadoop.hbase.quotas
Modifier and TypeInterfaceDescriptioninterface
org.apache.hadoop.hbase.quotas.RegionSize
Interface that encapsulates optionally sending a Region's size to the master.interface
org.apache.hadoop.hbase.quotas.RegionSizeStore
An interface for concurrently storing and updating the size of a Region.Modifier and TypeClassDescriptionfinal class
org.apache.hadoop.hbase.quotas.NoOpRegionSizeStore
ARegionSizeStore
implementation that stores nothing.class
org.apache.hadoop.hbase.quotas.RegionSizeImpl
An object encapsulating a Region's size and whether it's been reported to the master since the value last changed.class
org.apache.hadoop.hbase.quotas.RegionSizeStoreImpl
ARegionSizeStore
implementation backed by a ConcurrentHashMap. -
Uses of org.apache.hadoop.hbase.io.HeapSize in org.apache.hadoop.hbase.regionserver
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.regionserver.ByteBufferChunkKeyValue
ByteBuffer based cell which has the chunkid at the 0th offsetclass
org.apache.hadoop.hbase.regionserver.HMobStore
The store implementation to save MOBs (medium objects), it extends the HStore.class
org.apache.hadoop.hbase.regionserver.HRegion
Regions store data for a certain region of a table.class
org.apache.hadoop.hbase.regionserver.HStore
A Store holds a column family in a Region.class
org.apache.hadoop.hbase.regionserver.NoTagByteBufferChunkKeyValue
ByteBuffer based cell which has the chunkid at the 0th offset and with no tagsfinal class
org.apache.hadoop.hbase.regionserver.StoreContext
This carries the immutable information and references on some of the meta data about the HStore. -
Uses of org.apache.hadoop.hbase.io.HeapSize in org.apache.hadoop.hbase.util
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.util.MapReduceExtendedCell
A wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers. -
Uses of org.apache.hadoop.hbase.io.HeapSize in org.apache.hadoop.hbase.wal
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.wal.WALEdit
Used in HBase's transaction log (WAL) to represent a collection of edits (Cell/KeyValue objects) that came in as a single transaction.