| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.io | |
| org.apache.hadoop.hbase.io.hfile | Provides implementations of  HFileand HFileBlockCache. | 
| org.apache.hadoop.hbase.io.hfile.bucket | Provides  BucketCache, an implementation ofBlockCache. | 
| org.apache.hadoop.hbase.ipc | Tools to help define network clients and servers. | 
| org.apache.hadoop.hbase.regionserver | 
| Modifier and Type | Field and Description | 
|---|---|
| private ByteBuffAllocator | ByteBufferListOutputStream. allocator | 
| static ByteBuffAllocator | ByteBuffAllocator. HEAP | 
| Modifier and Type | Method and Description | 
|---|---|
| static ByteBuffAllocator | ByteBuffAllocator. create(org.apache.hadoop.conf.Configuration conf,
      boolean reservoirEnabled)Initialize an  ByteBuffAllocatorwhich 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 an  ByteBuffAllocatorwhich only allocate ByteBuffer from on-heap, it's
 designed for testing purpose or disabled reservoir case. | 
| Modifier and Type | Method and Description | 
|---|---|
| static long | ByteBuffAllocator. getHeapAllocationBytes(ByteBuffAllocator... allocators) | 
| static double | ByteBuffAllocator. getHeapAllocationRatio(ByteBuffAllocator... allocators) | 
| Constructor and Description | 
|---|
| ByteBufferListOutputStream(ByteBuffAllocator allocator) | 
| Modifier and Type | Field and Description | 
|---|---|
| private ByteBuffAllocator | HFileBlockBuilder. allocator | 
| private ByteBuffAllocator | HFileBlock. allocator | 
| private ByteBuffAllocator | HFileBlock.Writer. allocator | 
| private ByteBuffAllocator | HFileBlock.FSReaderImpl. allocator | 
| private ByteBuffAllocator | CacheConfig. byteBuffAllocator | 
| Modifier and Type | Method and Description | 
|---|---|
| ByteBuffAllocator | CacheConfig. getByteBuffAllocator() | 
| ByteBuffAllocator | HFileBlock. getByteBuffAllocator() | 
| Modifier and Type | Method and Description | 
|---|---|
| (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. | 
| T | CacheableDeserializer. deserialize(ByteBuff b,
           ByteBuffAllocator allocator) | 
| HFileBlock | HFileBlock.BlockDeserializer. deserialize(ByteBuff buf,
           ByteBuffAllocator alloc) | 
| HFileBlockBuilder | HFileBlockBuilder. withByteBuffAllocator(ByteBuffAllocator allocator) | 
| Constructor and Description | 
|---|
| CacheConfig(org.apache.hadoop.conf.Configuration conf,
           ColumnFamilyDescriptor family,
           BlockCache blockCache,
           ByteBuffAllocator byteBuffAllocator)Create a cache configuration using the specified configuration object and
 family descriptor. | 
| ExclusiveMemHFileBlock(BlockType blockType,
                      int onDiskSizeWithoutHeader,
                      int uncompressedSizeWithoutHeader,
                      long prevBlockOffset,
                      ByteBuff buf,
                      boolean fillHeader,
                      long offset,
                      int nextBlockOnDiskSize,
                      int onDiskDataSizeWithHeader,
                      HFileContext fileContext,
                      ByteBuffAllocator alloc) | 
| FSReaderImpl(ReaderContext readerContext,
            HFileContext fileContext,
            ByteBuffAllocator allocator) | 
| 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 new  HFileblock from the given fields. | 
| SharedMemHFileBlock(BlockType blockType,
                   int onDiskSizeWithoutHeader,
                   int uncompressedSizeWithoutHeader,
                   long prevBlockOffset,
                   ByteBuff buf,
                   boolean fillHeader,
                   long offset,
                   int nextBlockOnDiskSize,
                   int onDiskDataSizeWithHeader,
                   HFileContext fileContext,
                   ByteBuffAllocator alloc) | 
| Writer(HFileDataBlockEncoder dataBlockEncoder,
      HFileContext fileContext,
      ByteBuffAllocator allocator) | 
| Modifier and Type | Field and Description | 
|---|---|
| (package private) ByteBuffAllocator | BucketEntry. allocator | 
| Modifier and Type | Method and Description | 
|---|---|
| private ByteBuffAllocator | BucketCache.RAMQueueEntry. getByteBuffAllocator() | 
| Constructor and Description | 
|---|
| BucketEntry(long offset,
           int length,
           long accessCounter,
           boolean inMemory,
           RefCnt refCnt,
           ByteBuffAllocator allocator) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected ByteBuffAllocator | ServerCall. bbAllocator | 
| protected ByteBuffAllocator | RpcServer. bbAllocator | 
| Modifier and Type | Method and Description | 
|---|---|
| ByteBuffAllocator | RpcServerInterface. getByteBuffAllocator()Allocator to allocate/free the ByteBuffers, those ByteBuffers can be on-heap or off-heap. | 
| ByteBuffAllocator | RpcServer. getByteBuffAllocator() | 
| Modifier and Type | Method and Description | 
|---|---|
| ByteBufferListOutputStream | CellBlockBuilder. buildCellBlockStream(Codec codec,
                    org.apache.hadoop.io.compress.CompressionCodec compressor,
                    CellScanner cellScanner,
                    ByteBuffAllocator allocator)Puts CellScanner Cells into a cell block using passed in  codecand/orcompressor. | 
| Constructor and Description | 
|---|
| 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,
               CellScanner cellScanner,
               NettyServerRpcConnection connection,
               long size,
               InetAddress remoteAddress,
               long receiveTime,
               int timeout,
               ByteBuffAllocator bbAllocator,
               CellBlockBuilder cellBlockBuilder,
               RpcServer.CallCleanup reqCleanup) | 
| 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,
          CellScanner cellScanner,
          T connection,
          long size,
          InetAddress remoteAddress,
          long receiveTime,
          int timeout,
          ByteBuffAllocator byteBuffAllocator,
          CellBlockBuilder cellBlockBuilder,
          RpcServer.CallCleanup reqCleanup) | 
| 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,
                CellScanner cellScanner,
                SimpleServerRpcConnection connection,
                long size,
                InetAddress remoteAddress,
                long receiveTime,
                int timeout,
                ByteBuffAllocator bbAllocator,
                CellBlockBuilder cellBlockBuilder,
                RpcServer.CallCleanup reqCleanup,
                SimpleRpcServerResponder responder) | 
| Modifier and Type | Field and Description | 
|---|---|
| private ByteBuffAllocator | MetricsRegionServerWrapperImpl. allocator | 
| private static ByteBuffAllocator | RegionServicesForStores. ALLOCATOR_FOR_TEST | 
| Modifier and Type | Method and Description | 
|---|---|
| private static ByteBuffAllocator | RegionServicesForStores. getAllocatorForTest() | 
| ByteBuffAllocator | RegionServicesForStores. getByteBuffAllocator() | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.