Uses of Class
org.apache.hadoop.hbase.io.ByteBuffAllocator
Package
Description
Provides implementations of
HFile
and HFile
BlockCache
.Provides
BucketCache
, an implementation of
BlockCache
.Tools to help define network clients and servers.
-
Uses of ByteBuffAllocator in org.apache.hadoop.hbase.io
Modifier and TypeClassDescriptionclass
A ByteBuffAllocator that rewrite the bytebuffers right after released.Modifier and TypeFieldDescriptionprivate final ByteBuffAllocator
ByteBufferListOutputStream.allocator
static final ByteBuffAllocator
ByteBuffAllocator.HEAP
Modifier and TypeMethodDescriptionstatic ByteBuffAllocator
ByteBuffAllocator.create
(org.apache.hadoop.conf.Configuration conf, boolean reservoirEnabled) Initialize anByteBuffAllocator
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.private static ByteBuffAllocator
ByteBuffAllocator.createOnHeap()
Initialize anByteBuffAllocator
which only allocate ByteBuffer from on-heap, it's designed for testing purpose or disabled reservoir case.Modifier and TypeMethodDescriptionstatic long
ByteBuffAllocator.getHeapAllocationBytes
(ByteBuffAllocator... allocators) static double
ByteBuffAllocator.getHeapAllocationRatio
(ByteBuffAllocator... allocators) -
Uses of ByteBuffAllocator in org.apache.hadoop.hbase.io.hfile
Modifier and TypeFieldDescriptionprivate ByteBuffAllocator
HFileBlock.allocator
private final ByteBuffAllocator
HFileBlock.FSReaderImpl.allocator
private final ByteBuffAllocator
HFileBlock.Writer.allocator
private ByteBuffAllocator
HFileBlockBuilder.allocator
private final ByteBuffAllocator
CacheConfig.byteBuffAllocator
Modifier and TypeMethodDescriptionCacheConfig.getByteBuffAllocator()
HFileBlock.getByteBuffAllocator()
Modifier and TypeMethodDescription(package private) static HFileBlock
HFileBlock.createFromBuff
(ByteBuff buf, boolean usesHBaseChecksum, long offset, int nextBlockOnDiskSize, HFileContext fileContext, ByteBuffAllocator allocator) Creates a block from an existing buffer starting with a header.CacheableDeserializer.deserialize
(ByteBuff b, ByteBuffAllocator allocator) HFileBlock.BlockDeserializer.deserialize
(ByteBuff buf, ByteBuffAllocator alloc) HFileBlockBuilder.withByteBuffAllocator
(ByteBuffAllocator allocator) ModifierConstructorDescriptionCacheConfig
(org.apache.hadoop.conf.Configuration conf, ColumnFamilyDescriptor family, BlockCache blockCache, ByteBuffAllocator byteBuffAllocator) Create a cache configuration using the specified configuration object and family descriptor.(package private)
ExclusiveMemHFileBlock
(BlockType blockType, int onDiskSizeWithoutHeader, int uncompressedSizeWithoutHeader, long prevBlockOffset, ByteBuff buf, boolean fillHeader, long offset, int nextBlockOnDiskSize, int onDiskDataSizeWithHeader, HFileContext fileContext, ByteBuffAllocator alloc) (package private)
FSReaderImpl
(ReaderContext readerContext, HFileContext fileContext, ByteBuffAllocator allocator, org.apache.hadoop.conf.Configuration conf) HFileBlock
(BlockType blockType, int onDiskSizeWithoutHeader, int uncompressedSizeWithoutHeader, long prevBlockOffset, ByteBuff buf, boolean fillHeader, long offset, int nextBlockOnDiskSize, int onDiskDataSizeWithHeader, HFileContext fileContext, ByteBuffAllocator allocator) Creates a newHFile
block from the given fields.(package private)
SharedMemHFileBlock
(BlockType blockType, int onDiskSizeWithoutHeader, int uncompressedSizeWithoutHeader, long prevBlockOffset, ByteBuff buf, boolean fillHeader, long offset, int nextBlockOnDiskSize, int onDiskDataSizeWithHeader, HFileContext fileContext, ByteBuffAllocator alloc) Writer
(org.apache.hadoop.conf.Configuration conf, HFileDataBlockEncoder dataBlockEncoder, HFileContext fileContext, ByteBuffAllocator allocator, int maxSizeUnCompressed) -
Uses of ByteBuffAllocator in org.apache.hadoop.hbase.io.hfile.bucket
Modifier and TypeMethodDescriptionprivate ByteBuffAllocator
BucketCache.RAMQueueEntry.getByteBuffAllocator()
ModifierConstructorDescription(package private)
BucketEntry
(long offset, int length, int onDiskSizeWithHeader, long accessCounter, boolean inMemory, Function<BucketEntry, ByteBuffAllocator.Recycler> createRecycler, ByteBuffAllocator allocator) (package private)
BucketEntry
(long offset, int length, int onDiskSizeWithHeader, long accessCounter, long cachedTime, boolean inMemory, Function<BucketEntry, ByteBuffAllocator.Recycler> createRecycler, ByteBuffAllocator allocator) -
Uses of ByteBuffAllocator in org.apache.hadoop.hbase.ipc
Modifier and TypeFieldDescriptionprotected final ByteBuffAllocator
RpcServer.bbAllocator
protected final ByteBuffAllocator
ServerCall.bbAllocator
Modifier and TypeMethodDescriptionRpcServer.getByteBuffAllocator()
RpcServerInterface.getByteBuffAllocator()
Allocator to allocate/free the ByteBuffers, those ByteBuffers can be on-heap or off-heap.Modifier and TypeMethodDescriptionCellBlockBuilder.buildCellBlockStream
(Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor, ExtendedCellScanner cellScanner, ByteBuffAllocator allocator) Puts CellScanner Cells into a cell block using passed incodec
and/orcompressor
.ModifierConstructorDescription(package private)
NettyServerCall
(int id, org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md, org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header, org.apache.hbase.thirdparty.com.google.protobuf.Message param, ExtendedCellScanner cellScanner, NettyServerRpcConnection connection, long size, InetAddress remoteAddress, long receiveTime, int timeout, ByteBuffAllocator bbAllocator, CellBlockBuilder cellBlockBuilder, RpcServer.CallCleanup reqCleanup) (package private)
ServerCall
(int id, org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md, org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header, org.apache.hbase.thirdparty.com.google.protobuf.Message param, ExtendedCellScanner cellScanner, T connection, long size, InetAddress remoteAddress, long receiveTime, int timeout, ByteBuffAllocator byteBuffAllocator, CellBlockBuilder cellBlockBuilder, RpcServer.CallCleanup reqCleanup) (package private)
SimpleServerCall
(int id, org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md, org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header, org.apache.hbase.thirdparty.com.google.protobuf.Message param, ExtendedCellScanner cellScanner, SimpleServerRpcConnection connection, long size, InetAddress remoteAddress, long receiveTime, int timeout, ByteBuffAllocator bbAllocator, CellBlockBuilder cellBlockBuilder, RpcServer.CallCleanup reqCleanup, SimpleRpcServerResponder responder) Deprecated. -
Uses of ByteBuffAllocator in org.apache.hadoop.hbase.regionserver
Modifier and TypeFieldDescriptionprivate final ByteBuffAllocator
MetricsRegionServerWrapperImpl.allocator
private static ByteBuffAllocator
RegionServicesForStores.ALLOCATOR_FOR_TEST
Modifier and TypeMethodDescriptionprivate static ByteBuffAllocator
RegionServicesForStores.getAllocatorForTest()
RegionServicesForStores.getByteBuffAllocator()