Uses of Interface
org.apache.hadoop.hbase.io.ByteBuffAllocator.Recycler
-
Uses of ByteBuffAllocator.Recycler in org.apache.hadoop.hbase.io
-
Uses of ByteBuffAllocator.Recycler in org.apache.hadoop.hbase.io.hfile.bucket
Modifier and TypeMethodDescriptionBucketCache.createRecycler
(BucketEntry bucketEntry) Create theByteBuffAllocator.Recycler
forBucketEntry.refCnt
,which would be used asRefCnt.recycler
ofHFileBlock#buf
returned fromBucketCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean)
.Modifier and TypeMethodDescription(package private) static Pair<ConcurrentHashMap<BlockCacheKey,
BucketEntry>, NavigableSet<BlockCacheKey>> BucketProtoUtils.fromPB
(Map<Integer, String> deserializers, org.apache.hadoop.hbase.shaded.protobuf.generated.BucketCacheProtos.BackingMap backingMap, Function<BucketEntry, ByteBuffAllocator.Recycler> createRecycler) BucketCache.RAMQueueEntry.writeToCache
(IOEngine ioEngine, BucketAllocator alloc, LongAdder realCacheSize, Function<BucketEntry, ByteBuffAllocator.Recycler> createRecycler, ByteBuffer metaBuff) 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.Recycler in org.apache.hadoop.hbase.nio
Modifier and TypeMethodDescriptionstatic RefCnt
RefCnt.create
(ByteBuffAllocator.Recycler recycler) static ByteBuff
ByteBuff.wrap
(ByteBuffer[] buffers, ByteBuffAllocator.Recycler recycler) static ByteBuff
ByteBuff.wrap
(List<ByteBuffer> buffers, ByteBuffAllocator.Recycler recycler) ModifierConstructorDescriptionMultiByteBuff
(ByteBuffAllocator.Recycler recycler, ByteBuffer... items) RefCnt
(ByteBuffAllocator.Recycler recycler) SingleByteBuff
(ByteBuffAllocator.Recycler recycler, ByteBuffer buf)