Uses of Class
org.apache.hadoop.hbase.io.ByteBuffAllocator

Packages that use org.apache.hadoop.hbase.io.ByteBuffAllocator
Package
Description
 
Provides implementations of HFile and HFile BlockCache.
Tools to help define network clients and servers.
 
  • Uses of org.apache.hadoop.hbase.io.ByteBuffAllocator in org.apache.hadoop.hbase.io

    Subclasses of org.apache.hadoop.hbase.io.ByteBuffAllocator in in org.apache.hadoop.hbase.io
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.io.DeallocateRewriteByteBuffAllocator
    A ByteBuffAllocator that rewrite the bytebuffers right after released.
    Fields in org.apache.hadoop.hbase.io declared as org.apache.hadoop.hbase.io.ByteBuffAllocator in in
    Modifier and Type
    Field
    Description
    static final org.apache.hadoop.hbase.io.ByteBuffAllocator
    ByteBuffAllocator.HEAP
     
    Methods in org.apache.hadoop.hbase.io that return org.apache.hadoop.hbase.io.ByteBuffAllocator in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.io.ByteBuffAllocator
    ByteBuffAllocator.create(org.apache.hadoop.conf.Configuration conf, boolean reservoirEnabled)
    Initialize an ByteBuffAllocator which will try to allocate ByteBuffers from off-heap if reservoir is enabled and the reservoir has enough buffers, otherwise the allocator will just allocate the insufficient buffers from on-heap to meet the requirement.
    Methods in org.apache.hadoop.hbase.io with parameters of type org.apache.hadoop.hbase.io.ByteBuffAllocator in in
    Modifier and Type
    Method
    Description
    static long
    ByteBuffAllocator.getHeapAllocationBytes(org.apache.hadoop.hbase.io.ByteBuffAllocator... allocators)
     
    static double
    ByteBuffAllocator.getHeapAllocationRatio(org.apache.hadoop.hbase.io.ByteBuffAllocator... allocators)
     
    Constructors in org.apache.hadoop.hbase.io with parameters of type org.apache.hadoop.hbase.io.ByteBuffAllocator in in
    Modifier
    Constructor
    Description
     
    ByteBufferListOutputStream(org.apache.hadoop.hbase.io.ByteBuffAllocator allocator)
     
  • Uses of org.apache.hadoop.hbase.io.ByteBuffAllocator in org.apache.hadoop.hbase.io.hfile

    Methods in org.apache.hadoop.hbase.io.hfile that return org.apache.hadoop.hbase.io.ByteBuffAllocator in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.io.ByteBuffAllocator
    CacheConfig.getByteBuffAllocator()
     
    org.apache.hadoop.hbase.io.ByteBuffAllocator
    HFileBlock.getByteBuffAllocator()
     
    Methods in org.apache.hadoop.hbase.io.hfile with parameters of type org.apache.hadoop.hbase.io.ByteBuffAllocator in in
    Modifier and Type
    Method
    Description
    T
    CacheableDeserializer.deserialize(org.apache.hadoop.hbase.nio.ByteBuff b, org.apache.hadoop.hbase.io.ByteBuffAllocator allocator)
     
    org.apache.hadoop.hbase.io.hfile.HFileBlock
    HFileBlock.BlockDeserializer.deserialize(org.apache.hadoop.hbase.nio.ByteBuff buf, org.apache.hadoop.hbase.io.ByteBuffAllocator alloc)
     
    org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
    HFileBlockBuilder.withByteBuffAllocator(org.apache.hadoop.hbase.io.ByteBuffAllocator allocator)
     
    Constructors in org.apache.hadoop.hbase.io.hfile with parameters of type org.apache.hadoop.hbase.io.ByteBuffAllocator in in
    Modifier
    Constructor
    Description
     
    CacheConfig(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family, org.apache.hadoop.hbase.io.hfile.BlockCache blockCache, org.apache.hadoop.hbase.io.ByteBuffAllocator byteBuffAllocator)
    Create a cache configuration using the specified configuration object and family descriptor.
     
    HFileBlock(org.apache.hadoop.hbase.io.hfile.BlockType blockType, int onDiskSizeWithoutHeader, int uncompressedSizeWithoutHeader, long prevBlockOffset, org.apache.hadoop.hbase.nio.ByteBuff buf, boolean fillHeader, long offset, int nextBlockOnDiskSize, int onDiskDataSizeWithHeader, org.apache.hadoop.hbase.io.hfile.HFileContext fileContext, org.apache.hadoop.hbase.io.ByteBuffAllocator allocator)
    Creates a new HFile block from the given fields.
  • Uses of org.apache.hadoop.hbase.io.ByteBuffAllocator in org.apache.hadoop.hbase.ipc

    Fields in org.apache.hadoop.hbase.ipc declared as org.apache.hadoop.hbase.io.ByteBuffAllocator in in
    Modifier and Type
    Field
    Description
    protected final org.apache.hadoop.hbase.io.ByteBuffAllocator
    RpcServer.bbAllocator
     
    protected final org.apache.hadoop.hbase.io.ByteBuffAllocator
    ServerCall.bbAllocator
     
    Methods in org.apache.hadoop.hbase.ipc that return org.apache.hadoop.hbase.io.ByteBuffAllocator in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.io.ByteBuffAllocator
    RpcServer.getByteBuffAllocator()
     
    org.apache.hadoop.hbase.io.ByteBuffAllocator
    RpcServerInterface.getByteBuffAllocator()
    Allocator to allocate/free the ByteBuffers, those ByteBuffers can be on-heap or off-heap.
  • Uses of org.apache.hadoop.hbase.io.ByteBuffAllocator in org.apache.hadoop.hbase.regionserver

    Methods in org.apache.hadoop.hbase.regionserver that return org.apache.hadoop.hbase.io.ByteBuffAllocator in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.io.ByteBuffAllocator
    RegionServicesForStores.getByteBuffAllocator()