Uses of Class
org.apache.hadoop.hbase.io.hfile.LruCachedBlock
Packages that use LruCachedBlock
-
Uses of LruCachedBlock in org.apache.hadoop.hbase.io.hfile
Fields in org.apache.hadoop.hbase.io.hfile with type parameters of type LruCachedBlockModifier and TypeFieldDescriptionprivate final ConcurrentHashMap<BlockCacheKey,
LruCachedBlock> LruAdaptiveBlockCache.map
Defined the cache map asConcurrentHashMap
here, because inLruAdaptiveBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean)
, we need to guarantee the atomicity of map#computeIfPresent (key, func).private final ConcurrentHashMap<BlockCacheKey,
LruCachedBlock> LruBlockCache.map
Defined the cache map asConcurrentHashMap
here, because inLruBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean)
, we need to guarantee the atomicity of map#k (key, func).private org.apache.hbase.thirdparty.com.google.common.collect.MinMaxPriorityQueue<LruCachedBlock>
LruCachedBlockQueue.queue
Methods in org.apache.hadoop.hbase.io.hfile that return LruCachedBlockModifier and TypeMethodDescriptionLruCachedBlockQueue.poll()
Returns The next element in this queue, ornull
if the queue is empty.LruCachedBlockQueue.pollLast()
Returns The last element in this queue, ornull
if the queue is empty.Methods in org.apache.hadoop.hbase.io.hfile that return types with arguments of type LruCachedBlockModifier and TypeMethodDescription(package private) Map<BlockCacheKey,
LruCachedBlock> LruAdaptiveBlockCache.getMapForTests()
(package private) Map<BlockCacheKey,
LruCachedBlock> LruBlockCache.getMapForTests()
Methods in org.apache.hadoop.hbase.io.hfile with parameters of type LruCachedBlockModifier and TypeMethodDescriptionvoid
LruAdaptiveBlockCache.BlockBucket.add
(LruCachedBlock block) void
LruBlockCache.BlockBucket.add
(LruCachedBlock block) void
LruCachedBlockQueue.add
(LruCachedBlock cb) Attempt to add the specified cached block to this queue.int
LruCachedBlock.compareTo
(LruCachedBlock that) protected long
LruAdaptiveBlockCache.evictBlock
(LruCachedBlock block, boolean evictedByEvictionProcess) Evict the block, and it will be cached by the victim handler if exists && block may be read again laterprotected long
LruBlockCache.evictBlock
(LruCachedBlock block, boolean evictedByEvictionProcess) Evict the block, and it will be cached by the victim handler if exists && block may be read again laterprivate long
LruAdaptiveBlockCache.updateSizeMetrics
(LruCachedBlock cb, boolean evict) Helper function that updates the local size counter and also updates any per-cf or per-blocktype metrics it can discern from givenLruCachedBlock
private long
LruBlockCache.updateSizeMetrics
(LruCachedBlock cb, boolean evict) Helper function that updates the local size counter and also updates any per-cf or per-blocktype metrics it can discern from givenLruCachedBlock