Package | Description |
---|---|
org.apache.hadoop.hbase.io.hfile.bucket |
Provides
BucketCache , an implementation of
BlockCache . |
Modifier and Type | Class and Description |
---|---|
(package private) static class |
BucketCache.SharedMemoryBucketEntry |
class |
UnsafeSharedMemoryBucketEntry |
Modifier and Type | Field and Description |
---|---|
(package private) ConcurrentMap<BlockCacheKey,BucketCache.BucketEntry> |
BucketCache.backingMap |
(package private) static Comparator<BucketCache.BucketEntry> |
BucketCache.BucketEntry.COMPARATOR |
private org.apache.hbase.thirdparty.com.google.common.collect.MinMaxPriorityQueue<Map.Entry<BlockCacheKey,BucketCache.BucketEntry>> |
CachedEntryQueue.queue |
Modifier and Type | Method and Description |
---|---|
private BucketCache.BucketEntry |
BucketCache.RAMQueueEntry.getBucketEntry(IOEngine ioEngine,
long offset,
int len) |
BucketCache.BucketEntry |
BucketCache.RAMQueueEntry.writeToCache(IOEngine ioEngine,
BucketAllocator bucketAllocator,
UniqueIndexMap<Integer> deserialiserMap,
LongAdder realCacheSize) |
Modifier and Type | Method and Description |
---|---|
Map.Entry<BlockCacheKey,BucketCache.BucketEntry> |
CachedEntryQueue.poll() |
Map.Entry<BlockCacheKey,BucketCache.BucketEntry> |
CachedEntryQueue.pollLast() |
Modifier and Type | Method and Description |
---|---|
(package private) void |
BucketCache.blockEvicted(BlockCacheKey cacheKey,
BucketCache.BucketEntry bucketEntry,
boolean decrementBlockNumber) |
private void |
BucketCache.WriterThread.putIntoBackingMap(BlockCacheKey key,
BucketCache.BucketEntry bucketEntry)
Put the new bucket entry into backingMap.
|
Modifier and Type | Method and Description |
---|---|
void |
CachedEntryQueue.add(Map.Entry<BlockCacheKey,BucketCache.BucketEntry> entry)
Attempt to add the specified entry to this queue.
|
void |
BucketCache.BucketEntryGroup.add(Map.Entry<BlockCacheKey,BucketCache.BucketEntry> block) |
Constructor and Description |
---|
BucketAllocator(long availableSpace,
int[] bucketSizes,
Map<BlockCacheKey,BucketCache.BucketEntry> map,
LongAdder realCacheSize)
Rebuild the allocator's data structures from a persisted map.
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.