Package | Description |
---|---|
org.apache.hadoop.hbase.io.hfile |
Provides implementations of
HFile and HFile
BlockCache . |
Modifier and Type | Field and Description |
---|---|
private ConcurrentHashMap<BlockCacheKey,LruCachedBlock> |
LruBlockCache.map
Defined the cache map as
ConcurrentHashMap here, because in
LruBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean) , we need to guarantee the atomicity of map#computeIfPresent
(key, func). |
private ConcurrentHashMap<BlockCacheKey,LruCachedBlock> |
LruAdaptiveBlockCache.map
Defined the cache map as
ConcurrentHashMap here, because in
LruAdaptiveBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean) , we need to guarantee the atomicity of
map#computeIfPresent (key, func). |
private org.apache.hbase.thirdparty.com.google.common.collect.MinMaxPriorityQueue<LruCachedBlock> |
LruCachedBlockQueue.queue |
Modifier and Type | Method and Description |
---|---|
LruCachedBlock |
LruCachedBlockQueue.poll()
Returns The next element in this queue, or
null if the queue is empty. |
LruCachedBlock |
LruCachedBlockQueue.pollLast()
Returns The last element in this queue, or
null if the queue is empty. |
Modifier and Type | Method and Description |
---|---|
(package private) Map<BlockCacheKey,LruCachedBlock> |
LruBlockCache.getMapForTests() |
(package private) Map<BlockCacheKey,LruCachedBlock> |
LruAdaptiveBlockCache.getMapForTests() |
Modifier and Type | Method and Description |
---|---|
void |
LruCachedBlockQueue.add(LruCachedBlock cb)
Attempt to add the specified cached block to this queue.
|
void |
LruBlockCache.BlockBucket.add(LruCachedBlock block) |
void |
LruAdaptiveBlockCache.BlockBucket.add(LruCachedBlock block) |
int |
LruCachedBlock.compareTo(LruCachedBlock that) |
protected 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 later
|
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 later
|
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 given
LruCachedBlock |
private 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 given
LruCachedBlock |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.