Uses of Class
org.apache.hadoop.hbase.nio.ByteBuff
Packages that use org.apache.hadoop.hbase.nio.ByteBuff
Package
Description
Provides implementations of
HFile and HFile
BlockCache.-
Uses of org.apache.hadoop.hbase.nio.ByteBuff in org.apache.hadoop.hbase.codec
Fields in org.apache.hadoop.hbase.codec declared as org.apache.hadoop.hbase.nio.ByteBuff in inModifier and TypeFieldDescriptionprotected final org.apache.hadoop.hbase.nio.ByteBuffKeyValueCodec.ByteBuffKeyValueDecoder.bufMethods in org.apache.hadoop.hbase.codec with parameters of type org.apache.hadoop.hbase.nio.ByteBuff in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.codec.Codec.DecoderCellCodec.getDecoder(org.apache.hadoop.hbase.nio.ByteBuff buf) org.apache.hadoop.hbase.codec.Codec.DecoderCellCodecWithTags.getDecoder(org.apache.hadoop.hbase.nio.ByteBuff buf) org.apache.hadoop.hbase.codec.Codec.DecoderCodec.getDecoder(org.apache.hadoop.hbase.nio.ByteBuff buf) org.apache.hadoop.hbase.codec.Codec.DecoderKeyValueCodec.getDecoder(org.apache.hadoop.hbase.nio.ByteBuff buf) org.apache.hadoop.hbase.codec.Codec.DecoderKeyValueCodecWithTags.getDecoder(org.apache.hadoop.hbase.nio.ByteBuff buf) org.apache.hadoop.hbase.codec.Codec.DecoderMessageCodec.getDecoder(org.apache.hadoop.hbase.nio.ByteBuff buf) Constructors in org.apache.hadoop.hbase.codec with parameters of type org.apache.hadoop.hbase.nio.ByteBuff in inModifierConstructorDescriptionByteBuffKeyValueDecoder(org.apache.hadoop.hbase.nio.ByteBuff buf) ByteBuffKeyValueDecoder(org.apache.hadoop.hbase.nio.ByteBuff buf) -
Uses of org.apache.hadoop.hbase.nio.ByteBuff in org.apache.hadoop.hbase.io
Methods in org.apache.hadoop.hbase.io that return org.apache.hadoop.hbase.nio.ByteBuff in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.nio.ByteBuffByteBuffAllocator.allocate(int size) Allocate size bytes from the ByteBufAllocator, Note to call therelease()if no need any more, otherwise the memory leak happen in NIO ByteBuffer pool.Methods in org.apache.hadoop.hbase.io with parameters of type org.apache.hadoop.hbase.nio.ByteBuff in inModifier and TypeMethodDescriptionvoidByteArrayOutputStream.toByteBuff(org.apache.hadoop.hbase.nio.ByteBuff buff) intTagCompressionContext.uncompressTags(org.apache.hadoop.hbase.nio.ByteBuff src, byte[] dest, int offset, int length) Uncompress tags from the input ByteBuffer and writes to the destination array.Constructors in org.apache.hadoop.hbase.io with parameters of type org.apache.hadoop.hbase.nio.ByteBuff in inModifierConstructorDescriptionByteBuffInputStream(org.apache.hadoop.hbase.nio.ByteBuff buf) -
Uses of org.apache.hadoop.hbase.nio.ByteBuff in org.apache.hadoop.hbase.io.compress
Methods in org.apache.hadoop.hbase.io.compress with parameters of type org.apache.hadoop.hbase.nio.ByteBuff in inModifier and TypeMethodDescriptionbooleanByteBuffDecompressor.canDecompress(org.apache.hadoop.hbase.nio.ByteBuff output, org.apache.hadoop.hbase.nio.ByteBuff input) Signals of these two particularByteBuffs are compatible with this decompressor.static intBlockDecompressorHelper.decompress(org.apache.hadoop.hbase.nio.ByteBuff output, org.apache.hadoop.hbase.nio.ByteBuff input, int inputSize, org.apache.hadoop.hbase.io.compress.BlockDecompressorHelper.RawDecompressor rawDecompressor) intBlockDecompressorHelper.RawDecompressor.decompress(org.apache.hadoop.hbase.nio.ByteBuff output, org.apache.hadoop.hbase.nio.ByteBuff input, int inputLen) intByteBuffDecompressor.decompress(org.apache.hadoop.hbase.nio.ByteBuff output, org.apache.hadoop.hbase.nio.ByteBuff input, int inputLen) Fills the ouput buffer with uncompressed data. -
Uses of org.apache.hadoop.hbase.nio.ByteBuff in org.apache.hadoop.hbase.io.encoding
Methods in org.apache.hadoop.hbase.io.encoding with parameters of type org.apache.hadoop.hbase.nio.ByteBuff in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ExtendedCellCopyKeyDataBlockEncoder.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block) org.apache.hadoop.hbase.ExtendedCellDataBlockEncoder.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block) Return first key in block as a cell.org.apache.hadoop.hbase.ExtendedCellDiffKeyDeltaEncoder.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block) org.apache.hadoop.hbase.ExtendedCellFastDiffDeltaEncoder.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block) org.apache.hadoop.hbase.ExtendedCellPrefixKeyDeltaEncoder.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block) org.apache.hadoop.hbase.ExtendedCellRowIndexCodecV1.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block) voidHFileBlockDecodingContext.prepareDecoding(int onDiskSizeWithoutHeader, int uncompressedSizeWithoutHeader, org.apache.hadoop.hbase.nio.ByteBuff blockBufferWithoutHeader, org.apache.hadoop.hbase.nio.ByteBuff onDiskBlock) Perform all actions that need to be done before the encoder's real decoding process.voidHFileBlockDefaultDecodingContext.prepareDecoding(int onDiskSizeWithoutHeader, int uncompressedSizeWithoutHeader, org.apache.hadoop.hbase.nio.ByteBuff blockBufferWithoutHeader, org.apache.hadoop.hbase.nio.ByteBuff onDiskBlock) voidDataBlockEncoder.EncodedSeeker.setCurrentBuffer(org.apache.hadoop.hbase.nio.ByteBuff buffer) Set on which buffer there will be done seeking.voidRowIndexSeekerV1.setCurrentBuffer(org.apache.hadoop.hbase.nio.ByteBuff buffer) -
Uses of org.apache.hadoop.hbase.nio.ByteBuff in org.apache.hadoop.hbase.io.hfile
Methods in org.apache.hadoop.hbase.io.hfile that return org.apache.hadoop.hbase.nio.ByteBuff in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.nio.ByteBuffHFileBlock.getBufferReadOnly()Returns a read-only duplicate of the buffer this block stores internally ready to be read.org.apache.hadoop.hbase.nio.ByteBuffHFileBlock.getBufferWithoutHeader()Returns a buffer that does not include the header and checksum.Methods in org.apache.hadoop.hbase.io.hfile with parameters of type org.apache.hadoop.hbase.nio.ByteBuff in inModifier and TypeMethodDescriptionbooleanCompoundBloomFilter.contains(byte[] key, int keyOffset, int keyLength, org.apache.hadoop.hbase.nio.ByteBuff bloom) booleanCompoundBloomFilter.contains(org.apache.hadoop.hbase.Cell keyCell, org.apache.hadoop.hbase.nio.ByteBuff bloom, org.apache.hadoop.hbase.regionserver.BloomType type) TCacheableDeserializer.deserialize(org.apache.hadoop.hbase.nio.ByteBuff b, org.apache.hadoop.hbase.io.ByteBuffAllocator allocator) org.apache.hadoop.hbase.io.hfile.HFileBlockHFileBlock.BlockDeserializer.deserialize(org.apache.hadoop.hbase.nio.ByteBuff buf, org.apache.hadoop.hbase.io.ByteBuffAllocator alloc) static intHFileBlockIndex.BlockIndexReader.locateNonRootIndexEntry(org.apache.hadoop.hbase.nio.ByteBuff nonRootBlock, org.apache.hadoop.hbase.Cell key, CellComparator comparator) Search for one key using the secondary index in a non-root block.static org.apache.hadoop.hbase.io.hfile.BlockTypeBlockType.read(org.apache.hadoop.hbase.nio.ByteBuff buf) org.apache.hadoop.hbase.io.hfile.HFileBlockBuilderHFileBlockBuilder.withByteBuff(org.apache.hadoop.hbase.nio.ByteBuff buf) voidBlockType.write(org.apache.hadoop.hbase.nio.ByteBuff buf) Constructors in org.apache.hadoop.hbase.io.hfile with parameters of type org.apache.hadoop.hbase.nio.ByteBuff in inModifierConstructorDescriptionHFileBlock(org.apache.hadoop.hbase.io.hfile.BlockType blockType, int onDiskSizeWithoutHeader, int uncompressedSizeWithoutHeader, long prevBlockOffset, org.apache.hadoop.hbase.nio.ByteBuff buf, boolean fillHeader, long offset, int nextBlockOnDiskSize, int onDiskDataSizeWithHeader, org.apache.hadoop.hbase.io.hfile.HFileContext fileContext, org.apache.hadoop.hbase.io.ByteBuffAllocator allocator) Creates a newHFileblock from the given fields. -
Uses of org.apache.hadoop.hbase.nio.ByteBuff in org.apache.hadoop.hbase.io.util
Methods in org.apache.hadoop.hbase.io.util with parameters of type org.apache.hadoop.hbase.nio.ByteBuff in inModifier and TypeMethodDescriptionstatic booleanBlockIOUtils.preadWithExtra(org.apache.hadoop.hbase.nio.ByteBuff buff, org.apache.hadoop.fs.FSDataInputStream dis, long position, int necessaryLen, int extraLen) Read from an input stream at leastnecessaryLenand if possible,extraLenalso if available.static booleanBlockIOUtils.preadWithExtra(org.apache.hadoop.hbase.nio.ByteBuff buff, org.apache.hadoop.fs.FSDataInputStream dis, long position, int necessaryLen, int extraLen, boolean readAllBytes) Read from an input stream at leastnecessaryLenand if possible,extraLenalso if available.static voidBlockIOUtils.readFully(org.apache.hadoop.hbase.nio.ByteBuff buf, org.apache.hadoop.fs.FSDataInputStream dis, int length) Read length bytes into ByteBuffers directly.static voidBlockIOUtils.readFullyWithHeapBuffer(InputStream in, org.apache.hadoop.hbase.nio.ByteBuff out, int length) Copying bytes from InputStream toByteBuffby using an temporary heap byte[] (default size is 1024 now).static intStreamUtils.readRawVarint32(org.apache.hadoop.hbase.nio.ByteBuff input) static booleanBlockIOUtils.readWithExtra(org.apache.hadoop.hbase.nio.ByteBuff buf, org.apache.hadoop.fs.FSDataInputStream dis, int necessaryLen, int extraLen) Read bytes into ByteBuffers directly, those buffers either contains the extraLen bytes or only contains necessaryLen bytes, which depends on how much bytes do the last time we read. -
Uses of org.apache.hadoop.hbase.nio.ByteBuff in org.apache.hadoop.hbase.nio
Subclasses of org.apache.hadoop.hbase.nio.ByteBuff in in org.apache.hadoop.hbase.nioModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.nio.MultiByteBuffProvides a unified view of all the underlying ByteBuffers and will look as if a bigger sequential buffer.classorg.apache.hadoop.hbase.nio.SingleByteBuffAn implementation of ByteBuff where a single BB backs the BBI.Methods in org.apache.hadoop.hbase.nio that return org.apache.hadoop.hbase.nio.ByteBuff in inModifier and TypeMethodDescriptionabstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.duplicate()Returns an ByteBuff which is a duplicate version of this ByteBuff.abstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.limit(int limit) Marks the limit of this ByteBuffabstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.mark()Marks the current position of the ByteBuffabstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.moveBack(int len) Jumps back the current position of this ByteBuff by specified length.abstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.position(int position) Sets this ByteBuff's position to the given value.abstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.put(byte b) Writes a byte to this ByteBuff at the current position and increments the positionabstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.put(byte[] src) Copies from the given byte[] to this ByteBuffabstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.put(byte[] src, int offset, int length) Copies from the given byte[] to this ByteBuffabstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.put(int index, byte b) Writes a byte to this ByteBuff at the given indexabstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.put(int offset, org.apache.hadoop.hbase.nio.ByteBuff src, int srcOffset, int length) Copies the contents from the src ByteBuff to this ByteBuff.abstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.putInt(int value) Writes an int to this ByteBuff at its current position.abstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.putLong(long value) Writes a long to this ByteBuff at its current position.abstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.reset()Similar toByteBuffer.reset(), ensures that this ByteBuff is reset back to last marked position.abstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.rewind()Rewinds this ByteBuff and the position is set to 0abstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.skip(int len) Jumps the current position of this ByteBuff by specified length.abstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.slice()Returns an ByteBuff which is a sliced version of this ByteBuff.org.apache.hadoop.hbase.nio.ByteBuffByteBuff.touch()Calling this method in strategic locations where ByteBuffs are referenced may help diagnose potential buffer leaks.org.apache.hadoop.hbase.nio.ByteBuffByteBuff.touch(Object hint) static org.apache.hadoop.hbase.nio.ByteBuffByteBuff.wrap(ByteBuffer buffer) static org.apache.hadoop.hbase.nio.ByteBuffByteBuff.wrap(ByteBuffer[] buffers) static org.apache.hadoop.hbase.nio.ByteBuffByteBuff.wrap(ByteBuffer[] buffers, org.apache.hadoop.hbase.io.ByteBuffAllocator.Recycler recycler) static org.apache.hadoop.hbase.nio.ByteBuffByteBuff.wrap(ByteBuffer[] buffers, org.apache.hadoop.hbase.nio.RefCnt refCnt) In theory, the upstream should never construct an ByteBuff by passing an given refCnt, so please don't use this public method in other place.static org.apache.hadoop.hbase.nio.ByteBuffByteBuff.wrap(List<ByteBuffer> buffers) static org.apache.hadoop.hbase.nio.ByteBuffByteBuff.wrap(List<ByteBuffer> buffers, org.apache.hadoop.hbase.io.ByteBuffAllocator.Recycler recycler) Methods in org.apache.hadoop.hbase.nio with parameters of type org.apache.hadoop.hbase.nio.ByteBuff in inModifier and TypeMethodDescriptionstatic intByteBuff.compareTo(org.apache.hadoop.hbase.nio.ByteBuff buf1, int o1, int len1, org.apache.hadoop.hbase.nio.ByteBuff buf2, int o2, int len2) Compares two ByteBuffsabstract org.apache.hadoop.hbase.nio.ByteBuffByteBuff.put(int offset, org.apache.hadoop.hbase.nio.ByteBuff src, int srcOffset, int length) Copies the contents from the src ByteBuff to this ByteBuff.org.apache.hadoop.hbase.nio.MultiByteBuffMultiByteBuff.put(int destOffset, org.apache.hadoop.hbase.nio.ByteBuff src, int srcOffset, int length) Copies from a src BB to this MBB.org.apache.hadoop.hbase.nio.SingleByteBuffSingleByteBuff.put(int offset, org.apache.hadoop.hbase.nio.ByteBuff src, int srcOffset, int length) static intByteBuff.readCompressedInt(org.apache.hadoop.hbase.nio.ByteBuff buf) Read integer from ByteBuff coded in 7 bits and increment position.static longByteBuff.readLong(org.apache.hadoop.hbase.nio.ByteBuff in, int fitInBytes) Read long which was written to fitInBytes bytes and increment position. -
Uses of org.apache.hadoop.hbase.nio.ByteBuff in org.apache.hadoop.hbase.regionserver.wal
Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type org.apache.hadoop.hbase.nio.ByteBuff in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.codec.Codec.DecoderWALCellCodec.getDecoder(org.apache.hadoop.hbase.nio.ByteBuff buf) -
Uses of org.apache.hadoop.hbase.nio.ByteBuff in org.apache.hadoop.hbase.util
Methods in org.apache.hadoop.hbase.util with parameters of type org.apache.hadoop.hbase.nio.ByteBuff in inModifier and TypeMethodDescriptionbooleanBloomFilter.contains(byte[] buf, int offset, int length, org.apache.hadoop.hbase.nio.ByteBuff bloom) Check if the specified key is contained in the bloom filter.booleanBloomFilter.contains(org.apache.hadoop.hbase.Cell keyCell, org.apache.hadoop.hbase.nio.ByteBuff bloom, org.apache.hadoop.hbase.regionserver.BloomType type) Check if the specified key is contained in the bloom filter.static booleanBloomFilterUtil.contains(byte[] buf, int offset, int length, org.apache.hadoop.hbase.nio.ByteBuff bloomBuf, int bloomOffset, int bloomSize, org.apache.hadoop.hbase.util.Hash hash, int hashCount) static booleanBloomFilterUtil.contains(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.nio.ByteBuff bloomBuf, int bloomOffset, int bloomSize, org.apache.hadoop.hbase.util.Hash hash, int hashCount, org.apache.hadoop.hbase.regionserver.BloomType type) intByteBufferArray.read(long offset, org.apache.hadoop.hbase.nio.ByteBuff dst) Transfers bytes from this buffers array into the given destinationByteBuffstatic longByteBufferUtils.readVLong(org.apache.hadoop.hbase.nio.ByteBuff buf) Similar toWritableUtils.readVLong(java.io.DataInput)but reads from aByteBuff.intByteBufferArray.write(long offset, org.apache.hadoop.hbase.nio.ByteBuff src) Transfers bytes from the given sourceByteBuffinto this buffer array