Class BufferedDataBlockEncoder.OffheapDecodedExtendedCell
java.lang.Object
org.apache.hadoop.hbase.ByteBufferExtendedCell
org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder.OffheapDecodedExtendedCell
- All Implemented Interfaces:
Cell,ExtendedCell,HeapSize,RawCell
- Enclosing class:
- BufferedDataBlockEncoder
protected static class BufferedDataBlockEncoder.OffheapDecodedExtendedCell
extends ByteBufferExtendedCell
-
Nested Class Summary
-
Field Summary
FieldsModifier and TypeFieldDescriptionprivate byteprivate intprivate static final longprivate ByteBufferprivate intprivate intprivate shortprivate longprivate ByteBufferprivate intprivate intprivate longprivate byteprivate ByteBufferprivate intprivate intFields inherited from interface org.apache.hadoop.hbase.ExtendedCell
CELL_NOT_BASED_ON_CHUNKFields inherited from interface org.apache.hadoop.hbase.RawCell
MAX_TAGS_LENGTH -
Constructor Summary
ConstructorsModifierConstructorDescriptionprotectedOffheapDecodedExtendedCell(ByteBuffer keyBuffer, short rowLength, int familyOffset, byte familyLength, int qualOffset, int qualLength, long timeStamp, byte typeByte, ByteBuffer valueBuffer, int valueOffset, int valueLen, long seqId, ByteBuffer tagsBuffer, int tagsOffset, int tagsLength) -
Method Summary
Modifier and TypeMethodDescriptionDoes a deep copy of the contents to a new memory area and returns it as a new cell.byte[]Contiguous bytes composed of legal HDFS filename characters which may start at any index in the containing array.Returns TheByteBuffercontaining the column family bytes.byteReturns Number of family bytes.intReturns Array index of first family byteintReturns Position in theByteBufferwhere column family bytes startbyte[]Contiguous raw bytes that may start at any index in the containing array.Returns TheByteBuffercontaining the column qualifier bytes.intReturns Number of qualifier bytes.intReturns Array index of first qualifier byteintReturns Position in theByteBufferwhere column qualifier bytes startbyte[]Contiguous raw bytes that may start at any index in the containing array.Returns TheByteBuffercontaining the row bytes.shortReturns Number of row bytes.intReturns Array index of first row byteintReturns Position in theByteBufferwhere row bytes startlongA region-specific unique monotonically increasing sequence ID given to each Cell.intgetSerializedSize(boolean withTags) KeyValue formatbyte[]Contiguous raw bytes representing tags that may start at any index in the containing array.Returns TheByteBuffercontaining the tag bytes.intHBase internally uses 2 bytes to store tags length in Cell.intReturn the first offset where the tags start in the CellintReturns Position in theByteBufferwhere tag bytes startlongReturn a long value representing time at which this cell was "Put" into the row.byteReturns The byte representation of the KeyValue.TYPE of this cell: one of Put, Delete, etcbyte[]Contiguous raw bytes that may start at any index in the containing array.Returns TheByteBuffercontaining the value bytes.intReturns Number of value bytes.intReturns Array index of first value byteintReturns Position in theByteBufferwhere value bytes startlongheapSize()Return the approximate 'exclusive deep size' of implementing object.voidsetSequenceId(long seqId) Sets with the given seqId.voidsetTimestamp(byte[] ts) Sets with the given timestamp.voidsetTimestamp(long ts) Sets with the given timestamp.intwrite(OutputStream out, boolean withTags) Write this cell to an OutputStream in aKeyValueformat.voidwrite(ByteBuffer buf, int offset) Write this Cell into the given buf's offset in aKeyValueformat.Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface org.apache.hadoop.hbase.ExtendedCell
getChunkId, getSerializedSize, getType
-
Field Details
-
FIXED_OVERHEAD
-
keyBuffer
-
rowLength
-
familyOffset
-
familyLength
-
qualifierOffset
-
qualifierLength
-
timeStamp
-
typeByte
-
valueBuffer
-
valueOffset
-
valueLength
-
tagsBuffer
-
tagsOffset
-
tagsLength
-
seqId
-
-
Constructor Details
-
OffheapDecodedExtendedCell
protected OffheapDecodedExtendedCell(ByteBuffer keyBuffer, short rowLength, int familyOffset, byte familyLength, int qualOffset, int qualLength, long timeStamp, byte typeByte, ByteBuffer valueBuffer, int valueOffset, int valueLen, long seqId, ByteBuffer tagsBuffer, int tagsOffset, int tagsLength)
-
-
Method Details
-
getRowArray
Description copied from interface:CellContiguous raw bytes that may start at any index in the containing array. Max length is Short.MAX_VALUE which is 32,767 bytes.- Returns:
- The array containing the row bytes.
-
getRowOffset
Description copied from interface:CellReturns Array index of first row byte -
getRowLength
Description copied from interface:CellReturns Number of row bytes. Must be < rowArray.length - offset. -
getFamilyArray
Description copied from interface:CellContiguous 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.- Returns:
- the array containing the family bytes.
-
getFamilyOffset
Description copied from interface:CellReturns Array index of first family byte -
getFamilyLength
Description copied from interface:CellReturns Number of family bytes. Must be < familyArray.length - offset. -
getQualifierArray
Description copied from interface:CellContiguous raw bytes that may start at any index in the containing array.- Returns:
- The array containing the qualifier bytes.
-
getQualifierOffset
Description copied from interface:CellReturns Array index of first qualifier byte -
getQualifierLength
Description copied from interface:CellReturns Number of qualifier bytes. Must be < qualifierArray.length - offset. -
getTimestamp
Description copied from interface:CellReturn a long value representing time at which this cell was "Put" into the row. Typically represents the time of insertion, but can be any value from 0 to Long.MAX_VALUE. -
getTypeByte
Description copied from interface:ExtendedCellReturns The byte representation of the KeyValue.TYPE of this cell: one of Put, Delete, etc -
getSequenceId
Description copied from interface:ExtendedCellA 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 forHConstants.KEEP_SEQID_PERIODdays, but generally becomes irrelevant after the cell's row is no longer involved in any operations that require strict consistency.- Returns:
- seqId (always > 0 if exists), or 0 if it no longer exists
-
getValueArray
Description copied from interface:CellContiguous 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.- Returns:
- The array containing the value bytes.
-
getValueOffset
Description copied from interface:CellReturns Array index of first value byte -
getValueLength
Description copied from interface:CellReturns Number of value bytes. Must be < valueArray.length - offset. -
getTagsArray
Description copied from interface:RawCellContiguous raw bytes representing tags that may start at any index in the containing array.- Returns:
- the tags byte array
-
getTagsOffset
Description copied from interface:RawCellReturn the first offset where the tags start in the Cell -
getTagsLength
Description copied from interface:RawCellHBase 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 * Short.MAX_VALUE + 1 = 65535. As a result, the return type is int, because a short is not capable of handling that. Please note that even if the return type is int, the max tags length is far less than Integer.MAX_VALUE.- Returns:
- the total length of the tags in the Cell.
-
getRowByteBuffer
Description copied from class:ByteBufferExtendedCellReturns TheByteBuffercontaining the row bytes.- Specified by:
getRowByteBufferin classByteBufferExtendedCell
-
getRowPosition
Description copied from class:ByteBufferExtendedCellReturns Position in theByteBufferwhere row bytes start- Specified by:
getRowPositionin classByteBufferExtendedCell
-
getFamilyByteBuffer
Description copied from class:ByteBufferExtendedCellReturns TheByteBuffercontaining the column family bytes.- Specified by:
getFamilyByteBufferin classByteBufferExtendedCell
-
getFamilyPosition
Description copied from class:ByteBufferExtendedCellReturns Position in theByteBufferwhere column family bytes start- Specified by:
getFamilyPositionin classByteBufferExtendedCell
-
getQualifierByteBuffer
Description copied from class:ByteBufferExtendedCellReturns TheByteBuffercontaining the column qualifier bytes.- Specified by:
getQualifierByteBufferin classByteBufferExtendedCell
-
getQualifierPosition
Description copied from class:ByteBufferExtendedCellReturns Position in theByteBufferwhere column qualifier bytes start- Specified by:
getQualifierPositionin classByteBufferExtendedCell
-
getValueByteBuffer
Description copied from class:ByteBufferExtendedCellReturns TheByteBuffercontaining the value bytes.- Specified by:
getValueByteBufferin classByteBufferExtendedCell
-
getValuePosition
Description copied from class:ByteBufferExtendedCellReturns Position in theByteBufferwhere value bytes start- Specified by:
getValuePositionin classByteBufferExtendedCell
-
getTagsByteBuffer
Description copied from class:ByteBufferExtendedCellReturns TheByteBuffercontaining the tag bytes.- Specified by:
getTagsByteBufferin classByteBufferExtendedCell
-
getTagsPosition
Description copied from class:ByteBufferExtendedCellReturns Position in theByteBufferwhere tag bytes start- Specified by:
getTagsPositionin classByteBufferExtendedCell
-
heapSize
Description copied from interface:HeapSizeReturn the approximate 'exclusive deep size' of implementing object. Includes count of payload and hosting object sizings. -
setSequenceId
Description copied from interface:ExtendedCellSets with the given seqId.- Parameters:
seqId- sequence ID
-
write
Description copied from interface:ExtendedCellWrite this cell to an OutputStream in aKeyValueformat.
KeyValue format
<4 bytes keylength> <4 bytes valuelength> <2 bytes rowlength> <row> <1 byte columnfamilylength> <columnfamily> <columnqualifier> <8 bytes timestamp> <1 byte keytype> <value> <2 bytes tagslength> <tags>- Parameters:
out- Stream to which cell has to be writtenwithTags- Whether to write tags.- Returns:
- how many bytes are written.
- Throws:
IOException
-
getSerializedSize
Description copied from interface:ExtendedCellKeyValue format<4 bytes keylength> <4 bytes valuelength> <2 bytes rowlength> <row> <1 byte columnfamilylength> <columnfamily> <columnqualifier> <8 bytes timestamp> <1 byte keytype> <value> <2 bytes tagslength> <tags>- Parameters:
withTags- Whether to write tags.- Returns:
- Bytes count required to serialize this Cell in a
KeyValueformat.
-
setTimestamp
Description copied from interface:ExtendedCellSets with the given timestamp.- Parameters:
ts- timestamp- Throws:
IOException
-
setTimestamp
Description copied from interface:ExtendedCellSets with the given timestamp.- Parameters:
ts- buffer containing the timestamp value- Throws:
IOException
-
write
Description copied from interface:ExtendedCellWrite this Cell into the given buf's offset in aKeyValueformat.- Parameters:
buf- The buffer where to write the Cell.offset- The offset within buffer, to write the Cell.
-
deepClone
Description copied from interface:ExtendedCellDoes a deep copy of the contents to a new memory area and returns it as a new cell.- Returns:
- The deep cloned cell
-