Uses of Class
org.apache.hadoop.hbase.io.ByteBuffAllocator
Packages that use 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
Subclasses of ByteBuffAllocator in org.apache.hadoop.hbase.ioModifier and TypeClassDescriptionclass
A ByteBuffAllocator that rewrite the bytebuffers right after released.Fields in org.apache.hadoop.hbase.io declared as ByteBuffAllocatorModifier and TypeFieldDescriptionprivate final ByteBuffAllocator
ByteBufferListOutputStream.allocator
static final ByteBuffAllocator
ByteBuffAllocator.HEAP
Methods in org.apache.hadoop.hbase.io that return ByteBuffAllocatorModifier 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.Methods in org.apache.hadoop.hbase.io with parameters of type ByteBuffAllocatorModifier and TypeMethodDescriptionstatic long
ByteBuffAllocator.getHeapAllocationBytes
(ByteBuffAllocator... allocators) static double
ByteBuffAllocator.getHeapAllocationRatio
(ByteBuffAllocator... allocators) Constructors in org.apache.hadoop.hbase.io with parameters of type ByteBuffAllocator -
Uses of ByteBuffAllocator in org.apache.hadoop.hbase.io.hfile
Fields in org.apache.hadoop.hbase.io.hfile declared as ByteBuffAllocatorModifier 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
Methods in org.apache.hadoop.hbase.io.hfile that return ByteBuffAllocatorModifier and TypeMethodDescriptionCacheConfig.getByteBuffAllocator()
HFileBlock.getByteBuffAllocator()
Methods in org.apache.hadoop.hbase.io.hfile with parameters of type ByteBuffAllocatorModifier 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) Constructors in org.apache.hadoop.hbase.io.hfile with parameters of type ByteBuffAllocatorModifierConstructorDescriptionCacheConfig
(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
Fields in org.apache.hadoop.hbase.io.hfile.bucket declared as ByteBuffAllocatorMethods in org.apache.hadoop.hbase.io.hfile.bucket that return ByteBuffAllocatorModifier and TypeMethodDescriptionprivate ByteBuffAllocator
BucketCache.RAMQueueEntry.getByteBuffAllocator()
Constructors in org.apache.hadoop.hbase.io.hfile.bucket with parameters of type ByteBuffAllocatorModifierConstructorDescription(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
Fields in org.apache.hadoop.hbase.ipc declared as ByteBuffAllocatorModifier and TypeFieldDescriptionprotected final ByteBuffAllocator
RpcServer.bbAllocator
protected final ByteBuffAllocator
ServerCall.bbAllocator
Methods in org.apache.hadoop.hbase.ipc that return ByteBuffAllocatorModifier and TypeMethodDescriptionRpcServer.getByteBuffAllocator()
RpcServerInterface.getByteBuffAllocator()
Allocator to allocate/free the ByteBuffers, those ByteBuffers can be on-heap or off-heap.Methods in org.apache.hadoop.hbase.ipc with parameters of type ByteBuffAllocatorModifier 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
.Constructors in org.apache.hadoop.hbase.ipc with parameters of type ByteBuffAllocatorModifierConstructorDescription(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
Fields in org.apache.hadoop.hbase.regionserver declared as ByteBuffAllocatorModifier and TypeFieldDescriptionprivate final ByteBuffAllocator
MetricsRegionServerWrapperImpl.allocator
private static ByteBuffAllocator
RegionServicesForStores.ALLOCATOR_FOR_TEST
Methods in org.apache.hadoop.hbase.regionserver that return ByteBuffAllocatorModifier and TypeMethodDescriptionprivate static ByteBuffAllocator
RegionServicesForStores.getAllocatorForTest()
RegionServicesForStores.getByteBuffAllocator()