private static class TestBucketCache.MockedBucketCache extends org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
ACCEPT_FACTOR_CONFIG_NAME, backingMap, DEFAULT_ERROR_TOLERATION_DURATION, DEFAULT_MEMORY_FACTOR, DEFAULT_MIN_FACTOR, DEFAULT_MULTI_FACTOR, DEFAULT_SINGLE_FACTOR, DEFAULT_WRITER_QUEUE_ITEMS, DEFAULT_WRITER_THREADS, EXTRA_FREE_FACTOR_CONFIG_NAME, ioEngine, MEMORY_FACTOR_CONFIG_NAME, MIN_FACTOR_CONFIG_NAME, MULTI_FACTOR_CONFIG_NAME, offsetLock, ramCache, SINGLE_FACTOR_CONFIG_NAME, wait_when_cache, writerQueues, writerThreads
Constructor and Description |
---|
MockedBucketCache(String ioEngineName,
long capacity,
int blockSize,
int[] bucketSizes,
int writerThreads,
int writerQLen,
String persistencePath) |
Modifier and Type | Method and Description |
---|---|
void |
cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey,
org.apache.hadoop.hbase.io.hfile.Cacheable buf) |
void |
cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey,
org.apache.hadoop.hbase.io.hfile.Cacheable buf,
boolean inMemory) |
acceptableSize, blockEvicted, cacheBlockWithWait, evictBlock, evictBlocksByHfileName, getAcceptableFactor, getAlgorithm, getAllocator, getBlock, getBlockCaches, getBlockCount, getCurrentDataSize, getCurrentSize, getDataBlockCount, getExtraFreeFactor, getFreeSize, getIoEngine, getMaxSize, getMemoryFactor, getMinFactor, getMultiFactor, getPartitionSize, getRAMQueueEntries, getRealCacheSize, getRpcRefCount, getSingleFactor, getStats, heapSize, isCacheEnabled, iterator, logStats, shutdown, size, startWriterThreads, stopWriterThreads
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
forEach, spliterator
public MockedBucketCache(String ioEngineName, long capacity, int blockSize, int[] bucketSizes, int writerThreads, int writerQLen, String persistencePath) throws IOException
IOException
public void cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf, boolean inMemory)
cacheBlock
in interface org.apache.hadoop.hbase.io.hfile.BlockCache
cacheBlock
in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
public void cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf)
cacheBlock
in interface org.apache.hadoop.hbase.io.hfile.BlockCache
cacheBlock
in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.