Return-Path: X-Original-To: archive-asf-public-internal@cust-asf2.ponee.io Delivered-To: archive-asf-public-internal@cust-asf2.ponee.io Received: from cust-asf.ponee.io (cust-asf.ponee.io [163.172.22.183]) by cust-asf2.ponee.io (Postfix) with ESMTP id 7A352200D69 for ; Wed, 27 Dec 2017 16:19:47 +0100 (CET) Received: by cust-asf.ponee.io (Postfix) id 78B8D160C20; Wed, 27 Dec 2017 15:19:47 +0000 (UTC) Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by cust-asf.ponee.io (Postfix) with SMTP id 02EDA160C45 for ; Wed, 27 Dec 2017 16:19:41 +0100 (CET) Received: (qmail 47666 invoked by uid 500); 27 Dec 2017 15:19:38 -0000 Mailing-List: contact commits-help@hbase.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@hbase.apache.org Delivered-To: mailing list commits@hbase.apache.org Received: (qmail 46725 invoked by uid 99); 27 Dec 2017 15:19:37 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Wed, 27 Dec 2017 15:19:37 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id DB774F1816; Wed, 27 Dec 2017 15:19:35 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: git-site-role@apache.org To: commits@hbase.apache.org Date: Wed, 27 Dec 2017 15:19:59 -0000 Message-Id: <475f2850c6234971b48ee68e83f74326@git.apache.org> In-Reply-To: References: X-Mailer: ASF-Git Admin Mailer Subject: [25/51] [partial] hbase-site git commit: Published site at . archived-at: Wed, 27 Dec 2017 15:19:47 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/d2b28a1a/devapidocs/org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.OnheapDecodedCell.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.OnheapDecodedCell.html b/devapidocs/org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.OnheapDecodedCell.html index 89514fe..01f3365 100644 --- a/devapidocs/org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.OnheapDecodedCell.html +++ b/devapidocs/org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.OnheapDecodedCell.html @@ -18,7 +18,7 @@ catch(err) { } //--> -var methods = {"i0":10,"i1":10,"i2":10,"i3":10,"i4":10,"i5":10,"i6":10,"i7":10,"i8":10,"i9":10,"i10":10,"i11":10,"i12":10,"i13":10,"i14":10,"i15":10,"i16":10,"i17":10,"i18":10,"i19":10,"i20":10,"i21":10,"i22":10,"i23":10,"i24":10,"i25":10,"i26":10,"i27":10,"i28":10}; +var methods = {"i0":10,"i1":10,"i2":10,"i3":10,"i4":10,"i5":10,"i6":10,"i7":10,"i8":10,"i9":10,"i10":10,"i11":10,"i12":10,"i13":10,"i14":10,"i15":10,"i16":10,"i17":10,"i18":10,"i19":10,"i20":10,"i21":10,"i22":10,"i23":10,"i24":10,"i25":10,"i26":10}; var tabs = {65535:["t0","All Methods"],2:["t2","Instance Methods"],8:["t4","Concrete Methods"]}; var altColor = "altColor"; var rowColor = "rowColor"; @@ -117,7 +117,7 @@ var activeTableTab = "activeTableTab";

-
protected static class BufferedDataBlockEncoder.OnheapDecodedCell
+
protected static class BufferedDataBlockEncoder.OnheapDecodedCell
 extends Object
 implements ExtendedCell
Copies only the key part of the keybuffer by doing a deep copy and passes the @@ -343,89 +343,77 @@ implements getSerializedSize(boolean withTags)  -Optional<Tag> -getTag(byte type) -
Returns the specific tag of the given type
- - - -List<Tag> -getTags() -
Creates a list of tags in the current cell
- - - byte[] getTagsArray()
Contiguous raw bytes representing tags that may start at any index in the containing array.
- + int getTagsLength()
HBase internally uses 2 bytes to store tags length in Cell.
- + int getTagsOffset()  - + long getTimestamp()  - + byte getTypeByte()  - + byte[] getValueArray()
Contiguous raw bytes that may start at any index in the containing array.
- + int getValueLength()  - + int getValueOffset()  - + long heapSize()  - + void setSequenceId(long seqId)
Sets with the given seqId.
- + void setTimestamp(byte[] ts)
Sets with the given timestamp.
- + void setTimestamp(long ts)
Sets with the given timestamp.
- + String toString()  - + void write(ByteBuffer buf, int offset)
Write this Cell into the given buf's offset in a KeyValue format.
- + int write(OutputStream out, boolean withTags) @@ -452,7 +440,7 @@ implements

