Package | Description |
---|---|
org.apache.hadoop.hbase.io.hfile |
Provides implementations of
HFile and HFile
BlockCache . |
org.apache.hadoop.hbase.io.hfile.bucket |
Provides
BucketCache , an implementation of
BlockCache . |
Modifier and Type | Interface and Description |
---|---|
interface |
CacheableDeserializer<T extends Cacheable>
Interface for a deserializer.
|
Modifier and Type | Class and Description |
---|---|
class |
HFileBlock
Cacheable Blocks of an
HFile version 2 file. |
Modifier and Type | Field and Description |
---|---|
private Cacheable |
LruCachedBlock.buf |
Modifier and Type | Field and Description |
---|---|
(package private) static CacheableDeserializer<Cacheable> |
HFileBlock.BLOCK_DESERIALIZER
Used deserializing blocks from Cache.
|
private static Map<Integer,CacheableDeserializer<Cacheable>> |
CacheableDeserializerIdManager.registeredDeserializers |
Modifier and Type | Method and Description |
---|---|
Cacheable |
LruBlockCache.getBlock(BlockCacheKey cacheKey,
boolean caching,
boolean repeat,
boolean updateCacheMetrics)
Get the buffer of the block with the specified name.
|
Cacheable |
BlockCache.getBlock(BlockCacheKey cacheKey,
boolean caching,
boolean repeat,
boolean updateCacheMetrics)
Fetch block from cache.
|
Cacheable |
CombinedBlockCache.getBlock(BlockCacheKey cacheKey,
boolean caching,
boolean repeat,
boolean updateCacheMetrics) |
Cacheable |
InclusiveCombinedBlockCache.getBlock(BlockCacheKey cacheKey,
boolean caching,
boolean repeat,
boolean updateCacheMetrics) |
Cacheable |
MemcachedBlockCache.getBlock(BlockCacheKey cacheKey,
boolean caching,
boolean repeat,
boolean updateCacheMetrics) |
Cacheable |
LruCachedBlock.getBuffer() |
Modifier and Type | Method and Description |
---|---|
CacheableDeserializer<Cacheable> |
Cacheable.getDeserializer()
Returns CacheableDeserializer instance which reconstructs original object from ByteBuffer.
|
CacheableDeserializer<Cacheable> |
HFileBlock.getDeserializer() |
static CacheableDeserializer<Cacheable> |
CacheableDeserializerIdManager.getDeserializer(int id)
Get the cacheable deserializer as the given identifier Id
|
Modifier and Type | Method and Description |
---|---|
void |
LruBlockCache.cacheBlock(BlockCacheKey cacheKey,
Cacheable buf)
Cache the block with the specified name and buffer.
|
void |
BlockCache.cacheBlock(BlockCacheKey cacheKey,
Cacheable buf)
Add block to cache (defaults to not in-memory).
|
void |
CombinedBlockCache.cacheBlock(BlockCacheKey cacheKey,
Cacheable buf) |
void |
MemcachedBlockCache.cacheBlock(BlockCacheKey cacheKey,
Cacheable buf) |
void |
LruBlockCache.cacheBlock(BlockCacheKey cacheKey,
Cacheable buf,
boolean inMemory)
Cache the block with the specified name and buffer.
|
void |
BlockCache.cacheBlock(BlockCacheKey cacheKey,
Cacheable buf,
boolean inMemory)
Add block to cache.
|
void |
CombinedBlockCache.cacheBlock(BlockCacheKey cacheKey,
Cacheable buf,
boolean inMemory) |
void |
InclusiveCombinedBlockCache.cacheBlock(BlockCacheKey cacheKey,
Cacheable buf,
boolean inMemory) |
void |
MemcachedBlockCache.cacheBlock(BlockCacheKey cacheKey,
Cacheable buf,
boolean inMemory) |
private static int |
BlockCacheUtil.compareCacheBlock(Cacheable left,
Cacheable right,
boolean includeNextBlockMetadata) |
private void |
HFileReaderImpl.returnAndEvictBlock(BlockCache cache,
BlockCacheKey cacheKey,
Cacheable block) |
default void |
BlockCache.returnBlock(BlockCacheKey cacheKey,
Cacheable block)
Called when the scanner using the block decides to return the block once its usage
is over.
|
void |
CombinedBlockCache.returnBlock(BlockCacheKey cacheKey,
Cacheable block) |
static boolean |
BlockCacheUtil.shouldReplaceExistingCacheBlock(BlockCache blockCache,
BlockCacheKey cacheKey,
Cacheable newBlock)
Because of the region splitting, it's possible that the split key locate in the middle of a
block.
|
static int |
BlockCacheUtil.validateBlockAddition(Cacheable existing,
Cacheable newBlock,
BlockCacheKey cacheKey)
Validate that the existing and newBlock are the same without including the nextBlockMetadata,
if not, throw an exception.
|
Modifier and Type | Method and Description |
---|---|
static int |
CacheableDeserializerIdManager.registerDeserializer(CacheableDeserializer<Cacheable> cd)
Register the given
Cacheable -- usually an hfileblock instance, these implement
the Cacheable Interface -- deserializer and generate a unique identifier id for it and return
this as our result. |
Constructor and Description |
---|
LruCachedBlock(BlockCacheKey cacheKey,
Cacheable buf,
long accessTime) |
LruCachedBlock(BlockCacheKey cacheKey,
Cacheable buf,
long accessTime,
boolean inMemory) |
Modifier and Type | Field and Description |
---|---|
private Cacheable |
BucketCache.RAMQueueEntry.data |
Modifier and Type | Method and Description |
---|---|
Cacheable |
BucketCache.getBlock(BlockCacheKey key,
boolean caching,
boolean repeat,
boolean updateCacheMetrics)
Get the buffer of the block with the specified key.
|
Cacheable |
BucketCache.RAMQueueEntry.getData() |
Cacheable |
FileIOEngine.read(long offset,
int length,
CacheableDeserializer<Cacheable> deserializer)
Transfers data from file to the given byte buffer
|
Cacheable |
FileMmapEngine.read(long offset,
int length,
CacheableDeserializer<Cacheable> deserializer) |
Cacheable |
ByteBufferIOEngine.read(long offset,
int length,
CacheableDeserializer<Cacheable> deserializer) |
Cacheable |
IOEngine.read(long offset,
int length,
CacheableDeserializer<Cacheable> deserializer)
Transfers data from IOEngine to a Cacheable object.
|
Modifier and Type | Method and Description |
---|---|
protected CacheableDeserializer<Cacheable> |
BucketCache.BucketEntry.deserializerReference(UniqueIndexMap<Integer> deserialiserMap) |
Modifier and Type | Method and Description |
---|---|
void |
BucketCache.cacheBlock(BlockCacheKey cacheKey,
Cacheable buf)
Cache the block with the specified name and buffer.
|
void |
BucketCache.cacheBlock(BlockCacheKey cacheKey,
Cacheable cachedItem,
boolean inMemory)
Cache the block with the specified name and buffer.
|
private void |
BucketCache.cacheBlockWithWait(BlockCacheKey cacheKey,
Cacheable cachedItem,
boolean inMemory,
boolean wait)
Cache the block to ramCache
|
private void |
BucketCache.cacheBlockWithWaitInternal(BlockCacheKey cacheKey,
Cacheable cachedItem,
boolean inMemory,
boolean wait) |
void |
BucketCache.returnBlock(BlockCacheKey cacheKey,
Cacheable block) |
Modifier and Type | Method and Description |
---|---|
Cacheable |
FileIOEngine.read(long offset,
int length,
CacheableDeserializer<Cacheable> deserializer)
Transfers data from file to the given byte buffer
|
Cacheable |
FileMmapEngine.read(long offset,
int length,
CacheableDeserializer<Cacheable> deserializer) |
Cacheable |
ByteBufferIOEngine.read(long offset,
int length,
CacheableDeserializer<Cacheable> deserializer) |
Cacheable |
IOEngine.read(long offset,
int length,
CacheableDeserializer<Cacheable> deserializer)
Transfers data from IOEngine to a Cacheable object.
|
protected void |
BucketCache.BucketEntry.setDeserialiserReference(CacheableDeserializer<Cacheable> deserializer,
UniqueIndexMap<Integer> deserialiserMap) |
Constructor and Description |
---|
RAMQueueEntry(BlockCacheKey bck,
Cacheable data,
long accessCounter,
boolean inMemory) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.