Uses of Class
org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
Packages that use BucketEntry
-
Uses of BucketEntry in org.apache.hadoop.hbase.io.hfile.bucket
Fields in org.apache.hadoop.hbase.io.hfile.bucket with type parameters of type BucketEntryModifier and TypeFieldDescription(package private) Map<BlockCacheKey,BucketEntry> BucketCache.backingMap(package private) static final Comparator<BucketEntry>BucketEntry.COMPARATORprivate static final Comparator<Map.Entry<BlockCacheKey,BucketEntry>> CachedEntryQueue.COMPARATORprivate org.apache.hbase.thirdparty.com.google.common.collect.MinMaxPriorityQueue<Map.Entry<BlockCacheKey,BucketEntry>> CachedEntryQueue.queueMethods in org.apache.hadoop.hbase.io.hfile.bucket that return BucketEntryModifier and TypeMethodDescriptionBucketEntry.retain()BucketCache.RAMQueueEntry.writeToCache(IOEngine ioEngine, BucketAllocator alloc, LongAdder realCacheSize, Function<BucketEntry, ByteBuffAllocator.Recycler> createRecycler, ByteBuffer metaBuff) Methods in org.apache.hadoop.hbase.io.hfile.bucket that return types with arguments of type BucketEntryModifier 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, ornullif the queue is empty.CachedEntryQueue.pollLast()Returns The last element in this queue, ornullif the queue is empty.Methods in org.apache.hadoop.hbase.io.hfile.bucket with parameters of type BucketEntryModifier and TypeMethodDescription(package private) voidBucketCache.blockEvicted(BlockCacheKey cacheKey, BucketEntry bucketEntry, boolean decrementBlockNumber, boolean evictedByEvictionProcess) This method is invoked after the bucketEntry is removed fromBucketCache.backingMap(package private) voidFileIOEngine.checkCacheTime(BucketEntry be) private ByteBuffAllocator.RecyclerBucketCache.createRecycler(BucketEntry bucketEntry) Create theByteBuffAllocator.RecyclerforrefCnt,which would be used asRefCnt.recyclerofHFileBlock#bufreturned fromBucketCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean).private booleanBucketCache.doEvictBlock(BlockCacheKey cacheKey, BucketEntry bucketEntry, boolean evictedByEvictionProcess) (package private) booleanBucketCache.evictBucketEntryIfNoRpcReferenced(BlockCacheKey blockCacheKey, BucketEntry bucketEntry) (package private) voidBucketCache.freeBucketEntry(BucketEntry bucketEntry) Free the {BucketEntryactually,which could only be invoked when therefCntbecoming 0.protected voidBucketCache.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 CacheableFileMmapIOEngine.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.BucketEntryBucketProtoUtils.toPB(BucketEntry entry) Method parameters in org.apache.hadoop.hbase.io.hfile.bucket with type arguments of type BucketEntryModifier and TypeMethodDescriptionvoidBucketCache.BucketEntryGroup.add(Map.Entry<BlockCacheKey, BucketEntry> block) voidCachedEntryQueue.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.BackingMapBucketProtoUtils.toPB(Map<BlockCacheKey, BucketEntry> backingMap) BucketCache.RAMQueueEntry.writeToCache(IOEngine ioEngine, BucketAllocator alloc, LongAdder realCacheSize, Function<BucketEntry, ByteBuffAllocator.Recycler> createRecycler, ByteBuffer metaBuff) Constructor parameters in org.apache.hadoop.hbase.io.hfile.bucket with type arguments of type BucketEntryModifierConstructorDescription(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)