Uses of Interface
org.apache.hadoop.hbase.io.HeapSize
Packages that use 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
Subinterfaces of HeapSize in org.apache.hadoop.hbaseModifier and TypeInterfaceDescriptioninterfaceThe unit of storage in HBase consisting of the following fields:interfaceExtension toCellwith server side required functions.interfaceAn extended version of Cell that allows CPs manipulate Tags.Classes in org.apache.hadoop.hbase that implement HeapSizeModifier and TypeClassDescriptionclassThis class is a server side extension to theCellinterface.classThis is a key only Cell implementation which is identical toKeyValue.KeyOnlyKeyValuewith respect to key serialization but have its data in the form of Byte buffer (onheap and offheap).classThis Cell is an implementation ofByteBufferExtendedCellwhere the data resides in off heap/ on heap ByteBufferclassclassAn HBase Key/Value.static classA 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.classAn extension of the ByteBufferKeyValue where the tags length is always 0classAn extension of the KeyValue where the tags length is always 0private static classThese cells are used in reseeks/seeks to improve the read performance.private static classThese cells are used in reseeks/seeks to improve the read performance.private static classprivate static classprivate static classprivate static classprivate static classprivate static classprivate static classprivate static classprivate static classprivate static classprivate static class(package private) static class(package private) static classThis can be used when a Cell has to change with addition/removal of one or more tags.(package private) static class(package private) static classclassThis Cell is an implementation ofByteBufferExtendedCellwhere the data resides in off heap/ on heap ByteBufferclassThis class is an extension to KeyValue where rowLen and keyLen are cached.classThis Cell is an implementation ofByteBufferExtendedCellwhere the data resides in off heap/ on heap ByteBufferclassThis class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell. -
Uses of HeapSize in org.apache.hadoop.hbase.client
Classes in org.apache.hadoop.hbase.client that implement HeapSizeModifier and TypeClassDescriptionclassPerforms Append operations on a single row.classUsed to perform Delete operations on a single row.classUsed to perform Increment operations on a single row.classprivate static final classclassUsed to perform Put operations for a single row. -
Uses of HeapSize in org.apache.hadoop.hbase.filter
Classes in org.apache.hadoop.hbase.filter that implement HeapSizeModifier and TypeClassDescription(package private) static class(package private) static class -
Uses of HeapSize in org.apache.hadoop.hbase.io
Subinterfaces of HeapSize in org.apache.hadoop.hbase.ioModifier and TypeInterfaceDescriptioninterfaceA CellScanner that knows its size in memory in bytes. -
Uses of HeapSize in org.apache.hadoop.hbase.io.encoding
Classes in org.apache.hadoop.hbase.io.encoding that implement HeapSizeModifier and TypeClassDescriptionprotected static classprotected static classCopies 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
Subinterfaces of HeapSize in org.apache.hadoop.hbase.io.hfileModifier and TypeInterfaceDescriptioninterfaceCacheable is an interface that allows for an object to be cached.interfaceIn-memory BlockCache that may be backed by secondary layer(s).static interfaceClasses in org.apache.hadoop.hbase.io.hfile that implement HeapSizeModifier and TypeClassDescriptionclassCache Key for use with implementations ofBlockCacheclassCombinedBlockCache is an abstraction layer that combinesFirstLevelBlockCacheandBucketCache.classTheByteBuffAllocatorwon't allocate pooled heapByteBuffnow; at the same time, if allocate an off-heapByteBufffrom allocator, then it must be a pooled one.classCacheable Blocks of anHFileversion 2 file.(package private) static classThe reader will always hold the root level index in the memory.(package private) static classAn 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 classAn 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 classclassRead-only HFile Context Information.classclassAn on heap block cache implementation extended LruBlockCache and only cache index block.classThis realisation improve performance of classical LRU cache up to 3 times via reduce GC job.classA block cache implementation that is memory-aware usingHeapSize, 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.classRepresents an entry in theLruBlockCache.classA memory-bound queue that will grow until an element brings total size >= maxSize.protected static classclassTheByteBuffAllocatorwon't allocate pooled heapByteBuffnow; at the same time, if allocate an off-heapByteBufffrom allocator, then it must be a pooled one.final classA 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
Classes in org.apache.hadoop.hbase.io.hfile.bucket that implement HeapSizeModifier and TypeClassDescriptionclassBucketCache usesBucketAllocatorto 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
Subinterfaces of HeapSize in org.apache.hadoop.hbase.quotasModifier and TypeInterfaceDescriptioninterfaceInterface that encapsulates optionally sending a Region's size to the master.interfaceAn interface for concurrently storing and updating the size of a Region.Classes in org.apache.hadoop.hbase.quotas that implement HeapSizeModifier and TypeClassDescriptionfinal classARegionSizeStoreimplementation that stores nothing.classAn object encapsulating a Region's size and whether it's been reported to the master since the value last changed.classARegionSizeStoreimplementation backed by a ConcurrentHashMap. -
Uses of HeapSize in org.apache.hadoop.hbase.regionserver
Classes in org.apache.hadoop.hbase.regionserver that implement HeapSizeModifier and TypeClassDescriptionclassByteBuffer based cell which has the chunkid at the 0th offsetclassThe store implementation to save MOBs (medium objects), it extends the HStore.classRegions store data for a certain region of a table.classA Store holds a column family in a Region.classByteBuffer based cell which has the chunkid at the 0th offset and with no tagsfinal classThis carries the immutable information and references on some of the meta data about the HStore. -
Uses of HeapSize in org.apache.hadoop.hbase.util
Classes in org.apache.hadoop.hbase.util that implement HeapSizeModifier and TypeClassDescriptionclassA 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
Classes in org.apache.hadoop.hbase.wal that implement HeapSizeModifier and TypeClassDescriptionstatic classA buffer of some number of edits for a given region.classUsed in HBase's transaction log (WAL) to represent a collection of edits (Cell/KeyValue objects) that came in as a single transaction.