Class BucketCache
- All Implemented Interfaces:
- Iterable<CachedBlock>,- HeapSize,- BlockCache
BucketAllocator to allocate/free blocks, and uses BucketCache#ramCache
 and BucketCache#backingMap in order to determine if a given element is in the cache. The bucket
 cache can use off-heap memory ByteBufferIOEngine or mmap
 ExclusiveMemoryMmapIOEngine or pmem SharedMemoryMmapIOEngine or local files
 FileIOEngine to store/read the block data.
 
 Eviction is via a similar algorithm as used in
 LruBlockCache
 
 BucketCache can be used as mainly a block cache (see
 CombinedBlockCache), combined with a BlockCache to
 decrease CMS GC and heap fragmentation.
 
It also can be used as a secondary cache (e.g. using a file on ssd/fusionio to store blocks) to enlarge cache space via a victim cache.
- 
Nested Class SummaryNested ClassesModifier and TypeClassDescriptionprivate classUsed to group bucket entries into priority buckets.(package private) static classWrapped the delegate ConcurrentMap with maintaining its block's reference count.(package private) static classBlock Entry stored in the memory with key,data and so onprivate static class(package private) class
- 
Field SummaryFieldsModifier and TypeFieldDescription(package private) static final Stringprivate floatAcceptable size of cache (no evictions if size < acceptable)private final AtomicLongCache access count (sequential ID)private StringUseMessageDigestclass's encryption algorithms to check persistent file integrity, default algorithm is MD5private static final intprivate long(package private) Map<BlockCacheKey,BucketEntry> private AtomicBooleanprivate final LongAdderCurrent number of cached elements(package private) NavigableSet<BlockCacheKey>private final longApproximate block sizeprivate BucketAllocatorprivate longprivate final longprivate booleanFlag if the cache is enabled or not...private BucketCachePersisterprivate final BucketCacheStatsprivate static final floatprivate static final intstatic final intprivate static final floatprivate static final Stringprivate static final int(package private) static final float(package private) static final float(package private) static final floatprivate static final long(package private) static final floatPriority buckets(package private) static final int(package private) static final int(package private) static final Stringprivate floatFree this floating point factor of extra blocks when evicting.private static final Stringprivate booleanVolatile boolean to track if free space is in process or notprivate final LockMap of hFile -> Region -> File size.private final LongAdder(package private) final IOEngineprivate longprivate final intDuration of IO errors tolerated before we disable cache, 1 min as default(package private) static AtomicBooleanprivate static final org.slf4j.Logger(package private) static final Stringprivate floatIn-memory bucket size(package private) static final Stringprivate floatMinimum threshold of cache (when evicting, evict until size < min)(package private) static final Stringprivate floatMultiple access bucket size(package private) final IdReadWriteLock<Long>A ReentrantReadWriteLock to lock on a particular block identified by offset.private final Stringprivate static final Stringprivate long(package private) final BucketCache.RAMCacheprivate final LongAdderMap of region -> total size of the region prefetched on this region server.private final ScheduledExecutorServiceStatistics thread schedule pool (for heavy debugging, could remove)(package private) static final StringPriority buckets configprivate floatSingle access bucket sizeprivate static final intStatistics thread(package private) final ArrayList<BlockingQueue<BucketCache.RAMQueueEntry>>A list of writer queues.(package private) final BucketCache.WriterThread[]
- 
Constructor SummaryConstructorsConstructorDescriptionBucketCache(String ioEngineName, long capacity, int blockSize, int[] bucketSizes, int writerThreadNum, int writerQLen, String persistencePath) BucketCache(String ioEngineName, long capacity, int blockSize, int[] bucketSizes, int writerThreadNum, int writerQLen, String persistencePath, int ioErrorsTolerationDuration, org.apache.hadoop.conf.Configuration conf) 
- 
Method SummaryModifier and TypeMethodDescriptionlong(package private) voidblockEvicted(BlockCacheKey cacheKey, BucketEntry bucketEntry, boolean decrementBlockNumber, boolean evictedByEvictionProcess) This method is invoked after the bucketEntry is removed frombackingMapblockFitsIntoTheCache(HFileBlock block) Checks whether there's enough space left in the cache to accommodate the passed block.private intbucketSizesAboveThresholdCount(float minFactor) Return the count of bucketSizeinfos still need free spacevoidcacheBlock(BlockCacheKey cacheKey, Cacheable buf) Cache the block with the specified name and buffer.voidcacheBlock(BlockCacheKey cacheKey, Cacheable cachedItem, boolean inMemory) Cache the block with the specified name and buffer.voidcacheBlock(BlockCacheKey cacheKey, Cacheable cachedItem, boolean inMemory, boolean waitWhenCache) Cache the block with the specified name and buffer.voidcacheBlockWithWait(BlockCacheKey cacheKey, Cacheable cachedItem, boolean inMemory, boolean wait) Cache the block to ramCacheprotected voidcacheBlockWithWaitInternal(BlockCacheKey cacheKey, Cacheable cachedItem, boolean inMemory, boolean wait) private voidCheck whether we tolerate IO error this time.private ByteBuffAllocator.RecyclercreateRecycler(BucketEntry bucketEntry) Create theByteBuffAllocator.RecyclerforBucketEntry.refCnt,which would be used asRefCnt.recyclerofHFileBlock#bufreturned fromgetBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean).private FileInputStreamdeleteFileOnClose(File file) Create an input stream that deletes the file after reading it.private voidUsed to shut down the cache -or- turn it off in the case of something broken.(package private) voiddoDrain(List<BucketCache.RAMQueueEntry> entries, ByteBuffer metaBuff) Flush the entries in ramCache to IOEngine and add bucket entry to backingMap.private booleandoEvictBlock(BlockCacheKey cacheKey, BucketEntry bucketEntry, boolean evictedByEvictionProcess) private voidbooleanevictBlock(BlockCacheKey cacheKey) Try to evict the block fromBlockCacheby force.booleanevictBlockIfNoRpcReferenced(BlockCacheKey blockCacheKey) NOTE: This method is only for test.intevictBlocksByHfileName(String hfileName) Evicts all blocks for a specific HFile.(package private) booleanevictBucketEntryIfNoRpcReferenced(BlockCacheKey blockCacheKey, BucketEntry bucketEntry) voidfileCacheCompleted(org.apache.hadoop.fs.Path filePath, long size) protected voidfinalize()Needed mostly for UTs that might run in the same VM and create different BucketCache instances on different UT methods.(package private) voidfreeBucketEntry(BucketEntry bucketEntry) Free the {BucketEntryactually,which could only be invoked when theBucketEntry.refCntbecoming 0.private voidfreeEntireBuckets(int completelyFreeBucketsNeeded) This method will find the buckets that are minimally occupied and are not reference counted and will free them completely without any constraint on the access times of the elements, and as a process will completely free at most the number of buckets passed, sometimes it might not due to changing refCounts(package private) voidFree the space if the used size reaches acceptableSize() or one size block couldn't be allocated.(package private) floatprotected Stringprivate Set<BlockCacheKey>getAllCacheKeysForFile(String hfileName) private static StringPrepare and return a warning message for Bucket Allocator ExceptiongetBlock(BlockCacheKey key, boolean caching, boolean repeat, boolean updateCacheMetrics) Get the buffer of the block with the specified key.Returns The list of sub blockcaches that make up this one; returns null if no sub caches.longReturns the number of blocks currently cached in the block cache.Returns an Optional containing the size of the block related to the passed key.static Optional<BucketCache>getBucketCacheFromCacheConfig(CacheConfig cacheConf) longReturns the occupied size of data blocks, in bytes.longReturns the occupied size of the block cache, in bytes.longReturns the number of data blocks currently cached in the block cache.(package private) floatlongReturns the free size of the block cache, in bytes.Returns an Optional containing the map of files that have been fully cached (all its blocks are present in the cache.private IOEnginegetIOEngineFromName(String ioEngineName, long capacity, String persistencePath) Get the IOEngine from the IO engine namelongReturns the Max size of the block cache, in bytes.(package private) float(package private) float(package private) float(package private) longgetPartitionSize(float partitionFactor) (package private) static List<BucketCache.RAMQueueEntry>getRAMQueueEntries(BlockingQueue<BucketCache.RAMQueueEntry> q, List<BucketCache.RAMQueueEntry> receptacle) Blocks until elements available inqthen tries to grab as many as possible before returning.longintgetRpcRefCount(BlockCacheKey cacheKey) (package private) floatgetStats()Get the statistics for this block cache.longheapSize()Return the approximate 'exclusive deep size' of implementing object.Checks whether the block for the passed key is already cached.(package private) booleanbooleanbooleanbooleaniterator()Returns Iterator over the blocks in the cache.private voidjoin()voidlogStats()voidnotifyFileBlockEvicted(String fileName) Notifies the cache implementation that the given file had a block evictedvoidnotifyFileCachingCompleted(org.apache.hadoop.fs.Path fileName, int totalBlockCount, int dataBlockCount, long size) Notifies the cache implementation that the given file has been fully cached (all its blocks made into the cache).private voidparsePB(org.apache.hadoop.hbase.shaded.protobuf.generated.BucketCacheProtos.BucketCacheEntry proto) (package private) voidprotected voidputIntoBackingMap(BlockCacheKey key, BucketEntry bucketEntry) Put the new bucket entry into backingMap.private voidremoveFileFromPrefetch(String hfileName) protected booleanremoveFromRamCache(BlockCacheKey cacheKey) private voidretrieveFromFile(int[] bucketSizes) private voidvoidsetCacheInconsistent(boolean setCacheInconsistent) shouldCacheFile(String fileName) Checks whether blocks for the passed file should be cached or not.protected booleanshouldReplaceExistingCacheBlock(BlockCacheKey cacheKey, Cacheable newBlock) voidshutdown()Shutdown the cache.longsize()Returns the total size of the block cache, in bytes.(package private) voidprotected voidCalled by the constructor to start the writer threads.(package private) voidOnly used in testprivate voidprivate voidverifyCapacityAndClasses(long capacitySize, String ioclass, String mapclass) Methods inherited from class java.lang.Objectclone, equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface org.apache.hadoop.hbase.io.hfile.BlockCacheisMetaBlockMethods inherited from interface java.lang.IterableforEach, spliterator
- 
Field Details- 
LOG
- 
SINGLE_FACTOR_CONFIG_NAMEPriority buckets config- See Also:
 
- 
MULTI_FACTOR_CONFIG_NAME- See Also:
 
- 
MEMORY_FACTOR_CONFIG_NAME- See Also:
 
- 
EXTRA_FREE_FACTOR_CONFIG_NAME- See Also:
 
- 
ACCEPT_FACTOR_CONFIG_NAME- See Also:
 
- 
MIN_FACTOR_CONFIG_NAME- See Also:
 
- 
DEFAULT_SINGLE_FACTORPriority buckets- See Also:
 
- 
DEFAULT_MULTI_FACTOR- See Also:
 
- 
DEFAULT_MEMORY_FACTOR- See Also:
 
- 
DEFAULT_MIN_FACTOR- See Also:
 
- 
DEFAULT_EXTRA_FREE_FACTOR- See Also:
 
- 
DEFAULT_ACCEPT_FACTOR- See Also:
 
- 
DEFAULT_FREE_ENTIRE_BLOCK_FACTOR- See Also:
 
- 
statThreadPeriodStatistics thread- See Also:
 
- 
DEFAULT_WRITER_THREADS- See Also:
 
- 
DEFAULT_WRITER_QUEUE_ITEMS- See Also:
 
- 
ioEngine
- 
ramCache
- 
backingMap
- 
backingMapValidated
- 
fullyCachedFilesMap of hFile -> Region -> File size. This map is used to track all files completed prefetch, together with the region those belong to and the total cached size for the region.TestBlockEvictionOnRegionMovement
- 
regionCachedSizeMapMap of region -> total size of the region prefetched on this region server. This is the total size of hFiles for this region prefetched on this region server
- 
cachePersister
- 
cacheEnabledFlag if the cache is enabled or not... We shut it off if there are IO errors for some time, so that Bucket IO exceptions/errors don't bring down the HBase server.
- 
writerQueuesA list of writer queues. We have a queue perBucketCache.WriterThreadwe have running. In other words, the work adding blocks to the BucketCache is divided up amongst the running WriterThreads. Its done by taking hash of the cache key modulo queue count. WriterThread when it runs takes whatever has been recently added and 'drains' the entries to the BucketCache. It then updates the ramCache and backingMap accordingly.
- 
writerThreads
- 
freeInProgressVolatile boolean to track if free space is in process or not
- 
freeSpaceLock
- 
realCacheSize
- 
heapSize
- 
blockNumberCurrent number of cached elements
- 
accessCountCache access count (sequential ID)
- 
DEFAULT_CACHE_WAIT_TIME- See Also:
 
- 
cacheStats
- 
persistencePath
- 
isCacheInconsistent
- 
cacheCapacity
- 
blockSizeApproximate block size
- 
ioErrorsTolerationDurationDuration of IO errors tolerated before we disable cache, 1 min as default
- 
DEFAULT_ERROR_TOLERATION_DURATION- See Also:
 
- 
ioErrorStartTime
- 
offsetLockA ReentrantReadWriteLock to lock on a particular block identified by offset. The purpose of this is to avoid freeing the block which is being read.Key set of offsets in BucketCache is limited so soft reference is the best choice here. 
- 
blocksByHFile
- 
scheduleThreadPoolStatistics thread schedule pool (for heavy debugging, could remove)
- 
bucketAllocator
- 
acceptableFactorAcceptable size of cache (no evictions if size < acceptable)
- 
minFactorMinimum threshold of cache (when evicting, evict until size < min)
- 
extraFreeFactorFree this floating point factor of extra blocks when evicting. For example free the number of blocks requested * (1 + extraFreeFactor)
- 
singleFactorSingle access bucket size
- 
multiFactorMultiple access bucket size
- 
memoryFactorIn-memory bucket size
- 
bucketcachePersistInterval
- 
FILE_VERIFY_ALGORITHM- See Also:
 
- 
DEFAULT_FILE_VERIFY_ALGORITHM- See Also:
 
- 
QUEUE_ADDITION_WAIT_TIME- See Also:
 
- 
DEFAULT_QUEUE_ADDITION_WAIT_TIME- See Also:
 
- 
queueAdditionWaitTime
- 
algorithmUseMessageDigestclass's encryption algorithms to check persistent file integrity, default algorithm is MD5
- 
allocFailLogPrevTs
- 
ALLOCATION_FAIL_LOG_TIME_PERIOD- See Also:
 
 
- 
- 
Constructor Details- 
BucketCachepublic BucketCache(String ioEngineName, long capacity, int blockSize, int[] bucketSizes, int writerThreadNum, int writerQLen, String persistencePath) throws IOException - Throws:
- IOException
 
- 
BucketCachepublic BucketCache(String ioEngineName, long capacity, int blockSize, int[] bucketSizes, int writerThreadNum, int writerQLen, String persistencePath, int ioErrorsTolerationDuration, org.apache.hadoop.conf.Configuration conf) throws IOException - Throws:
- IOException
 
 
- 
- 
Method Details- 
sanityCheckConfigs
- 
startWriterThreadsCalled by the constructor to start the writer threads. Used by tests that need to override starting the threads.
- 
startBucketCachePersisterThread
- 
isCacheEnabledboolean isCacheEnabled()
- 
getMaxSizeDescription copied from interface:BlockCacheReturns the Max size of the block cache, in bytes.- Specified by:
- getMaxSizein interface- BlockCache
- Returns:
- size of cache, in bytes
 
- 
getIoEngine
- 
getIOEngineFromNameprivate IOEngine getIOEngineFromName(String ioEngineName, long capacity, String persistencePath) throws IOException Get the IOEngine from the IO engine name- Returns:
- the IOEngine
- Throws:
- IOException
 
- 
isCachePersistenceEnabled
- 
cacheBlockCache the block with the specified name and buffer.- Specified by:
- cacheBlockin interface- BlockCache
- Parameters:
- cacheKey- block's cache key
- buf- block buffer
 
- 
cacheBlockCache the block with the specified name and buffer.- Specified by:
- cacheBlockin interface- BlockCache
- Parameters:
- cacheKey- block's cache key
- cachedItem- block buffer
- inMemory- if block is in-memory
 
- 
cacheBlockpublic void cacheBlock(BlockCacheKey cacheKey, Cacheable cachedItem, boolean inMemory, boolean waitWhenCache) Cache the block with the specified name and buffer.- Specified by:
- cacheBlockin interface- BlockCache
- Parameters:
- cacheKey- block's cache key
- cachedItem- block buffer
- inMemory- if block is in-memory
- waitWhenCache- Whether to wait for the cache to be flushed mainly when BucketCache is configured.
 
- 
cacheBlockWithWaitpublic void cacheBlockWithWait(BlockCacheKey cacheKey, Cacheable cachedItem, boolean inMemory, boolean wait) Cache the block to ramCache- Parameters:
- cacheKey- block's cache key
- cachedItem- block buffer
- inMemory- if block is in-memory
- wait- if true, blocking wait when queue is full
 
- 
shouldReplaceExistingCacheBlock
- 
cacheBlockWithWaitInternalprotected void cacheBlockWithWaitInternal(BlockCacheKey cacheKey, Cacheable cachedItem, boolean inMemory, boolean wait) 
- 
getBlockpublic Cacheable getBlock(BlockCacheKey key, boolean caching, boolean repeat, boolean updateCacheMetrics) Get the buffer of the block with the specified key.- Specified by:
- getBlockin interface- BlockCache
- Parameters:
- key- block's cache key
- caching- true if the caller caches blocks on cache misses
- repeat- Whether this is a repeat lookup for the same block
- updateCacheMetrics- Whether we should update cache metrics or not
- Returns:
- buffer of specified cache key, or null if not in cache
 
- 
blockEvictedvoid blockEvicted(BlockCacheKey cacheKey, BucketEntry bucketEntry, boolean decrementBlockNumber, boolean evictedByEvictionProcess) This method is invoked after the bucketEntry is removed frombackingMap
- 
freeBucketEntryFree the {BucketEntryactually,which could only be invoked when theBucketEntry.refCntbecoming 0.
- 
evictBlockTry to evict the block fromBlockCacheby force. We'll call this in few cases:
 1. Close an HFile, and clear all cached blocks.
 2. CallAdmin.clearBlockCache(TableName)to clear all blocks for a given table.
 Firstly, we'll try to remove the block from RAMCache,and then try to evict from backingMap. Here we evict the block from backingMap immediately, but only free the reference from bucket cache by calling BucketEntry.markedAsEvicted. If there're still some RPC referring this block, block can only be de-allocated when all of them release the block.NOTICE: we need to grab the write offset lock firstly before releasing the reference from bucket cache. if we don't, we may read an BucketEntrywith refCnt = 0 whengetBlock(BlockCacheKey, boolean, boolean, boolean), it's a memory leak.- Specified by:
- evictBlockin interface- BlockCache
- Parameters:
- cacheKey- Block to evict
- Returns:
- true to indicate whether we've evicted successfully or not.
 
- 
doEvictBlockprivate boolean doEvictBlock(BlockCacheKey cacheKey, BucketEntry bucketEntry, boolean evictedByEvictionProcess) Evict theBlockCacheKeyandBucketEntryfrombackingMapandramCache.
 NOTE:When Evict frombackingMap,only the matchedBlockCacheKeyandBucketEntrycould be removed.- Parameters:
- cacheKey-- BlockCacheKeyto evict.
- bucketEntry-- BucketEntrymatched- BlockCacheKeyto evict.
- Returns:
- true to indicate whether we've evicted successfully or not.
 
- 
createRecyclerCreate the ByteBuffAllocator.RecyclerforBucketEntry.refCnt,which would be used asRefCnt.recyclerofHFileBlock#bufreturned fromgetBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean). NOTE: forgetBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean),theRefCnt.recyclerofHFileBlock#buffrombackingMapandramCacheare different: 1.ForRefCnt.recyclerofHFileBlock#buffrombackingMap, it is the return value of currentcreateRecycler(org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry)method. 2.ForRefCnt.recyclerofHFileBlock#buffromramCache, it isByteBuffAllocator.putbackBuffer(java.nio.ByteBuffer).
- 
evictBlockIfNoRpcReferencedNOTE: This method is only for test.
- 
evictBucketEntryIfNoRpcReferencedEvictBlockCacheKeyand its correspondingBucketEntryonly ifBucketEntry.isRpcRef()is false.
 NOTE:When evict frombackingMap,only the matchedBlockCacheKeyandBucketEntrycould be removed.- Parameters:
- blockCacheKey-- BlockCacheKeyto evict.
- bucketEntry-- BucketEntrymatched- BlockCacheKeyto evict.
- Returns:
- true to indicate whether we've evicted successfully or not.
 
- 
removeFromRamCache
- 
isCacheInconsistent
- 
setCacheInconsistent
- 
logStats
- 
getRealCacheSize
- 
acceptableSize
- 
getPartitionSize
- 
bucketSizesAboveThresholdCountReturn the count of bucketSizeinfos still need free space
- 
freeEntireBucketsThis method will find the buckets that are minimally occupied and are not reference counted and will free them completely without any constraint on the access times of the elements, and as a process will completely free at most the number of buckets passed, sometimes it might not due to changing refCounts- Parameters:
- completelyFreeBucketsNeeded- number of buckets to free
 
- 
freeSpaceFree the space if the used size reaches acceptableSize() or one size block couldn't be allocated. When freeing the space, we use the LRU algorithm and ensure there must be some blocks evicted- Parameters:
- why- Why we are being called
 
- 
putIntoBackingMapPut the new bucket entry into backingMap. Notice that we are allowed to replace the existing cache with a new block for the same cache key. there's a corner case: one thread cache a block in ramCache, copy to io-engine and add a bucket entry to backingMap. Caching another new block with the same cache key do the same thing for the same cache key, so if not evict the previous bucket entry, then memory leak happen because the previous bucketEntry is gone but the bucketAllocator do not free its memory.- Parameters:
- key- Block cache key
- bucketEntry- Bucket entry to put into backingMap.
- See Also:
 
- 
getAllocationFailWarningMessageprivate static String getAllocationFailWarningMessage(BucketAllocatorException fle, BucketCache.RAMQueueEntry re) Prepare and return a warning message for Bucket Allocator Exception- Parameters:
- fle- The exception
- re- The RAMQueueEntry for which the exception was thrown.
- Returns:
- A warning message created from the input RAMQueueEntry object.
 
- 
doDrainvoid doDrain(List<BucketCache.RAMQueueEntry> entries, ByteBuffer metaBuff) throws InterruptedException Flush the entries in ramCache to IOEngine and add bucket entry to backingMap. Process all that are passed in even if failure being sure to remove from ramCache else we'll never undo the references and we'll OOME.- Parameters:
- entries- Presumes list passed in here will be processed by this invocation only. No interference expected.
- Throws:
- InterruptedException
 
- 
getRAMQueueEntriesstatic List<BucketCache.RAMQueueEntry> getRAMQueueEntries(BlockingQueue<BucketCache.RAMQueueEntry> q, List<BucketCache.RAMQueueEntry> receptacle) throws InterruptedException Blocks until elements available inqthen tries to grab as many as possible before returning.- Parameters:
- receptacle- Where to stash the elements taken from queue. We clear before we use it just in case.
- q- The queue to take from.
- Returns:
- receptacleladen with elements taken from the queue or empty if none found.
- Throws:
- InterruptedException
 
- 
persistToFile- Throws:
- IOException
- See Also:
 
- 
isCachePersistent
- 
getRegionCachedInfo
- 
retrieveFromFile- Throws:
- IOException
- See Also:
 
- 
updateRegionSizeMapWhileRetrievingFromFile
- 
dumpPrefetchList
- 
deleteFileOnCloseCreate an input stream that deletes the file after reading it. Use in try-with-resources to avoid this pattern where an exception thrown from a finally block may mask earlier exceptions:File f = ... try (FileInputStream fis = new FileInputStream(f)) { // use the input stream } finally { if (!f.delete()) throw new IOException("failed to delete"); }- Parameters:
- file- the file to read and delete
- Returns:
- a FileInputStream for the given file
- Throws:
- IOException- if there is a problem creating the stream
 
- 
verifyCapacityAndClassesprivate void verifyCapacityAndClasses(long capacitySize, String ioclass, String mapclass) throws IOException - Throws:
- IOException
 
- 
parsePBprivate void parsePB(org.apache.hadoop.hbase.shaded.protobuf.generated.BucketCacheProtos.BucketCacheEntry proto) throws IOException - Throws:
- IOException
 
- 
checkIOErrorIsToleratedCheck whether we tolerate IO error this time. If the duration of IOEngine throwing errors exceeds ioErrorsDurationTimeTolerated, we will disable the cache
- 
disableCacheUsed to shut down the cache -or- turn it off in the case of something broken.
- 
join- Throws:
- InterruptedException
 
- 
shutdownDescription copied from interface:BlockCacheShutdown the cache.- Specified by:
- shutdownin interface- BlockCache
 
- 
finalizeNeeded mostly for UTs that might run in the same VM and create different BucketCache instances on different UT methods.
- 
getStatsDescription copied from interface:BlockCacheGet the statistics for this block cache.- Specified by:
- getStatsin interface- BlockCache
 
- 
getAllocator
- 
heapSizeDescription copied from interface:HeapSizeReturn the approximate 'exclusive deep size' of implementing object. Includes count of payload and hosting object sizings.
- 
sizeDescription copied from interface:BlockCacheReturns the total size of the block cache, in bytes.- Specified by:
- sizein interface- BlockCache
- Returns:
- size of cache, in bytes
 
- 
getCurrentDataSizeDescription copied from interface:BlockCacheReturns the occupied size of data blocks, in bytes.- Specified by:
- getCurrentDataSizein interface- BlockCache
- Returns:
- occupied space in cache, in bytes
 
- 
getFreeSizeDescription copied from interface:BlockCacheReturns the free size of the block cache, in bytes.- Specified by:
- getFreeSizein interface- BlockCache
- Returns:
- free space in cache, in bytes
 
- 
getBlockCountDescription copied from interface:BlockCacheReturns the number of blocks currently cached in the block cache.- Specified by:
- getBlockCountin interface- BlockCache
- Returns:
- number of blocks in the cache
 
- 
getDataBlockCountDescription copied from interface:BlockCacheReturns the number of data blocks currently cached in the block cache.- Specified by:
- getDataBlockCountin interface- BlockCache
- Returns:
- number of blocks in the cache
 
- 
getCurrentSizeDescription copied from interface:BlockCacheReturns the occupied size of the block cache, in bytes.- Specified by:
- getCurrentSizein interface- BlockCache
- Returns:
- occupied space in cache, in bytes
 
- 
getAlgorithm
- 
evictBlocksByHfileNameEvicts all blocks for a specific HFile.This is used for evict-on-close to remove all blocks of a specific HFile. - Specified by:
- evictBlocksByHfileNamein interface- BlockCache
- Returns:
- the number of blocks evicted
 
- 
getAllCacheKeysForFile
- 
stopWriterThreadsOnly used in test- Throws:
- InterruptedException
 
- 
iteratorDescription copied from interface:BlockCacheReturns Iterator over the blocks in the cache.- Specified by:
- iteratorin interface- BlockCache
- Specified by:
- iteratorin interface- Iterable<CachedBlock>
 
- 
getBlockCachesDescription copied from interface:BlockCacheReturns The list of sub blockcaches that make up this one; returns null if no sub caches.- Specified by:
- getBlockCachesin interface- BlockCache
 
- 
getRpcRefCount
- 
getAcceptableFactorfloat getAcceptableFactor()
- 
getMinFactorfloat getMinFactor()
- 
getExtraFreeFactorfloat getExtraFreeFactor()
- 
getSingleFactorfloat getSingleFactor()
- 
getMultiFactorfloat getMultiFactor()
- 
getMemoryFactorfloat getMemoryFactor()
- 
getPersistencePath
- 
getBackingMap
- 
getBackingMapValidated
- 
getFullyCachedFilesDescription copied from interface:BlockCacheReturns an Optional containing the map of files that have been fully cached (all its blocks are present in the cache. This method may not be overridden by all implementing classes. In such cases, the returned Optional will be empty.- Specified by:
- getFullyCachedFilesin interface- BlockCache
- Returns:
- empty optional if this method is not supported, otherwise the returned optional contains a map of all files that have been fully cached.
 
- 
getBucketCacheFromCacheConfig
- 
notifyFileCachingCompletedpublic void notifyFileCachingCompleted(org.apache.hadoop.fs.Path fileName, int totalBlockCount, int dataBlockCount, long size) Description copied from interface:BlockCacheNotifies the cache implementation that the given file has been fully cached (all its blocks made into the cache).- Specified by:
- notifyFileCachingCompletedin interface- BlockCache
- Parameters:
- fileName- the file that has been completely cached.
 
- 
notifyFileBlockEvictedDescription copied from interface:BlockCacheNotifies the cache implementation that the given file had a block evicted- Specified by:
- notifyFileBlockEvictedin interface- BlockCache
- Parameters:
- fileName- the file had a block evicted.
 
- 
blockFitsIntoTheCacheDescription copied from interface:BlockCacheChecks whether there's enough space left in the cache to accommodate the passed block. This method may not be overridden by all implementing classes. In such cases, the returned Optional will be empty. For subclasses implementing this logic, the returned Optional would contain the boolean value reflecting if the passed block fits into the remaining cache space available.- Specified by:
- blockFitsIntoTheCachein interface- BlockCache
- Parameters:
- block- the block we want to check if fits into the cache.
- Returns:
- empty optional if this method is not supported, otherwise the returned optional contains the boolean value informing if the block fits into the cache available space.
 
- 
shouldCacheFileDescription copied from interface:BlockCacheChecks whether blocks for the passed file should be cached or not. This method may not be overridden by all implementing classes. In such cases, the returned Optional will be empty. For subclasses implementing this logic, the returned Optional would contain the boolean value reflecting if the passed file should indeed be cached.- Specified by:
- shouldCacheFilein interface- BlockCache
- Parameters:
- fileName- to check if it should be cached.
- Returns:
- empty optional if this method is not supported, otherwise the returned optional contains the boolean value informing if the file should be cached.
 
- 
isAlreadyCachedDescription copied from interface:BlockCacheChecks whether the block for the passed key is already cached. This method may not be overridden by all implementing classes. In such cases, the returned Optional will be empty. For subclasses implementing this logic, the returned Optional would contain the boolean value reflecting if the block for the passed key is already cached or not.- Specified by:
- isAlreadyCachedin interface- BlockCache
- Parameters:
- key- for the block we want to check if it's already in the cache.
- Returns:
- empty optional if this method is not supported, otherwise the returned optional contains the boolean value informing if the block is already cached.
 
- 
getBlockSizeDescription copied from interface:BlockCacheReturns an Optional containing the size of the block related to the passed key. If the block is not in the cache, returned optional will be empty. Also, this method may not be overridden by all implementing classes. In such cases, the returned Optional will be empty.- Specified by:
- getBlockSizein interface- BlockCache
- Parameters:
- key- for the block we want to check if it's already in the cache.
- Returns:
- empty optional if this method is not supported, otherwise the returned optional contains the boolean value informing if the block is already cached.
 
- 
removeFileFromPrefetch
- 
fileCacheCompleted
 
-