Uses of Interface
org.apache.hadoop.hbase.io.HeapSize
Packages that use 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
Subinterfaces of org.apache.hadoop.hbase.io.HeapSize in in org.apache.hadoop.hbaseModifier and TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.CellThe unit of storage in HBase consisting of the following fields:interfaceorg.apache.hadoop.hbase.ExtendedCellExtension toCellwith server side required functions.interfaceorg.apache.hadoop.hbase.RawCellAn extended version of Cell that allows CPs manipulate Tags.Classes in org.apache.hadoop.hbase that implement org.apache.hadoop.hbase.io.HeapSize in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.ByteBufferExtendedCellThis class is a server side extension to theCellinterface.classorg.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValueThis 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).classorg.apache.hadoop.hbase.ByteBufferKeyValueThis Cell is an implementation ofByteBufferExtendedCellwhere the data resides in off heap/ on heap ByteBufferclassorg.apache.hadoop.hbase.IndividualBytesFieldCellclassorg.apache.hadoop.hbase.KeyValueAn HBase Key/Value.static classorg.apache.hadoop.hbase.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.classorg.apache.hadoop.hbase.NoTagsByteBufferKeyValueAn extension of the ByteBufferKeyValue where the tags length is always 0classorg.apache.hadoop.hbase.NoTagsKeyValueAn extension of the KeyValue where the tags length is always 0classorg.apache.hadoop.hbase.SizeCachedByteBufferKeyValueThis Cell is an implementation ofByteBufferExtendedCellwhere the data resides in off heap/ on heap ByteBufferclassorg.apache.hadoop.hbase.SizeCachedKeyValueThis class is an extension to KeyValue where rowLen and keyLen are cached.classorg.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValueThis Cell is an implementation ofByteBufferExtendedCellwhere the data resides in off heap/ on heap ByteBufferclassorg.apache.hadoop.hbase.SizeCachedNoTagsKeyValueThis 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
Classes in org.apache.hadoop.hbase.client that implement org.apache.hadoop.hbase.io.HeapSize in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.client.AppendPerforms Append operations on a single row.classorg.apache.hadoop.hbase.client.DeleteUsed to perform Delete operations on a single row.classorg.apache.hadoop.hbase.client.IncrementUsed to perform Increment operations on a single row.classorg.apache.hadoop.hbase.client.Mutationclassorg.apache.hadoop.hbase.client.PutUsed to perform Put operations for a single row. -
Uses of org.apache.hadoop.hbase.io.HeapSize in org.apache.hadoop.hbase.io
Subinterfaces of org.apache.hadoop.hbase.io.HeapSize in in org.apache.hadoop.hbase.ioModifier and TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.io.SizedCellScannerA CellScanner that knows its size in memory in bytes. -
Uses of org.apache.hadoop.hbase.io.HeapSize in org.apache.hadoop.hbase.io.hfile
Subinterfaces of org.apache.hadoop.hbase.io.HeapSize in in org.apache.hadoop.hbase.io.hfileModifier and TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.io.hfile.CacheableCacheable is an interface that allows for an object to be cached.interfaceorg.apache.hadoop.hbase.io.hfile.FirstLevelBlockCacheIn-memory BlockCache that may be backed by secondary layer(s).static interfaceorg.apache.hadoop.hbase.io.hfile.HFileIndexBlockEncoder.EncodedSeekerClasses in org.apache.hadoop.hbase.io.hfile that implement org.apache.hadoop.hbase.io.HeapSize in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.io.hfile.BlockCacheKeyCache Key for use with implementations ofBlockCacheclassorg.apache.hadoop.hbase.io.hfile.CombinedBlockCacheCombinedBlockCache is an abstraction layer that combinesFirstLevelBlockCacheandBucketCache.classorg.apache.hadoop.hbase.io.hfile.ExclusiveMemHFileBlockTheByteBuffAllocatorwon't allocate pooled heapByteBuffnow; at the same time, if allocate an off-heapByteBufffrom allocator, then it must be a pooled one.classorg.apache.hadoop.hbase.io.hfile.HFileBlockCacheable Blocks of anHFileversion 2 file.classorg.apache.hadoop.hbase.io.hfile.HFileContextRead-only HFile Context Information.classorg.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCacheclassorg.apache.hadoop.hbase.io.hfile.IndexOnlyLruBlockCacheAn on heap block cache implementation extended LruBlockCache and only cache index block.classorg.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCacheThis realisation improve performance of classical LRU cache up to 3 times via reduce GC job.classorg.apache.hadoop.hbase.io.hfile.LruBlockCacheA 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.classorg.apache.hadoop.hbase.io.hfile.LruCachedBlockRepresents an entry in theLruBlockCache.classorg.apache.hadoop.hbase.io.hfile.LruCachedBlockQueueA memory-bound queue that will grow until an element brings total size >= maxSize.protected static classorg.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeekerclassorg.apache.hadoop.hbase.io.hfile.SharedMemHFileBlockTheByteBuffAllocatorwon't allocate pooled heapByteBuffnow; at the same time, if allocate an off-heapByteBufffrom allocator, then it must be a pooled one.final classorg.apache.hadoop.hbase.io.hfile.TinyLfuBlockCacheA 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
Subinterfaces of org.apache.hadoop.hbase.io.HeapSize in in org.apache.hadoop.hbase.quotasModifier and TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.quotas.RegionSizeInterface that encapsulates optionally sending a Region's size to the master.interfaceorg.apache.hadoop.hbase.quotas.RegionSizeStoreAn interface for concurrently storing and updating the size of a Region.Classes in org.apache.hadoop.hbase.quotas that implement org.apache.hadoop.hbase.io.HeapSize in inModifier and TypeClassDescriptionfinal classorg.apache.hadoop.hbase.quotas.NoOpRegionSizeStoreARegionSizeStoreimplementation that stores nothing.classorg.apache.hadoop.hbase.quotas.RegionSizeImplAn object encapsulating a Region's size and whether it's been reported to the master since the value last changed.classorg.apache.hadoop.hbase.quotas.RegionSizeStoreImplARegionSizeStoreimplementation backed by a ConcurrentHashMap. -
Uses of org.apache.hadoop.hbase.io.HeapSize in org.apache.hadoop.hbase.regionserver
Classes in org.apache.hadoop.hbase.regionserver that implement org.apache.hadoop.hbase.io.HeapSize in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.regionserver.ByteBufferChunkKeyValueByteBuffer based cell which has the chunkid at the 0th offsetclassorg.apache.hadoop.hbase.regionserver.HMobStoreThe store implementation to save MOBs (medium objects), it extends the HStore.classorg.apache.hadoop.hbase.regionserver.HRegionRegions store data for a certain region of a table.classorg.apache.hadoop.hbase.regionserver.HStoreA Store holds a column family in a Region.classorg.apache.hadoop.hbase.regionserver.NoTagByteBufferChunkKeyValueByteBuffer based cell which has the chunkid at the 0th offset and with no tagsfinal classorg.apache.hadoop.hbase.regionserver.StoreContextThis 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
Classes in org.apache.hadoop.hbase.util that implement org.apache.hadoop.hbase.io.HeapSize in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.util.MapReduceExtendedCellA 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
Classes in org.apache.hadoop.hbase.wal that implement org.apache.hadoop.hbase.io.HeapSize in inModifier and TypeClassDescriptionstatic classorg.apache.hadoop.hbase.wal.EntryBuffers.RegionEntryBufferA buffer of some number of edits for a given region.classorg.apache.hadoop.hbase.wal.WALEditUsed in HBase's transaction log (WAL) to represent a collection of edits (Cell/KeyValue objects) that came in as a single transaction.