Uses of Interface
org.apache.hadoop.hbase.io.hfile.Cacheable

Packages that use org.apache.hadoop.hbase.io.hfile.Cacheable
Package
Description
Provides implementations of HFile and HFile BlockCache.
  • Uses of org.apache.hadoop.hbase.io.hfile.Cacheable in org.apache.hadoop.hbase.io.hfile

    Classes in org.apache.hadoop.hbase.io.hfile with type parameters of type org.apache.hadoop.hbase.io.hfile.Cacheable in in
    Modifier and Type
    Interface
    Description
    interface 
    org.apache.hadoop.hbase.io.hfile.CacheableDeserializer<T extends org.apache.hadoop.hbase.io.hfile.Cacheable>
    Interface for a deserializer.
    Classes in org.apache.hadoop.hbase.io.hfile that implement org.apache.hadoop.hbase.io.hfile.Cacheable in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.io.hfile.ExclusiveMemHFileBlock
    The ByteBuffAllocator won't allocate pooled heap ByteBuff now; at the same time, if allocate an off-heap ByteBuff from allocator, then it must be a pooled one.
    class 
    org.apache.hadoop.hbase.io.hfile.HFileBlock
    Cacheable Blocks of an HFile version 2 file.
    class 
    org.apache.hadoop.hbase.io.hfile.SharedMemHFileBlock
    The ByteBuffAllocator won't allocate pooled heap ByteBuff now; at the same time, if allocate an off-heap ByteBuff from allocator, then it must be a pooled one.
    Fields in org.apache.hadoop.hbase.io.hfile with type parameters of type org.apache.hadoop.hbase.io.hfile.Cacheable in in
    Modifier and Type
    Field
    Description
    static final org.apache.hadoop.hbase.io.hfile.CacheableDeserializer<org.apache.hadoop.hbase.io.hfile.Cacheable>
    HFileBlock.BLOCK_DESERIALIZER
    Used deserializing blocks from Cache.
    Methods in org.apache.hadoop.hbase.io.hfile that return org.apache.hadoop.hbase.io.hfile.Cacheable in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.io.hfile.Cacheable
    BlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics)
    Fetch block from cache.
    default org.apache.hadoop.hbase.io.hfile.Cacheable
    BlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics, org.apache.hadoop.hbase.io.hfile.BlockType blockType)
    Fetch block from cache.
    org.apache.hadoop.hbase.io.hfile.Cacheable
    CombinedBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics)
     
    org.apache.hadoop.hbase.io.hfile.Cacheable
    CombinedBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics, org.apache.hadoop.hbase.io.hfile.BlockType blockType)
     
    org.apache.hadoop.hbase.io.hfile.Cacheable
    InclusiveCombinedBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics)
     
    org.apache.hadoop.hbase.io.hfile.Cacheable
    LruAdaptiveBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics)
    Get the buffer of the block with the specified name.
    org.apache.hadoop.hbase.io.hfile.Cacheable
    LruBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics)
    Get the buffer of the block with the specified name.
    org.apache.hadoop.hbase.io.hfile.Cacheable
    MemcachedBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics)
     
    org.apache.hadoop.hbase.io.hfile.Cacheable
    TinyLfuBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, boolean caching, boolean repeat, boolean updateCacheMetrics)
     
    org.apache.hadoop.hbase.io.hfile.Cacheable
    LruCachedBlock.getBuffer()
     
    default org.apache.hadoop.hbase.io.hfile.Cacheable
    Cacheable.retain()
    Increase its reference count, and only when no reference we can free the object's memory.
    Methods in org.apache.hadoop.hbase.io.hfile that return types with arguments of type org.apache.hadoop.hbase.io.hfile.Cacheable in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.io.hfile.CacheableDeserializer<org.apache.hadoop.hbase.io.hfile.Cacheable>
    Cacheable.getDeserializer()
    Returns CacheableDeserializer instance which reconstructs original object from ByteBuffer.
    static org.apache.hadoop.hbase.io.hfile.CacheableDeserializer<org.apache.hadoop.hbase.io.hfile.Cacheable>
    CacheableDeserializerIdManager.getDeserializer(int id)
    Get the cacheable deserializer registered at the given identifier Id.
    org.apache.hadoop.hbase.io.hfile.CacheableDeserializer<org.apache.hadoop.hbase.io.hfile.Cacheable>
    HFileBlock.getDeserializer()
     
    Methods in org.apache.hadoop.hbase.io.hfile with parameters of type org.apache.hadoop.hbase.io.hfile.Cacheable in in
    Modifier and Type
    Method
    Description
    void
    BlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf)
    Add block to cache (defaults to not in-memory).
    void
    BlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf, boolean inMemory)
    Add block to cache.
    default void
    BlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf, boolean inMemory, boolean waitWhenCache)
    Add block to cache.
    void
    CombinedBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf)
     
    void
    CombinedBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf, boolean inMemory)
     
    void
    CombinedBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf, boolean inMemory, boolean waitWhenCache)
     
    void
    InclusiveCombinedBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf, boolean inMemory)
     
    void
    IndexOnlyLruBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf, boolean inMemory)
    Cache only index block with the specified name and buffer
    void
    LruAdaptiveBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf)
    Cache the block with the specified name and buffer.
    void
    LruAdaptiveBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf, boolean inMemory)
    Cache the block with the specified name and buffer.
    void
    LruBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf)
    Cache the block with the specified name and buffer.
    void
    LruBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf, boolean inMemory)
    Cache the block with the specified name and buffer.
    void
    MemcachedBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf)
     
    void
    MemcachedBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf, boolean inMemory)
     
    void
    TinyLfuBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey key, org.apache.hadoop.hbase.io.hfile.Cacheable value)
     
    void
    TinyLfuBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable value, boolean inMemory)
     
    static boolean
    BlockCacheUtil.shouldReplaceExistingCacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCache blockCache, org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.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(org.apache.hadoop.hbase.io.hfile.Cacheable existing, org.apache.hadoop.hbase.io.hfile.Cacheable newBlock, org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey)
    Validate that the existing and newBlock are the same without including the nextBlockMetadata, if not, throw an exception.
    Method parameters in org.apache.hadoop.hbase.io.hfile with type arguments of type org.apache.hadoop.hbase.io.hfile.Cacheable in in
    Modifier and Type
    Method
    Description
    static int
    CacheableDeserializerIdManager.registerDeserializer(org.apache.hadoop.hbase.io.hfile.CacheableDeserializer<org.apache.hadoop.hbase.io.hfile.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.
    Constructors in org.apache.hadoop.hbase.io.hfile with parameters of type org.apache.hadoop.hbase.io.hfile.Cacheable in in
    Modifier
    Constructor
    Description
     
    LruCachedBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf, long accessTime)
     
     
    LruCachedBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable buf, long accessTime, boolean inMemory)