private static class TestBucketWriterThread.MockBucketCache 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 |
---|
MockBucketCache(String ioEngineName,
long capacity,
int blockSize,
int[] bucketSizes,
int writerThreadNum,
int writerQLen,
String persistencePath,
int ioErrorsTolerationDuration) |
Modifier and Type | Method and Description |
---|---|
protected void |
startWriterThreads() |
acceptableSize, blockEvicted, cacheBlock, cacheBlock, cacheBlockWithWait, cacheBlockWithWaitInternal, doDrain, evictBlock, evictBlockIfNoRpcReferenced, evictBlocksByHfileName, evictBucketEntryIfNoRpcReferenced, freeBucketEntry, freeSpace, 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, putIntoBackingMap, removeFromRamCache, shouldReplaceExistingCacheBlock, shutdown, size, stopWriterThreads
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
forEach, spliterator
public MockBucketCache(String ioEngineName, long capacity, int blockSize, int[] bucketSizes, int writerThreadNum, int writerQLen, String persistencePath, int ioErrorsTolerationDuration) throws IOException
IOException
protected void startWriterThreads()
startWriterThreads
in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.