| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.io.hfile.bucket | Provides  BucketCache, an implementation ofBlockCache. | 
| Modifier and Type | Field and Description | 
|---|---|
| (package private) ConcurrentHashMap<BlockCacheKey,BucketEntry> | BucketCache. backingMap | 
| private static Comparator<Map.Entry<BlockCacheKey,BucketEntry>> | CachedEntryQueue. COMPARATOR | 
| (package private) static Comparator<BucketEntry> | BucketEntry. COMPARATOR | 
| private org.apache.hbase.thirdparty.com.google.common.collect.MinMaxPriorityQueue<Map.Entry<BlockCacheKey,BucketEntry>> | CachedEntryQueue. queue | 
| Modifier and Type | Method and Description | 
|---|---|
| BucketEntry | BucketEntry. retain() | 
| BucketEntry | BucketCache.RAMQueueEntry. writeToCache(IOEngine ioEngine,
            BucketAllocator alloc,
            LongAdder realCacheSize) | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) static ConcurrentHashMap<BlockCacheKey,BucketEntry> | BucketProtoUtils. fromPB(Map<Integer,String> deserializers,
      org.apache.hadoop.hbase.shaded.protobuf.generated.BucketCacheProtos.BackingMap backingMap) | 
| Map.Entry<BlockCacheKey,BucketEntry> | CachedEntryQueue. poll() | 
| Map.Entry<BlockCacheKey,BucketEntry> | CachedEntryQueue. pollLast() | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) void | BucketCache. blockEvicted(BlockCacheKey cacheKey,
            BucketEntry bucketEntry,
            boolean decrementBlockNumber) | 
| private void | BucketCache.WriterThread. putIntoBackingMap(BlockCacheKey key,
                 BucketEntry bucketEntry)Put the new bucket entry into backingMap. | 
| abstract Cacheable | FileMmapIOEngine. read(BucketEntry be) | 
| Cacheable | SharedMemoryMmapIOEngine. read(BucketEntry be) | 
| Cacheable | ExclusiveMemoryMmapIOEngine. read(BucketEntry be) | 
| Cacheable | FileIOEngine. read(BucketEntry be)Transfers data from file to the given byte buffer | 
| Cacheable | ByteBufferIOEngine. read(BucketEntry be) | 
| Cacheable | IOEngine. read(BucketEntry be)Transfers data from IOEngine to a Cacheable object. | 
| private static org.apache.hadoop.hbase.shaded.protobuf.generated.BucketCacheProtos.BucketEntry | BucketProtoUtils. toPB(BucketEntry entry) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | CachedEntryQueue. add(Map.Entry<BlockCacheKey,BucketEntry> entry)Attempt to add the specified entry to this queue. | 
| void | BucketCache.BucketEntryGroup. add(Map.Entry<BlockCacheKey,BucketEntry> block) | 
| private static org.apache.hadoop.hbase.shaded.protobuf.generated.BucketCacheProtos.BackingMap | BucketProtoUtils. toPB(Map<BlockCacheKey,BucketEntry> backingMap) | 
| Constructor and Description | 
|---|
| BucketAllocator(long availableSpace,
               int[] bucketSizes,
               Map<BlockCacheKey,BucketEntry> map,
               LongAdder realCacheSize)Rebuild the allocator's data structures from a persisted map. | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.