Class TestBucketWriterThread.MockBucketCache

java.lang.Object
org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
org.apache.hadoop.hbase.io.hfile.bucket.TestBucketWriterThread.MockBucketCache
All Implemented Interfaces:
Iterable<org.apache.hadoop.hbase.io.hfile.CachedBlock>, org.apache.hadoop.hbase.io.HeapSize, org.apache.hadoop.hbase.io.hfile.BlockCache
Enclosing class:
TestBucketWriterThread

private static class TestBucketWriterThread.MockBucketCache extends org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
A BucketCache that does not start its writer threads.
  • Nested Class Summary

    Nested classes/interfaces inherited from class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache

    org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMCache, org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMQueueEntry, org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.WriterThread
  • Field Summary

    Fields inherited from class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache

    ACCEPT_FACTOR_CONFIG_NAME, backingMap, blocksByHFile, 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, fullyCachedFiles, ioEngine, isCacheInconsistent, MEMORY_FACTOR_CONFIG_NAME, MIN_FACTOR_CONFIG_NAME, MULTI_FACTOR_CONFIG_NAME, offsetLock, ramCache, regionCachedSize, SINGLE_FACTOR_CONFIG_NAME, writerQueues, writerThreads
  • Constructor Summary

    Constructors
    Constructor
    Description
    MockBucketCache(String ioEngineName, long capacity, int blockSize, int[] bucketSizes, int writerThreadNum, int writerQLen, String persistencePath, int ioErrorsTolerationDuration)
     
  • Method Summary

    Modifier and Type
    Method
    Description
    protected void
     

    Methods inherited from class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache

    acceptableSize, blockEvicted, blockFitsIntoTheCache, cacheBlock, cacheBlock, cacheBlock, cacheBlockWithWait, cacheBlockWithWaitInternal, doDrain, evictBlock, evictBlockIfNoRpcReferenced, evictBlocksByHfileName, evictBlocksRangeByHfileName, evictBucketEntryIfNoRpcReferenced, fileCacheCompleted, finalize, freeBucketEntry, freeSpace, getAcceptableFactor, getAlgorithm, getAllocator, getBackingMap, getBackingMapValidated, getBlock, getBlockCaches, getBlockCount, getBlockForReference, getBlockSize, getBucketCacheFromCacheConfig, getCurrentDataSize, getCurrentSize, getDataBlockCount, getExtraFreeFactor, getFreeSize, getFullyCachedFiles, getIoEngine, getMaxSize, getMemoryFactor, getMinFactor, getMultiFactor, getPartitionSize, getPersistencePath, getRAMQueueEntries, getRealCacheSize, getRegionCachedInfo, getRpcRefCount, getSingleFactor, getStats, heapSize, isAlreadyCached, isCacheEnabled, isCacheInconsistent, isCachePersistenceEnabled, isCachePersistent, iterator, logStats, notifyFileCachingCompleted, persistToFile, putIntoBackingMap, removeFromRamCache, setCacheInconsistent, shouldCacheFile, shouldReplaceExistingCacheBlock, shutdown, size, startBucketCachePersisterThread, stopWriterThreads

    Methods inherited from class java.lang.Object

    clone, equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait

    Methods inherited from interface org.apache.hadoop.hbase.io.hfile.BlockCache

    getBlock, isMetaBlock

    Methods inherited from interface java.lang.Iterable

    forEach, spliterator
  • Constructor Details

    • MockBucketCache

      public MockBucketCache(String ioEngineName, long capacity, int blockSize, int[] bucketSizes, int writerThreadNum, int writerQLen, String persistencePath, int ioErrorsTolerationDuration) throws IOException
      Throws:
      IOException
  • Method Details

    • startWriterThreads

      protected void startWriterThreads()
      Overrides:
      startWriterThreads in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache