Uses of Class
org.apache.hadoop.hbase.nio.ByteBuff

Packages that use org.apache.hadoop.hbase.nio.ByteBuff
  • 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 in
    Modifier and Type
    Field
    Description
    protected final org.apache.hadoop.hbase.nio.ByteBuff
    KeyValueCodec.ByteBuffKeyValueDecoder.buf
     
    Methods in org.apache.hadoop.hbase.codec with parameters of type org.apache.hadoop.hbase.nio.ByteBuff in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.codec.Codec.Decoder
    CellCodec.getDecoder(org.apache.hadoop.hbase.nio.ByteBuff buf)
     
    org.apache.hadoop.hbase.codec.Codec.Decoder
    CellCodecWithTags.getDecoder(org.apache.hadoop.hbase.nio.ByteBuff buf)
     
    org.apache.hadoop.hbase.codec.Codec.Decoder
    Codec.getDecoder(org.apache.hadoop.hbase.nio.ByteBuff buf)
     
    org.apache.hadoop.hbase.codec.Codec.Decoder
    KeyValueCodec.getDecoder(org.apache.hadoop.hbase.nio.ByteBuff buf)
     
    org.apache.hadoop.hbase.codec.Codec.Decoder
    KeyValueCodecWithTags.getDecoder(org.apache.hadoop.hbase.nio.ByteBuff buf)
     
    org.apache.hadoop.hbase.codec.Codec.Decoder
    MessageCodec.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 in
    Modifier
    Constructor
    Description
     
    ByteBuffKeyValueDecoder(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 in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuffAllocator.allocate(int size)
    Allocate size bytes from the ByteBufAllocator, Note to call the release() 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 in
    Modifier and Type
    Method
    Description
    void
    ByteArrayOutputStream.toByteBuff(org.apache.hadoop.hbase.nio.ByteBuff buff)
     
    int
    TagCompressionContext.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 in
    Modifier
    Constructor
    Description
     
    ByteBuffInputStream(org.apache.hadoop.hbase.nio.ByteBuff buf)
     
  • 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 in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.Cell
    CopyKeyDataBlockEncoder.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block)
     
    org.apache.hadoop.hbase.Cell
    DataBlockEncoder.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block)
    Return first key in block as a cell.
    org.apache.hadoop.hbase.Cell
    DiffKeyDeltaEncoder.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block)
     
    org.apache.hadoop.hbase.Cell
    FastDiffDeltaEncoder.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block)
     
    org.apache.hadoop.hbase.Cell
    PrefixKeyDeltaEncoder.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block)
     
    org.apache.hadoop.hbase.Cell
    RowIndexCodecV1.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block)
     
    void
    HFileBlockDecodingContext.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.
    void
    HFileBlockDefaultDecodingContext.prepareDecoding(int onDiskSizeWithoutHeader, int uncompressedSizeWithoutHeader, org.apache.hadoop.hbase.nio.ByteBuff blockBufferWithoutHeader, org.apache.hadoop.hbase.nio.ByteBuff onDiskBlock)
     
    void
    DataBlockEncoder.EncodedSeeker.setCurrentBuffer(org.apache.hadoop.hbase.nio.ByteBuff buffer)
    Set on which buffer there will be done seeking.
    void
    RowIndexSeekerV1.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 in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.nio.ByteBuff
    HFileBlock.getBufferReadOnly()
    Returns a read-only duplicate of the buffer this block stores internally ready to be read.
    org.apache.hadoop.hbase.nio.ByteBuff
    HFileBlock.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 in
    Modifier and Type
    Method
    Description
    boolean
    CompoundBloomFilter.contains(byte[] key, int keyOffset, int keyLength, org.apache.hadoop.hbase.nio.ByteBuff bloom)
     
    boolean
    CompoundBloomFilter.contains(org.apache.hadoop.hbase.Cell keyCell, org.apache.hadoop.hbase.nio.ByteBuff bloom, org.apache.hadoop.hbase.regionserver.BloomType type)
     
    T
    CacheableDeserializer.deserialize(org.apache.hadoop.hbase.nio.ByteBuff b, org.apache.hadoop.hbase.io.ByteBuffAllocator allocator)
     
    org.apache.hadoop.hbase.io.hfile.HFileBlock
    HFileBlock.BlockDeserializer.deserialize(org.apache.hadoop.hbase.nio.ByteBuff buf, org.apache.hadoop.hbase.io.ByteBuffAllocator alloc)
     
    static org.apache.hadoop.hbase.io.hfile.BlockType
    BlockType.read(org.apache.hadoop.hbase.nio.ByteBuff buf)
     
    org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
    HFileBlockBuilder.withByteBuff(org.apache.hadoop.hbase.nio.ByteBuff buf)
     
    void
    BlockType.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 in
    Modifier
    Constructor
    Description
     
    HFileBlock(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 new HFile block 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 in
    Modifier and Type
    Method
    Description
    static boolean
    BlockIOUtils.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 least necessaryLen and if possible, extraLen also if available.
    static boolean
    BlockIOUtils.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 least necessaryLen and if possible, extraLen also if available.
    static void
    BlockIOUtils.readFully(org.apache.hadoop.hbase.nio.ByteBuff buf, org.apache.hadoop.fs.FSDataInputStream dis, int length)
    Read length bytes into ByteBuffers directly.
    static void
    BlockIOUtils.readFullyWithHeapBuffer(InputStream in, org.apache.hadoop.hbase.nio.ByteBuff out, int length)
    Copying bytes from InputStream to ByteBuff by using an temporary heap byte[] (default size is 1024 now).
    static int
    StreamUtils.readRawVarint32(org.apache.hadoop.hbase.nio.ByteBuff input)
     
    static boolean
    BlockIOUtils.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.nio
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.nio.MultiByteBuff
    Provides a unified view of all the underlying ByteBuffers and will look as if a bigger sequential buffer.
    class 
    org.apache.hadoop.hbase.nio.SingleByteBuff
    An 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 in
    Modifier and Type
    Method
    Description
    abstract org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.duplicate()
    Returns an ByteBuff which is a duplicate version of this ByteBuff.
    abstract org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.limit(int limit)
    Marks the limit of this ByteBuff
    abstract org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.mark()
    Marks the current position of the ByteBuff
    abstract org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.moveBack(int len)
    Jumps back the current position of this ByteBuff by specified length.
    abstract org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.position(int position)
    Sets this ByteBuff's position to the given value.
    abstract org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.put(byte b)
    Writes a byte to this ByteBuff at the current position and increments the position
    abstract org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.put(byte[] src)
    Copies from the given byte[] to this ByteBuff
    abstract org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.put(byte[] src, int offset, int length)
    Copies from the given byte[] to this ByteBuff
    abstract org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.put(int index, byte b)
    Writes a byte to this ByteBuff at the given index
    abstract org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.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.ByteBuff
    ByteBuff.putInt(int value)
    Writes an int to this ByteBuff at its current position.
    abstract org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.putLong(long value)
    Writes a long to this ByteBuff at its current position.
    abstract org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.reset()
    Similar to ByteBuffer.reset(), ensures that this ByteBuff is reset back to last marked position.
    abstract org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.rewind()
    Rewinds this ByteBuff and the position is set to 0
    abstract org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.skip(int len)
    Jumps the current position of this ByteBuff by specified length.
    abstract org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.slice()
    Returns an ByteBuff which is a sliced version of this ByteBuff.
    org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.touch()
    Calling this method in strategic locations where ByteBuffs are referenced may help diagnose potential buffer leaks.
    org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.touch(Object hint)
     
    static org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.wrap(ByteBuffer buffer)
     
    static org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.wrap(ByteBuffer[] buffers)
     
    static org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.wrap(ByteBuffer[] buffers, org.apache.hadoop.hbase.io.ByteBuffAllocator.Recycler recycler)
     
    static org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.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.ByteBuff
    ByteBuff.wrap(List<ByteBuffer> buffers)
     
    static org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.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 in
    Modifier and Type
    Method
    Description
    static int
    ByteBuff.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 ByteBuffs
    abstract org.apache.hadoop.hbase.nio.ByteBuff
    ByteBuff.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.MultiByteBuff
    MultiByteBuff.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.SingleByteBuff
    SingleByteBuff.put(int offset, org.apache.hadoop.hbase.nio.ByteBuff src, int srcOffset, int length)
     
    static int
    ByteBuff.readCompressedInt(org.apache.hadoop.hbase.nio.ByteBuff buf)
    Read integer from ByteBuff coded in 7 bits and increment position.
    static long
    ByteBuff.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 in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.codec.Codec.Decoder
    WALCellCodec.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 in
    Modifier and Type
    Method
    Description
    boolean
    BloomFilter.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.
    boolean
    BloomFilter.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 boolean
    BloomFilterUtil.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 boolean
    BloomFilterUtil.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)
     
    int
    ByteBufferArray.read(long offset, org.apache.hadoop.hbase.nio.ByteBuff dst)
    Transfers bytes from this buffers array into the given destination ByteBuff
    static long
    ByteBufferUtils.readVLong(org.apache.hadoop.hbase.nio.ByteBuff buf)
    Deprecated.
    Similar to WritableUtils.readVLong(java.io.DataInput) but reads from a ByteBuff.
    int
    ByteBufferArray.write(long offset, org.apache.hadoop.hbase.nio.ByteBuff src)
    Transfers bytes from the given source ByteBuff into this buffer array