Methods inherited from interface org.apache.hadoop.hbase.RawCell

-checkForTagsLength, cloneTags +checkForTagsLength, cloneTags, getTag, getTags @@ -474,7 +462,7 @@ implements
  • FIXED_OVERHEAD

    -
    private static final long FIXED_OVERHEAD
    +
    private static final long FIXED_OVERHEAD
  • @@ -483,7 +471,7 @@ implements
  • keyOnlyBuffer

    -
    private byte[] keyOnlyBuffer
    +
    private byte[] keyOnlyBuffer
  • @@ -492,7 +480,7 @@ implements
  • rowLength

    -
    private short rowLength
    +
    private short rowLength
  • @@ -501,7 +489,7 @@ implements
  • familyOffset

    -
    private int familyOffset
    +
    private int familyOffset
  • @@ -510,7 +498,7 @@ implements
  • familyLength

    -
    private byte familyLength
    +
    private byte familyLength
  • @@ -519,7 +507,7 @@ implements
  • qualifierOffset

    -
    private int qualifierOffset
    +
    private int qualifierOffset
  • @@ -528,7 +516,7 @@ implements
  • qualifierLength

    -
    private int qualifierLength
    +
    private int qualifierLength
  • @@ -537,7 +525,7 @@ implements
  • timestamp

    -
    private long timestamp
    +
    private long timestamp
  • @@ -546,7 +534,7 @@ implements
  • typeByte

    -
    private byte typeByte
    +
    private byte typeByte
  • @@ -555,7 +543,7 @@ implements
  • valueBuffer

    -
    private byte[] valueBuffer
    +
    private byte[] valueBuffer
  • @@ -564,7 +552,7 @@ implements
  • valueOffset

    -
    private int valueOffset
    +
    private int valueOffset
  • @@ -573,7 +561,7 @@ implements
  • valueLength

    -
    private int valueLength
    +
    private int valueLength
  • @@ -582,7 +570,7 @@ implements
  • tagsBuffer

    -
    private byte[] tagsBuffer
    +
    private byte[] tagsBuffer
  • @@ -591,7 +579,7 @@ implements
  • tagsOffset

    -
    private int tagsOffset
    +
    private int tagsOffset
  • @@ -600,7 +588,7 @@ implements
  • tagsLength

    -
    private int tagsLength
    +
    private int tagsLength
  • @@ -609,7 +597,7 @@ implements
  • seqId

    -
    private long seqId
    +
    private long seqId
  • @@ -626,7 +614,7 @@ implements
  • OnheapDecodedCell

    -
    protected OnheapDecodedCell(byte[] keyBuffer,
    +
    protected OnheapDecodedCell(byte[] keyBuffer,
                                 short rowLength,
                                 int familyOffset,
                                 byte familyLength,
    @@ -657,7 +645,7 @@ implements 
     
  • getRowArray

    -
    public byte[] getRowArray()
    +
    public byte[] getRowArray()
    Description copied from interface: Cell
    Contiguous raw bytes that may start at any index in the containing array. Max length is Short.MAX_VALUE which is 32,767 bytes.
    @@ -675,7 +663,7 @@ implements
  • getFamilyArray

    -
    public byte[] getFamilyArray()
    +
    public byte[] getFamilyArray()
    Description copied from interface: Cell
    Contiguous bytes composed of legal HDFS filename characters which may start at any index in the containing array. Max length is Byte.MAX_VALUE, which is 127 bytes.
    @@ -693,7 +681,7 @@ implements
  • getQualifierArray

    -
    public byte[] getQualifierArray()
    +
    public byte[] getQualifierArray()
    Description copied from interface: Cell
    Contiguous raw bytes that may start at any index in the containing array.
    @@ -710,7 +698,7 @@ implements
  • getRowOffset

    -
    public int getRowOffset()
    +
    public int getRowOffset()
    Specified by:
    getRowOffset in interface Cell
    @@ -725,7 +713,7 @@ implements
  • getRowLength

    -
    public short getRowLength()
    +
    public short getRowLength()
    Specified by:
    getRowLength in interface Cell
    @@ -740,7 +728,7 @@ implements
  • getFamilyOffset

    -
    public int getFamilyOffset()
    +
    public int getFamilyOffset()
    Specified by:
    getFamilyOffset in interface Cell
    @@ -755,7 +743,7 @@ implements
  • getFamilyLength

    -
    public byte getFamilyLength()
    +
    public byte getFamilyLength()
    Specified by:
    getFamilyLength in interface Cell
    @@ -770,7 +758,7 @@ implements
  • getQualifierOffset

    -
    public int getQualifierOffset()
    +
    public int getQualifierOffset()
    Specified by:
    getQualifierOffset in interface Cell
    @@ -785,7 +773,7 @@ implements
  • getQualifierLength

    -
    public int getQualifierLength()
    +
    public int getQualifierLength()
    Specified by:
    getQualifierLength in interface Cell
    @@ -800,7 +788,7 @@ implements
  • getTimestamp

    -
    public long getTimestamp()
    +
    public long getTimestamp()
    Specified by:
    getTimestamp in interface Cell
    @@ -816,7 +804,7 @@ implements
  • getTypeByte

    -
    public byte getTypeByte()
    +
    public byte getTypeByte()
    Specified by:
    getTypeByte in interface Cell
    @@ -833,7 +821,7 @@ implements
  • getSequenceId

    -
    public long getSequenceId()
    +
    public long getSequenceId()
    Description copied from interface: ExtendedCell
    A region-specific unique monotonically increasing sequence ID given to each Cell. It always exists for cells in the memstore but is not retained forever. It will be kept for @@ -855,7 +843,7 @@ implements
  • getValueArray

    -
    public byte[] getValueArray()
    +
    public byte[] getValueArray()
    Description copied from interface: Cell
    Contiguous raw bytes that may start at any index in the containing array. Max length is Integer.MAX_VALUE which is 2,147,483,647 bytes.
    @@ -873,7 +861,7 @@ implements
  • getValueOffset

    -
    public int getValueOffset()
    +
    public int getValueOffset()
    Specified by:
    getValueOffset in interface Cell
    @@ -888,7 +876,7 @@ implements
  • getValueLength

    -
    public int getValueLength()
    +
    public int getValueLength()
    Specified by:
    getValueLength in interface Cell
    @@ -903,7 +891,7 @@ implements
  • getTagsArray

    -
    public byte[] getTagsArray()
    +
    public byte[] getTagsArray()
    Description copied from interface: ExtendedCell
    Contiguous raw bytes representing tags that may start at any index in the containing array.
    @@ -922,7 +910,7 @@ implements
  • getTagsOffset

    -
    public int getTagsOffset()
    +
    public int getTagsOffset()
    Specified by:
    getTagsOffset in interface Cell
    @@ -939,7 +927,7 @@ implements
  • getTagsLength

    -
    public int getTagsLength()
    +
    public int getTagsLength()
    Description copied from interface: ExtendedCell
    HBase internally uses 2 bytes to store tags length in Cell. As the tags length is always a non-negative number, to make good use of the sign bit, the max of tags length is defined 2 * @@ -962,7 +950,7 @@ implements
  • toString

    -
    public String toString()
    +
    public String toString()
    Overrides:
    toString in class Object
    @@ -975,7 +963,7 @@ implements
  • setSequenceId

    -
    public void setSequenceId(long seqId)
    +
    public void setSequenceId(long seqId)
    Description copied from interface: ExtendedCell
    Sets with the given seqId.
    @@ -992,7 +980,7 @@ implements
  • heapSize

    -
    public long heapSize()
    +
    public long heapSize()
    Specified by:
    heapSize in interface HeapSize
    @@ -1008,7 +996,7 @@ implements
  • write

    -
    public int write(OutputStream out,
    +
    public int write(OutputStream out,
                      boolean withTags)
               throws IOException
    Description copied from interface: ExtendedCell
    @@ -1037,7 +1025,7 @@ implements
  • getSerializedSize

    -
    public int getSerializedSize(boolean withTags)
    +
    public int getSerializedSize(boolean withTags)
    Specified by:
    getSerializedSize in interface ExtendedCell
    @@ -1059,7 +1047,7 @@ implements
  • write

    -
    public void write(ByteBuffer buf,
    +
    public void write(ByteBuffer buf,
                       int offset)
    Description copied from interface: ExtendedCell
    Write this Cell into the given buf's offset in a KeyValue format.
    @@ -1078,7 +1066,7 @@ implements
  • setTimestamp

    -
    public void setTimestamp(long ts)
    +
    public void setTimestamp(long ts)
                       throws IOException
    Description copied from interface: ExtendedCell
    Sets with the given timestamp.
    @@ -1098,7 +1086,7 @@ implements
  • setTimestamp

    -
    public void setTimestamp(byte[] ts)
    +
    public void setTimestamp(byte[] ts)
                       throws IOException
    Description copied from interface: ExtendedCell
    Sets with the given timestamp.
    @@ -1115,10 +1103,10 @@ implements -
      + - - - -
        -
      • -

        getTag

        -
        public Optional<TaggetTag(byte type)
        -
        Description copied from interface: RawCell
        -
        Returns the specific tag of the given type
        -
        -
        Specified by:
        -
        getTag in interface RawCell
        -
        Parameters:
        -
        type - the type of the tag
        -
        Returns:
        -
        the specific tag if available or null
        -
        -
      • -
      - - - -
        -
      • -

        getTags

        -
        public List<TaggetTags()
        -
        Description copied from interface: RawCell
        -
        Creates a list of tags in the current cell
        -
        -
        Specified by:
        -
        getTags in interface RawCell
        -
        Returns:
        -
        a list of tags
        -
        -
      • -
  • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/d2b28a1a/devapidocs/org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.SeekerState.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.SeekerState.html b/devapidocs/org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.SeekerState.html index 74ce373..90ae7c6 100644 --- a/devapidocs/org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.SeekerState.html +++ b/devapidocs/org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.SeekerState.html @@ -117,7 +117,7 @@ var activeTableTab = "activeTableTab";


  • -
    protected static class BufferedDataBlockEncoder.SeekerState
    +
    protected static class BufferedDataBlockEncoder.SeekerState
     extends Object
  • @@ -312,7 +312,7 @@ extends
  • currentBuffer

    -
    protected ByteBuff currentBuffer
    +
    protected ByteBuff currentBuffer
  • @@ -321,7 +321,7 @@ extends
  • tagCompressionContext

    -
    protected TagCompressionContext tagCompressionContext
    +
    protected TagCompressionContext tagCompressionContext
  • @@ -330,7 +330,7 @@ extends
  • valueOffset

    -
    protected int valueOffset
    +
    protected int valueOffset
  • @@ -339,7 +339,7 @@ extends
  • keyLength

    -
    protected int keyLength
    +
    protected int keyLength
  • @@ -348,7 +348,7 @@ extends
  • valueLength

    -
    protected int valueLength
    +
    protected int valueLength
  • @@ -357,7 +357,7 @@ extends
  • lastCommonPrefix

    -
    protected int lastCommonPrefix
    +
    protected int lastCommonPrefix
  • @@ -366,7 +366,7 @@ extends
  • tagsLength

    -
    protected int tagsLength
    +
    protected int tagsLength
  • @@ -375,7 +375,7 @@ extends
  • tagsOffset

    -
    protected int tagsOffset
    +
    protected int tagsOffset
  • @@ -384,7 +384,7 @@ extends
  • tagsCompressedLength

    -
    protected int tagsCompressedLength
    +
    protected int tagsCompressedLength
  • @@ -393,7 +393,7 @@ extends
  • uncompressTags

    -
    protected boolean uncompressTags
    +
    protected boolean uncompressTags
  • @@ -402,7 +402,7 @@ extends
  • keyBuffer

    -
    protected byte[] keyBuffer
    +
    protected byte[] keyBuffer
    We need to store a copy of the key.
  • @@ -412,7 +412,7 @@ extends
  • tagsBuffer

    -
    protected byte[] tagsBuffer
    +
    protected byte[] tagsBuffer
  • @@ -421,7 +421,7 @@ extends
  • memstoreTS

    -
    protected long memstoreTS
    +
    protected long memstoreTS
  • @@ -430,7 +430,7 @@ extends
  • nextKvOffset

    -
    protected int nextKvOffset
    +
    protected int nextKvOffset
  • @@ -439,7 +439,7 @@ extends
  • currentKey

    -
    protected KeyValue.KeyOnlyKeyValue currentKey
    +
    protected KeyValue.KeyOnlyKeyValue currentKey
  • @@ -448,7 +448,7 @@ extends
  • tmpPair

    -
    private final ObjectIntPair<ByteBuffer> tmpPair
    +
    private final ObjectIntPair<ByteBuffer> tmpPair
  • @@ -457,7 +457,7 @@ extends
  • includeTags

    -
    private final boolean includeTags
    +
    private final boolean includeTags
  • @@ -474,7 +474,7 @@ extends
  • SeekerState

    -
    public SeekerState(ObjectIntPair<ByteBuffer> tmpPair,
    +
    public SeekerState(ObjectIntPair<ByteBuffer> tmpPair,
                        boolean includeTags)
  • @@ -492,7 +492,7 @@ extends
  • isValid

    -
    protected boolean isValid()
    +
    protected boolean isValid()
  • @@ -501,7 +501,7 @@ extends
  • invalidate

    -
    protected void invalidate()
    +
    protected void invalidate()
  • @@ -510,7 +510,7 @@ extends
  • ensureSpaceForKey

    -
    protected void ensureSpaceForKey()
    +
    protected void ensureSpaceForKey()
  • @@ -519,7 +519,7 @@ extends
  • ensureSpaceForTags

    -
    protected void ensureSpaceForTags()
    +
    protected void ensureSpaceForTags()
  • @@ -528,7 +528,7 @@ extends
  • setKey

    -
    protected void setKey(byte[] keyBuffer,
    +
    protected void setKey(byte[] keyBuffer,
                           long memTS)
  • @@ -538,7 +538,7 @@ extends
  • copyFromNext

    -
    protected void copyFromNext(BufferedDataBlockEncoder.SeekerState nextState)
    +
    protected void copyFromNext(BufferedDataBlockEncoder.SeekerState nextState)
    Copy the state from the next one into this instance (the previous state placeholder). Used to save the previous state when we are advancing the seeker to the next key/value.
    @@ -550,7 +550,7 @@ extends
  • toCell

    -
    public Cell toCell()
    +
    public Cell toCell()
  • @@ -559,7 +559,7 @@ extends
  • toOnheapCell

    -
    private Cell toOnheapCell(ByteBuffer valAndTagsBuffer,
    +
    private Cell toOnheapCell(ByteBuffer valAndTagsBuffer,
                               int vOffset,
                               int tagsLenSerializationSize)
  • @@ -570,7 +570,7 @@ extends
  • toOffheapCell

    -
    private Cell toOffheapCell(ByteBuffer valAndTagsBuffer,
    +
    private Cell toOffheapCell(ByteBuffer valAndTagsBuffer,
                                int vOffset,
                                int tagsLenSerializationSize)
  • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/d2b28a1a/devapidocs/org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.html b/devapidocs/org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.html index dae10fa..9da69f4 100644 --- a/devapidocs/org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.html +++ b/devapidocs/org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.html @@ -123,7 +123,7 @@ var activeTableTab = "activeTableTab";

    @InterfaceAudience.Private
    -abstract class BufferedDataBlockEncoder
    +abstract class BufferedDataBlockEncoder
     extends AbstractDataBlockEncoder
    Base class for all data block encoders that use a buffer.
  • @@ -359,7 +359,7 @@ extends
  • INITIAL_KEY_BUFFER_SIZE

    -
    private static int INITIAL_KEY_BUFFER_SIZE
    +
    private static int INITIAL_KEY_BUFFER_SIZE
    TODO: This datablockencoder is dealing in internals of hfileblocks. Purge reference to HFBs
  • @@ -377,7 +377,7 @@ extends
  • BufferedDataBlockEncoder

    -
    BufferedDataBlockEncoder()
    +
    BufferedDataBlockEncoder()
  • @@ -394,7 +394,7 @@ extends
  • decodeKeyValues

    -
    public ByteBuffer decodeKeyValues(DataInputStream source,
    +
    public ByteBuffer decodeKeyValues(DataInputStream source,
                                       HFileBlockDecodingContext blkDecodingCtx)
                                throws IOException
    Description copied from interface: DataBlockEncoder
    @@ -415,7 +415,7 @@ extends
  • compareCommonRowPrefix

    -
    public static int compareCommonRowPrefix(Cell left,
    +
    public static int compareCommonRowPrefix(Cell left,
                                              Cell right,
                                              int rowCommonPrefix)
    common prefixes
    @@ -427,7 +427,7 @@ extends
  • compareCommonFamilyPrefix

    -
    public static int compareCommonFamilyPrefix(Cell left,
    +
    public static int compareCommonFamilyPrefix(Cell left,
                                                 Cell right,
                                                 int familyCommonPrefix)
  • @@ -438,7 +438,7 @@ extends
  • compareCommonQualifierPrefix

    -
    public static int compareCommonQualifierPrefix(Cell left,
    +
    public static int compareCommonQualifierPrefix(Cell left,
                                                    Cell right,
                                                    int qualCommonPrefix)
  • @@ -449,7 +449,7 @@ extends
  • afterEncodingKeyValue

    -
    protected final int afterEncodingKeyValue(Cell cell,
    +
    protected final int afterEncodingKeyValue(Cell cell,
                                               DataOutputStream out,
                                               HFileBlockDefaultEncodingContext encodingCtx)
                                        throws IOException
    @@ -471,7 +471,7 @@ extends
  • afterDecodingKeyValue

    -
    protected final void afterDecodingKeyValue(DataInputStream source,
    +
    protected final void afterDecodingKeyValue(DataInputStream source,
                                                ByteBuffer dest,
                                                HFileBlockDefaultDecodingContext decodingCtx)
                                         throws IOException
    @@ -487,7 +487,7 @@ extends
  • internalDecodeKeyValues

    -
    protected abstract ByteBuffer internalDecodeKeyValues(DataInputStream source,
    +
    protected abstract ByteBuffer internalDecodeKeyValues(DataInputStream source,
                                                           int allocateHeaderLength,
                                                           int skipLastBytes,
                                                           HFileBlockDefaultDecodingContext decodingCtx)
    @@ -504,7 +504,7 @@ extends 
     
  • ensureSpace

    -
    protected static void ensureSpace(ByteBuffer out,
    +
    protected static void ensureSpace(ByteBuffer out,
                                       int length)
                                throws EncoderBufferTooSmallException
    Asserts that there is at least the given amount of unfilled space @@ -524,7 +524,7 @@ extends
  • startBlockEncoding

    -
    public void startBlockEncoding(HFileBlockEncodingContext blkEncodingCtx,
    +
    public void startBlockEncoding(HFileBlockEncodingContext blkEncodingCtx,
                                    DataOutputStream out)
                             throws IOException
    Description copied from interface: DataBlockEncoder
    @@ -543,7 +543,7 @@ extends
  • encode

    -
    public int encode(Cell cell,
    +
    public int encode(Cell cell,
                       HFileBlockEncodingContext encodingCtx,
                       DataOutputStream out)
                throws IOException
    @@ -563,7 +563,7 @@ extends
  • internalEncode

    -
    public abstract int internalEncode(Cell cell,
    +
    public abstract int internalEncode(Cell cell,
                                        HFileBlockDefaultEncodingContext encodingCtx,
                                        DataOutputStream out)
                                 throws IOException
    @@ -579,7 +579,7 @@ extends
  • endBlockEncoding

    -
    public void endBlockEncoding(HFileBlockEncodingContext encodingCtx,
    +
    public void endBlockEncoding(HFileBlockEncodingContext encodingCtx,
                                  DataOutputStream out,
                                  byte[] uncompressedBytesWithHeader)
                           throws IOException