Uses of Interface
org.apache.hadoop.hbase.io.hfile.Cacheable
Packages that use Cacheable
Package
Description
Provides implementations of
HFile and HFile
BlockCache.Provides
BucketCache, an implementation of
BlockCache.-
Uses of Cacheable in org.apache.hadoop.hbase.io.hfile
Classes in org.apache.hadoop.hbase.io.hfile with type parameters of type CacheableModifier and TypeInterfaceDescriptioninterfaceCacheableDeserializer<T extends Cacheable>Interface for a deserializer.Classes in org.apache.hadoop.hbase.io.hfile that implement CacheableModifier and TypeClassDescriptionclassTheByteBuffAllocatorwon'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.classTheByteBuffAllocatorwon't allocate pooled heapByteBuffnow; at the same time, if allocate an off-heapByteBufffrom allocator, then it must be a pooled one.Fields in org.apache.hadoop.hbase.io.hfile declared as CacheableModifier and TypeFieldDescriptionprivate final CacheableLruCachedBlock.bufprivate final CacheableTinyLfuBlockCache.CachedBlockView.valueFields in org.apache.hadoop.hbase.io.hfile with type parameters of type CacheableModifier and TypeFieldDescriptionstatic final CacheableDeserializer<Cacheable>HFileBlock.BLOCK_DESERIALIZERUsed deserializing blocks from Cache.(package private) final com.github.benmanes.caffeine.cache.Cache<BlockCacheKey,Cacheable> TinyLfuBlockCache.cacheprivate final com.github.benmanes.caffeine.cache.Policy.Eviction<BlockCacheKey,Cacheable> TinyLfuBlockCache.policyprivate static final Map<Integer,CacheableDeserializer<Cacheable>> CacheableDeserializerIdManager.registeredDeserializersMethods in org.apache.hadoop.hbase.io.hfile that return CacheableModifier and TypeMethodDescriptionprivate CacheableLruAdaptiveBlockCache.asReferencedHeapBlock(Cacheable buf) The block cached in LruAdaptiveBlockCache will always be an heap block: on the one side, the heap access will be more faster then off-heap, the small index block or meta block cached in CombinedBlockCache will benefit a lot.private CacheableLruBlockCache.asReferencedHeapBlock(Cacheable buf) The block cached in LRUBlockCache will always be an heap block: on the one side, the heap access will be more faster then off-heap, the small index block or meta block cached in CombinedBlockCache will benefit a lot.private CacheableTinyLfuBlockCache.asReferencedHeapBlock(Cacheable buf) The block cached in TinyLfuBlockCache will always be an heap block: on the one side, the heap access will be more faster then off-heap, the small index block or meta block cached in CombinedBlockCache will benefit a lot.BlockCache.getBlock(BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics) Fetch block from cache.CombinedBlockCache.getBlock(BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics) InclusiveCombinedBlockCache.getBlock(BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics) LruAdaptiveBlockCache.getBlock(BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics) Get the buffer of the block with the specified name.LruBlockCache.getBlock(BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics) Get the buffer of the block with the specified name.MemcachedBlockCache.getBlock(BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics) TinyLfuBlockCache.getBlock(BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics) private CacheableCombinedBlockCache.getBlockWithType(BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics) LruCachedBlock.getBuffer()default CacheableCacheable.retain()Increase its reference count, and only when no reference we can free the object's memory.Methods in org.apache.hadoop.hbase.io.hfile that return types with arguments of type CacheableModifier and TypeMethodDescriptionCacheable.getDeserializer()Returns CacheableDeserializer instance which reconstructs original object from ByteBuffer.static CacheableDeserializer<Cacheable>CacheableDeserializerIdManager.getDeserializer(int id) Get the cacheable deserializer registered at the given identifier Id.HFileBlock.getDeserializer()Methods in org.apache.hadoop.hbase.io.hfile with parameters of type CacheableModifier and TypeMethodDescriptionprivate CacheableLruAdaptiveBlockCache.asReferencedHeapBlock(Cacheable buf) The block cached in LruAdaptiveBlockCache will always be an heap block: on the one side, the heap access will be more faster then off-heap, the small index block or meta block cached in CombinedBlockCache will benefit a lot.private CacheableLruBlockCache.asReferencedHeapBlock(Cacheable buf) The block cached in LRUBlockCache will always be an heap block: on the one side, the heap access will be more faster then off-heap, the small index block or meta block cached in CombinedBlockCache will benefit a lot.private CacheableTinyLfuBlockCache.asReferencedHeapBlock(Cacheable buf) The block cached in TinyLfuBlockCache will always be an heap block: on the one side, the heap access will be more faster then off-heap, the small index block or meta block cached in CombinedBlockCache will benefit a lot.voidBlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf) Add block to cache (defaults to not in-memory).voidBlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf, boolean inMemory) Add block to cache.default voidBlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf, boolean inMemory, boolean waitWhenCache) Add block to cache.voidCombinedBlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf) voidCombinedBlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf, boolean inMemory) voidCombinedBlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf, boolean inMemory, boolean waitWhenCache) voidInclusiveCombinedBlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf, boolean inMemory) voidIndexOnlyLruBlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf, boolean inMemory) Cache only index block with the specified name and buffervoidLruAdaptiveBlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf) Cache the block with the specified name and buffer.voidLruAdaptiveBlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf, boolean inMemory) Cache the block with the specified name and buffer.voidLruBlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf) Cache the block with the specified name and buffer.voidLruBlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf, boolean inMemory) Cache the block with the specified name and buffer.voidMemcachedBlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf) voidMemcachedBlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf, boolean inMemory) voidTinyLfuBlockCache.cacheBlock(BlockCacheKey key, Cacheable value) voidTinyLfuBlockCache.cacheBlock(BlockCacheKey cacheKey, Cacheable value, boolean inMemory) private static intBlockCacheUtil.compareCacheBlock(Cacheable left, Cacheable right, boolean includeNextBlockMetadata) voidTinyLfuBlockCache.EvictionListener.onRemoval(BlockCacheKey key, Cacheable value, com.github.benmanes.caffeine.cache.RemovalCause cause) private voidHFileReaderImpl.returnAndEvictBlock(BlockCache cache, BlockCacheKey cacheKey, Cacheable block) static booleanBlockCacheUtil.shouldReplaceExistingCacheBlock(BlockCache blockCache, BlockCacheKey cacheKey, Cacheable newBlock) Because of the region splitting, it's possible that the split key locate in the middle of a block.private voidCombinedBlockCache.updateBlockMetrics(Cacheable block, BlockCacheKey key, BlockCache cache, boolean caching) static intBlockCacheUtil.validateBlockAddition(Cacheable existing, Cacheable newBlock, BlockCacheKey cacheKey) Validate that the existing and newBlock are the same without including the nextBlockMetadata, if not, throw an exception.Method parameters in org.apache.hadoop.hbase.io.hfile with type arguments of type CacheableModifier and TypeMethodDescriptionstatic intCacheableDeserializerIdManager.registerDeserializer(CacheableDeserializer<Cacheable> cd) Register the givenCacheable-- usually an hfileblock instance, these implement the Cacheable Interface -- deserializer and generate a unique identifier id for it and return this as our result.Constructors in org.apache.hadoop.hbase.io.hfile with parameters of type CacheableModifierConstructorDescriptionCachedBlockView(BlockCacheKey key, Cacheable value, long now) LruCachedBlock(BlockCacheKey cacheKey, Cacheable buf, long accessTime) LruCachedBlock(BlockCacheKey cacheKey, Cacheable buf, long accessTime, boolean inMemory) -
Uses of Cacheable in org.apache.hadoop.hbase.io.hfile.bucket
Fields in org.apache.hadoop.hbase.io.hfile.bucket declared as CacheableMethods in org.apache.hadoop.hbase.io.hfile.bucket that return CacheableModifier and TypeMethodDescriptionBucketCache.getBlock(BlockCacheKey key, boolean caching, boolean repeat, boolean updateCacheMetrics) Get the buffer of the block with the specified key.BucketCache.RAMQueueEntry.getData()ByteBufferIOEngine.read(BucketEntry be) ExclusiveMemoryMmapIOEngine.read(BucketEntry be) FileIOEngine.read(BucketEntry be) Transfers data from file to the given byte bufferabstract CacheableFileMmapIOEngine.read(BucketEntry be) IOEngine.read(BucketEntry be) Transfers data from IOEngine to a Cacheable object.SharedMemoryMmapIOEngine.read(BucketEntry be) (package private) CacheableBucketEntry.wrapAsCacheable(ByteBuffer[] buffers) (package private) CacheableBucketEntry.wrapAsCacheable(ByteBuff buf) Methods in org.apache.hadoop.hbase.io.hfile.bucket that return types with arguments of type CacheableModifier and TypeMethodDescription(package private) CacheableDeserializer<Cacheable>BucketEntry.deserializerReference()Methods in org.apache.hadoop.hbase.io.hfile.bucket with parameters of type CacheableModifier and TypeMethodDescriptionvoidBucketCache.cacheBlock(BlockCacheKey cacheKey, Cacheable buf) Cache the block with the specified name and buffer.voidBucketCache.cacheBlock(BlockCacheKey cacheKey, Cacheable cachedItem, boolean inMemory) Cache the block with the specified name and buffer.voidBucketCache.cacheBlock(BlockCacheKey cacheKey, Cacheable cachedItem, boolean inMemory, boolean waitWhenCache) Cache the block with the specified name and buffer.voidBucketCache.cacheBlockWithWait(BlockCacheKey cacheKey, Cacheable cachedItem, boolean inMemory, boolean wait) Cache the block to ramCacheprotected voidBucketCache.cacheBlockWithWaitInternal(BlockCacheKey cacheKey, Cacheable cachedItem, boolean inMemory, boolean wait) protected booleanBucketCache.shouldReplaceExistingCacheBlock(BlockCacheKey cacheKey, Cacheable newBlock) Method parameters in org.apache.hadoop.hbase.io.hfile.bucket with type arguments of type CacheableModifier and TypeMethodDescription(package private) voidBucketEntry.setDeserializerReference(CacheableDeserializer<Cacheable> deserializer) Constructors in org.apache.hadoop.hbase.io.hfile.bucket with parameters of type CacheableModifierConstructorDescription(package private)RAMQueueEntry(BlockCacheKey bck, Cacheable data, long accessCounter, boolean inMemory, boolean isCachePersistent)