Uses of Interface
org.apache.hadoop.hbase.io.ByteBuffAllocator.Recycler
Packages that use ByteBuffAllocator.Recycler
-
Uses of ByteBuffAllocator.Recycler in org.apache.hadoop.hbase.io
Fields in org.apache.hadoop.hbase.io declared as ByteBuffAllocator.Recycler -
Uses of ByteBuffAllocator.Recycler in org.apache.hadoop.hbase.io.hfile.bucket
Methods in org.apache.hadoop.hbase.io.hfile.bucket that return ByteBuffAllocator.RecyclerModifier and TypeMethodDescriptionprivate ByteBuffAllocator.RecyclerBucketCache.createRecycler(BucketEntry bucketEntry) Create theByteBuffAllocator.RecyclerforBucketEntry.refCnt,which would be used asRefCnt.recyclerofHFileBlock#bufreturned fromBucketCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean).Method parameters in org.apache.hadoop.hbase.io.hfile.bucket with type arguments of type ByteBuffAllocator.RecyclerModifier 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) Constructor parameters in org.apache.hadoop.hbase.io.hfile.bucket with type arguments of type ByteBuffAllocator.RecyclerModifierConstructorDescription(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
Fields in org.apache.hadoop.hbase.nio declared as ByteBuffAllocator.RecyclerMethods in org.apache.hadoop.hbase.nio that return ByteBuffAllocator.RecyclerMethods in org.apache.hadoop.hbase.nio with parameters of type ByteBuffAllocator.RecyclerModifier and TypeMethodDescriptionstatic RefCntRefCnt.create(ByteBuffAllocator.Recycler recycler) static ByteBuffByteBuff.wrap(ByteBuffer[] buffers, ByteBuffAllocator.Recycler recycler) static ByteBuffByteBuff.wrap(List<ByteBuffer> buffers, ByteBuffAllocator.Recycler recycler) Constructors in org.apache.hadoop.hbase.nio with parameters of type ByteBuffAllocator.RecyclerModifierConstructorDescriptionMultiByteBuff(ByteBuffAllocator.Recycler recycler, ByteBuffer... items) RefCnt(ByteBuffAllocator.Recycler recycler) SingleByteBuff(ByteBuffAllocator.Recycler recycler, ByteBuffer buf)