Uses of Class
org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
-
Uses of BucketEntry in org.apache.hadoop.hbase.io.hfile.bucket
Modifier and TypeFieldDescription(package private) Map<BlockCacheKey,
BucketEntry> BucketCache.backingMap
(package private) static final Comparator<BucketEntry>
BucketEntry.COMPARATOR
private static final Comparator<Map.Entry<BlockCacheKey,
BucketEntry>> CachedEntryQueue.COMPARATOR
private org.apache.hbase.thirdparty.com.google.common.collect.MinMaxPriorityQueue<Map.Entry<BlockCacheKey,
BucketEntry>> CachedEntryQueue.queue
Modifier and TypeMethodDescriptionBucketEntry.retain()
BucketCache.RAMQueueEntry.writeToCache
(IOEngine ioEngine, BucketAllocator alloc, LongAdder realCacheSize, Function<BucketEntry, ByteBuffAllocator.Recycler> createRecycler, ByteBuffer metaBuff) Modifier and TypeMethodDescription(package private) static Pair<ConcurrentHashMap<BlockCacheKey,
BucketEntry>, NavigableSet<BlockCacheKey>> BucketProtoUtils.fromPB
(Map<Integer, String> deserializers, org.apache.hadoop.hbase.shaded.protobuf.generated.BucketCacheProtos.BackingMap backingMap, Function<BucketEntry, ByteBuffAllocator.Recycler> createRecycler) BucketCache.getBackingMap()
CachedEntryQueue.poll()
Returns The next element in this queue, ornull
if the queue is empty.CachedEntryQueue.pollLast()
Returns The last element in this queue, ornull
if the queue is empty.Modifier and TypeMethodDescription(package private) void
BucketCache.blockEvicted
(BlockCacheKey cacheKey, BucketEntry bucketEntry, boolean decrementBlockNumber, boolean evictedByEvictionProcess) This method is invoked after the bucketEntry is removed fromBucketCache.backingMap
(package private) void
FileIOEngine.checkCacheTime
(BucketEntry be) private ByteBuffAllocator.Recycler
BucketCache.createRecycler
(BucketEntry bucketEntry) Create theByteBuffAllocator.Recycler
forrefCnt
,which would be used asRefCnt.recycler
ofHFileBlock#buf
returned fromBucketCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean)
.private boolean
BucketCache.doEvictBlock
(BlockCacheKey cacheKey, BucketEntry bucketEntry, boolean evictedByEvictionProcess) (package private) boolean
BucketCache.evictBucketEntryIfNoRpcReferenced
(BlockCacheKey blockCacheKey, BucketEntry bucketEntry) (package private) void
BucketCache.freeBucketEntry
(BucketEntry bucketEntry) Free the {BucketEntry
actually,which could only be invoked when therefCnt
becoming 0.protected void
BucketCache.putIntoBackingMap
(BlockCacheKey key, BucketEntry bucketEntry) Put the new bucket entry into backingMap.ByteBufferIOEngine.read
(BucketEntry be) ExclusiveMemoryMmapIOEngine.read
(BucketEntry be) FileIOEngine.read
(BucketEntry be) Transfers data from file to the given byte bufferabstract Cacheable
FileMmapIOEngine.read
(BucketEntry be) IOEngine.read
(BucketEntry be) Transfers data from IOEngine to a Cacheable object.SharedMemoryMmapIOEngine.read
(BucketEntry be) private static org.apache.hadoop.hbase.shaded.protobuf.generated.BucketCacheProtos.BucketEntry
BucketProtoUtils.toPB
(BucketEntry entry) Modifier and TypeMethodDescriptionvoid
BucketCache.BucketEntryGroup.add
(Map.Entry<BlockCacheKey, BucketEntry> block) void
CachedEntryQueue.add
(Map.Entry<BlockCacheKey, BucketEntry> entry) Attempt to add the specified entry to this queue.(package private) static Pair<ConcurrentHashMap<BlockCacheKey,
BucketEntry>, NavigableSet<BlockCacheKey>> BucketProtoUtils.fromPB
(Map<Integer, String> deserializers, org.apache.hadoop.hbase.shaded.protobuf.generated.BucketCacheProtos.BackingMap backingMap, Function<BucketEntry, ByteBuffAllocator.Recycler> createRecycler) private static org.apache.hadoop.hbase.shaded.protobuf.generated.BucketCacheProtos.BackingMap
BucketProtoUtils.toPB
(Map<BlockCacheKey, BucketEntry> backingMap) BucketCache.RAMQueueEntry.writeToCache
(IOEngine ioEngine, BucketAllocator alloc, LongAdder realCacheSize, Function<BucketEntry, ByteBuffAllocator.Recycler> createRecycler, ByteBuffer metaBuff) ModifierConstructorDescription(package private)
BucketAllocator
(long availableSpace, int[] bucketSizes, Map<BlockCacheKey, BucketEntry> map, LongAdder realCacheSize) Rebuild the allocator's data structures from a persisted map.(package private)
BucketEntry
(long offset, int length, int onDiskSizeWithHeader, long accessCounter, boolean inMemory, Function<BucketEntry, ByteBuffAllocator.Recycler> createRecycler, ByteBuffAllocator allocator) (package private)
BucketEntry
(long offset, int length, int onDiskSizeWithHeader, long accessCounter, long cachedTime, boolean inMemory, Function<BucketEntry, ByteBuffAllocator.Recycler> createRecycler, ByteBuffAllocator allocator)