Package | Description |
---|---|
org.apache.hadoop.hbase.io.hfile.bucket |
Provides
BucketCache , an implementation of
BlockCache . |
Modifier and Type | Field and Description |
---|---|
(package private) ConcurrentHashMap<BlockCacheKey,BucketCache.RAMQueueEntry> |
BucketCache.RAMCache.delegate
Defined the map as
ConcurrentHashMap explicitly here, because in
BucketCache.RAMCache.get(BlockCacheKey) and
BucketCache.RAMCache.putIfAbsent(BlockCacheKey, BucketCache.RAMQueueEntry) , we need to guarantee
the atomicity of map#computeIfPresent(key, func) and map#putIfAbsent(key, func). |
private BlockingQueue<BucketCache.RAMQueueEntry> |
BucketCache.WriterThread.inputQueue |
(package private) ArrayList<BlockingQueue<BucketCache.RAMQueueEntry>> |
BucketCache.writerQueues
A list of writer queues.
|
Modifier and Type | Method and Description |
---|---|
BucketCache.RAMQueueEntry |
BucketCache.RAMCache.get(BlockCacheKey key) |
BucketCache.RAMQueueEntry |
BucketCache.RAMCache.putIfAbsent(BlockCacheKey key,
BucketCache.RAMQueueEntry entry)
Return the previous associated value, or null if absent.
|
Modifier and Type | Method and Description |
---|---|
(package private) static List<BucketCache.RAMQueueEntry> |
BucketCache.getRAMQueueEntries(BlockingQueue<BucketCache.RAMQueueEntry> q,
List<BucketCache.RAMQueueEntry> receptacle)
Blocks until elements available in
q then tries to grab as many as possible before
returning. |
Modifier and Type | Method and Description |
---|---|
private static String |
BucketCache.getAllocationFailWarningMessage(BucketAllocatorException fle,
BucketCache.RAMQueueEntry re)
Prepare and return a warning message for Bucket Allocator Exception
|
BucketCache.RAMQueueEntry |
BucketCache.RAMCache.putIfAbsent(BlockCacheKey key,
BucketCache.RAMQueueEntry entry)
Return the previous associated value, or null if absent.
|
Modifier and Type | Method and Description |
---|---|
(package private) void |
BucketCache.doDrain(List<BucketCache.RAMQueueEntry> entries,
ByteBuffer metaBuff)
Flush the entries in ramCache to IOEngine and add bucket entry to backingMap.
|
(package private) static List<BucketCache.RAMQueueEntry> |
BucketCache.getRAMQueueEntries(BlockingQueue<BucketCache.RAMQueueEntry> q,
List<BucketCache.RAMQueueEntry> receptacle)
Blocks until elements available in
q then tries to grab as many as possible before
returning. |
(package private) static List<BucketCache.RAMQueueEntry> |
BucketCache.getRAMQueueEntries(BlockingQueue<BucketCache.RAMQueueEntry> q,
List<BucketCache.RAMQueueEntry> receptacle)
Blocks until elements available in
q then tries to grab as many as possible before
returning. |
boolean |
BucketCache.RAMCache.remove(BlockCacheKey key,
Consumer<BucketCache.RAMQueueEntry> action)
Defined an
Consumer here, because once the removed entry release its reference count,
then it's ByteBuffers may be recycled and accessing it outside this method will be thrown an
exception. |
Constructor and Description |
---|
WriterThread(BlockingQueue<BucketCache.RAMQueueEntry> queue) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.