Uses of Interface
org.apache.hadoop.hbase.Cell

Packages that use org.apache.hadoop.hbase.Cell
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase

    Subinterfaces of org.apache.hadoop.hbase.Cell in in org.apache.hadoop.hbase
    Modifier and Type
    Interface
    Description
    interface 
    org.apache.hadoop.hbase.ExtendedCell
    Extension to Cell with server side required functions.
    interface 
    org.apache.hadoop.hbase.RawCell
    An extended version of Cell that allows CPs manipulate Tags.
    Classes in org.apache.hadoop.hbase that implement org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.ByteBufferExtendedCell
    This class is a server side extension to the Cell interface.
    class 
    org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
    This is a key only Cell implementation which is identical to KeyValue.KeyOnlyKeyValue with respect to key serialization but have its data in the form of Byte buffer (onheap and offheap).
    class 
    org.apache.hadoop.hbase.ByteBufferKeyValue
    This Cell is an implementation of ByteBufferExtendedCell where the data resides in off heap/ on heap ByteBuffer
    class 
    org.apache.hadoop.hbase.IndividualBytesFieldCell
     
    class 
    org.apache.hadoop.hbase.KeyValue
    An HBase Key/Value.
    static class 
    org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
    A simple form of KeyValue that creates a keyvalue with only the key part of the byte[] Mainly used in places where we need to compare two cells.
    class 
    org.apache.hadoop.hbase.NoTagsByteBufferKeyValue
    An extension of the ByteBufferKeyValue where the tags length is always 0
    class 
    org.apache.hadoop.hbase.NoTagsKeyValue
    An extension of the KeyValue where the tags length is always 0
    class 
    org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
    This Cell is an implementation of ByteBufferExtendedCell where the data resides in off heap/ on heap ByteBuffer
    class 
    org.apache.hadoop.hbase.SizeCachedKeyValue
    This class is an extension to KeyValue where rowLen and keyLen are cached.
    class 
    org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
    This Cell is an implementation of ByteBufferExtendedCell where the data resides in off heap/ on heap ByteBuffer
    class 
    org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
    This class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.
    Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.Cell
    CellBuilder.build()
     
    static org.apache.hadoop.hbase.Cell
    CellUtil.cloneIfNecessary(org.apache.hadoop.hbase.Cell cell)
     
    static org.apache.hadoop.hbase.Cell
    CellUtil.createCell(byte[] row)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static org.apache.hadoop.hbase.Cell
    CellUtil.createCell(byte[] row, byte[] value)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static org.apache.hadoop.hbase.Cell
    CellUtil.createCell(byte[] row, byte[] family, byte[] qualifier)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static org.apache.hadoop.hbase.Cell
    CellUtil.createCell(byte[] row, byte[] family, byte[] qualifier, long timestamp, byte type, byte[] value)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static org.apache.hadoop.hbase.Cell
    CellUtil.createCell(byte[] row, byte[] family, byte[] qualifier, long timestamp, byte type, byte[] value, byte[] tags, long memstoreTS)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static org.apache.hadoop.hbase.Cell
    CellUtil.createCell(byte[] row, byte[] family, byte[] qualifier, long timestamp, byte type, byte[] value, long memstoreTS)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static org.apache.hadoop.hbase.Cell
    CellUtil.createCell(byte[] row, byte[] family, byte[] qualifier, long timestamp, org.apache.hadoop.hbase.KeyValue.Type type, byte[] value, byte[] tags)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static org.apache.hadoop.hbase.Cell
    CellUtil.createCell(byte[] rowArray, int rowOffset, int rowLength, byte[] familyArray, int familyOffset, int familyLength, byte[] qualifierArray, int qualifierOffset, int qualifierLength)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static org.apache.hadoop.hbase.Cell
    CellUtil.createCell(org.apache.hadoop.hbase.Cell cell, byte[] tags)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static org.apache.hadoop.hbase.Cell
    CellUtil.createCell(org.apache.hadoop.hbase.Cell cell, byte[] value, byte[] tags)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static org.apache.hadoop.hbase.Cell
    CellUtil.createCell(org.apache.hadoop.hbase.Cell cell, List<org.apache.hadoop.hbase.Tag> tags)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createCell(org.apache.hadoop.hbase.Cell cell, byte[] tags)
    Returns A new cell which is having the extra tags also added to it.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createCell(org.apache.hadoop.hbase.Cell cell, byte[] value, byte[] tags)
     
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createCell(org.apache.hadoop.hbase.Cell cell, List<org.apache.hadoop.hbase.Tag> tags)
    Returns A new cell which is having the extra tags also added to it.
    static org.apache.hadoop.hbase.Cell
    RawCell.createCell(org.apache.hadoop.hbase.Cell cell, List<org.apache.hadoop.hbase.Tag> tags)
    Returns A new cell which is having the extra tags also added to it.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstDeleteFamilyCellOnRow(byte[] row, byte[] fam)
    Create a Delete Family Cell for the specified row and family that would be smaller than all other possible Delete Family KeyValues that have the same row and family.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstOnNextRow(org.apache.hadoop.hbase.Cell cell)
     
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstOnRow(byte[] row)
     
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstOnRow(byte[] row, byte[] family, byte[] col)
     
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstOnRow(byte[] row, int roffset, short rlength)
     
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstOnRow(byte[] row, int roffset, short rlength, byte[] family, int foffset, byte flength, byte[] col, int coffset, int clength)
     
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstOnRow(org.apache.hadoop.hbase.Cell cell)
    Create a Cell that is smaller than all other possible Cells for the given Cell's row.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstOnRowCol(org.apache.hadoop.hbase.Cell cell)
     
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstOnRowCol(org.apache.hadoop.hbase.Cell cell, byte[] qArray, int qoffest, int qlength)
    Create a Cell that is smaller than all other possible Cells for the given Cell's rk:cf and passed qualifier.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstOnRowColTS(org.apache.hadoop.hbase.Cell cell, long ts)
    Creates the first cell with the row/family/qualifier of this cell and the given timestamp.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstOnRowFamily(org.apache.hadoop.hbase.Cell cell, byte[] fArray, int foff, int flen)
     
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createLastOnRow(byte[] row)
     
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createLastOnRow(org.apache.hadoop.hbase.Cell cell)
    Create a Cell that is larger than all other possible Cells for the given Cell's row.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createLastOnRowCol(org.apache.hadoop.hbase.Cell cell)
    Create a Cell that is larger than all other possible Cells for the given Cell's rk:cf:q.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createNextOnRowCol(org.apache.hadoop.hbase.Cell cell)
    Return a new cell is located following input cell.
    org.apache.hadoop.hbase.Cell
    CellScanner.current()
    Returns the current Cell which may be mutable
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.deepClone(org.apache.hadoop.hbase.Cell cell)
    Deep clones the given cell if the cell supports deep cloning
    Methods in org.apache.hadoop.hbase that return types with arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    Comparator<org.apache.hadoop.hbase.Cell>
    CellComparator.getSimpleComparator()
    Return a dumbed-down, fast comparator for hbase2 base-type, the ByteBufferKeyValue.
    Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    static int
    KeyValueUtil.appendKeyTo(org.apache.hadoop.hbase.Cell cell, byte[] output, int offset)
     
    static int
    KeyValueUtil.appendKeyTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer buf, int offset)
     
    static int
    KeyValueUtil.appendTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer buf, int offset, boolean withTags)
    Copy the Cell content into the passed buf in KeyValue serialization format.
    static int
    KeyValueUtil.appendToByteArray(org.apache.hadoop.hbase.Cell cell, byte[] output, int offset, boolean withTags)
    copy key and value
    static List<org.apache.hadoop.hbase.Tag>
    TagUtil.carryForwardTags(List<org.apache.hadoop.hbase.Tag> tagsOrNull, org.apache.hadoop.hbase.Cell cell)
    Add to tagsOrNull any Tags cell is carrying or null if none.
    static List<org.apache.hadoop.hbase.Tag>
    TagUtil.carryForwardTags(org.apache.hadoop.hbase.Cell cell)
    Returns A List<Tag> of any Tags found in cell else null.
    static byte[]
    CellUtil.cloneFamily(org.apache.hadoop.hbase.Cell cell)
     
    static org.apache.hadoop.hbase.Cell
    CellUtil.cloneIfNecessary(org.apache.hadoop.hbase.Cell cell)
     
    static byte[]
    CellUtil.cloneQualifier(org.apache.hadoop.hbase.Cell cell)
     
    static byte[]
    CellUtil.cloneRow(org.apache.hadoop.hbase.Cell cell)
    get individual arrays for tests
    static byte[]
    CellUtil.cloneTags(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    As of HBase-2.0.
    static byte[]
    PrivateCellUtil.cloneTags(org.apache.hadoop.hbase.Cell cell)
     
    static byte[]
    CellUtil.cloneValue(org.apache.hadoop.hbase.Cell cell)
     
    int
    CellComparator.compare(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell)
    Lexographically compares two cells.
    int
    CellComparator.compare(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell, boolean ignoreSequenceid)
    Compare cells.
    final int
    CellComparatorImpl.compare(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b)
     
    int
    CellComparatorImpl.compare(org.apache.hadoop.hbase.Cell l, org.apache.hadoop.hbase.Cell r, boolean ignoreSequenceid)
     
    static final int
    CellUtil.compare(CellComparator comparator, org.apache.hadoop.hbase.Cell left, byte[] key, int offset, int length)
    Deprecated.
    As of HBase-2.0.
    int
    KeyValue.KVComparator.compare(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Deprecated.
    Compares the Key of a cell -- with fields being more significant in this order: rowkey, colfam/qual, timestamp, type, mvcc
    int
    KeyValue.MetaComparator.compare(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Deprecated.
    Compare key portion of a KeyValue for keys in hbase:meta table.
    int
    MetaCellComparator.compare(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b, boolean ignoreSequenceid)
     
    static final int
    PrivateCellUtil.compare(CellComparator comparator, org.apache.hadoop.hbase.Cell left, byte[] key, int offset, int length)
    Used when a cell needs to be compared with a key byte[] such as cases of finding the index from the index block, bloom keys from the bloom blocks This byte[] is expected to be serialized in the KeyValue serialization format If the KeyValue (Cell's) serialization format changes this method cannot be used.
    final int
    CellComparatorImpl.compareColumns(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Compares the family and qualifier part of the cell
    static final int
    CellUtil.compareColumns(org.apache.hadoop.hbase.Cell left, byte[] right, int rfoffset, int rflength, int rqoffset, int rqlength)
    Compares the cell's column (family and qualifier) with the given byte[]
    int
    CellComparator.compareFamilies(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell)
    Lexicographically compares the families of the two cells
    protected int
    CellComparatorImpl.compareFamilies(org.apache.hadoop.hbase.Cell left, int leftFamLen, org.apache.hadoop.hbase.Cell right, int rightFamLen)
    This method will be overridden when we compare cells inner store to bypass family comparing.
    final int
    CellComparatorImpl.compareFamilies(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Compare the families of left and right cell
    static final int
    CellUtil.compareFamilies(org.apache.hadoop.hbase.Cell left, byte[] right, int roffset, int rlength)
    Compares the cell's family with the given byte[]
    protected int
    InnerStoreCellComparator.compareFamilies(org.apache.hadoop.hbase.Cell left, int leftFamilyLength, org.apache.hadoop.hbase.Cell right, int rightFamilyLength)
     
    static int
    PrivateCellUtil.compareFamily(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator)
    Compare cell's column family against given comparator
    int
    KeyValue.KVComparator.compareKey(org.apache.hadoop.hbase.Cell cell, byte[] row, int roff, int rlen, byte[] fam, int foff, int flen, byte[] col, int coff, int clen, long ts, byte type)
    Deprecated.
     
    static final int
    PrivateCellUtil.compareKeyBasedOnColHint(CellComparator comparator, org.apache.hadoop.hbase.Cell nextIndexedCell, org.apache.hadoop.hbase.Cell currentCell, int foff, int flen, byte[] colHint, int coff, int clen, long ts, byte type)
    Used to compare two cells based on the column hint provided.
    static final int
    PrivateCellUtil.compareKeyIgnoresMvcc(CellComparator comparator, org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Compares only the key portion of a cell.
    int
    KeyValue.KVComparator.compareOnlyKeyPortion(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Deprecated.
     
    int
    KeyValue.MetaComparator.compareOnlyKeyPortion(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Deprecated.
     
    static int
    PrivateCellUtil.compareQualifier(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator)
    Compare cell's qualifier against given comparator
    int
    CellComparator.compareQualifiers(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell)
    Lexicographically compares the qualifiers of the two cells
    final int
    CellComparatorImpl.compareQualifiers(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Compare the qualifiers part of the left and right cells.
    static final int
    CellUtil.compareQualifiers(org.apache.hadoop.hbase.Cell left, byte[] right, int rOffset, int rLength)
    Compares the cell's qualifier with the given byte[]
    static int
    PrivateCellUtil.compareRow(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator)
    Compare cell's row against given comparator
    protected int
    KeyValue.KVComparator.compareRowKey(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Deprecated.
    Compares the only the user specified portion of a Key.
    protected int
    KeyValue.MetaComparator.compareRowKey(org.apache.hadoop.hbase.Cell l, org.apache.hadoop.hbase.Cell r)
    Deprecated.
    Override the row key comparison to parse and compare the meta row key parts.
    default int
    CellComparator.compareRows(ByteBuffer row, org.apache.hadoop.hbase.Cell cell)
    Lexicographically compare two rows
    int
    CellComparator.compareRows(org.apache.hadoop.hbase.Cell cell, byte[] bytes, int offset, int length)
    Compares the row part of the cell with a simple plain byte[] like the stopRow in Scan.
    int
    CellComparator.compareRows(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell)
    Lexographically compares the rows of two cells.
    int
    CellComparatorImpl.compareRows(org.apache.hadoop.hbase.Cell left, byte[] right, int roffset, int rlength)
    Compares the row part of the cell with a simple plain byte[] like the stopRow in Scan.
    int
    CellComparatorImpl.compareRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Compares the rows of the left and right cell.
    int
    KeyValue.KVComparator.compareRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Deprecated.
    Compares the rows of a cell
    int
    MetaCellComparator.compareRows(ByteBuffer row, org.apache.hadoop.hbase.Cell cell)
     
    int
    MetaCellComparator.compareRows(org.apache.hadoop.hbase.Cell left, byte[] right, int roffset, int rlength)
     
    int
    MetaCellComparator.compareRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
     
    int
    CellComparator.compareTimestamps(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell)
    Compares cell's timestamps in DESCENDING order.
    int
    CellComparatorImpl.compareTimestamps(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
     
    int
    KeyValue.KVComparator.compareTimestamps(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Deprecated.
     
    static int
    PrivateCellUtil.compareValue(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator)
    Compare cell's value against given comparator
    int
    CellComparator.compareWithoutRow(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell)
    Lexicographically compares the two cells excluding the row part.
    final int
    CellComparatorImpl.compareWithoutRow(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
     
    static void
    PrivateCellUtil.compressFamily(OutputStream out, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.util.Dictionary dict)
     
    static void
    PrivateCellUtil.compressQualifier(OutputStream out, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.util.Dictionary dict)
     
    static void
    PrivateCellUtil.compressRow(OutputStream out, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.util.Dictionary dict)
     
    static void
    PrivateCellUtil.compressTags(OutputStream out, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.TagCompressionContext tagCompressionContext)
    Compresses the tags to the given outputstream using the TagcompressionContext
    static byte[]
    TagUtil.concatTags(byte[] tags, org.apache.hadoop.hbase.Cell cell)
     
    static int
    CellUtil.copyFamilyTo(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset)
    Copies the family to the given byte[]
    static int
    CellUtil.copyFamilyTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset)
    Copies the family to the given bytebuffer
    static ByteBuffer
    KeyValueUtil.copyKeyToNewByteBuffer(org.apache.hadoop.hbase.Cell cell)
    The position will be set to the beginning of the new ByteBuffer
    static int
    CellUtil.copyQualifierTo(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset)
    Copies the qualifier to the given byte[]
    static int
    CellUtil.copyQualifierTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset)
    Copies the qualifier to the given bytebuffer
    static byte[]
    CellUtil.copyRow(org.apache.hadoop.hbase.Cell cell)
    Copies the row to a new byte[]
    static int
    CellUtil.copyRowTo(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset)
    Copies the row to the given byte[]
    static int
    CellUtil.copyRowTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset)
    Copies the row to the given bytebuffer
    static int
    PrivateCellUtil.copyTagsTo(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset)
    Copies the tags info into the tag portion of the cell
    static int
    PrivateCellUtil.copyTagsTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset)
    Copies the tags info into the tag portion of the cell
    static int
    CellUtil.copyTagTo(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset)
    Deprecated.
    As of HBase-2.0.
    static int
    CellUtil.copyTagTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset)
    Deprecated.
    As of HBase-2.0.
    static byte[]
    KeyValueUtil.copyToNewByteArray(org.apache.hadoop.hbase.Cell cell)
     
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.copyToNewKeyValue(org.apache.hadoop.hbase.Cell cell)
    copy the cell to create a new keyvalue
    static int
    CellUtil.copyValueTo(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset)
    Copies the value to the given byte[]
    static int
    CellUtil.copyValueTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset)
    Copies the value to the given bytebuffer
    static org.apache.hadoop.hbase.Cell
    CellUtil.createCell(org.apache.hadoop.hbase.Cell cell, byte[] tags)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static org.apache.hadoop.hbase.Cell
    CellUtil.createCell(org.apache.hadoop.hbase.Cell cell, byte[] value, byte[] tags)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static org.apache.hadoop.hbase.Cell
    CellUtil.createCell(org.apache.hadoop.hbase.Cell cell, List<org.apache.hadoop.hbase.Tag> tags)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createCell(org.apache.hadoop.hbase.Cell cell, byte[] tags)
    Returns A new cell which is having the extra tags also added to it.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createCell(org.apache.hadoop.hbase.Cell cell, byte[] value, byte[] tags)
     
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createCell(org.apache.hadoop.hbase.Cell cell, List<org.apache.hadoop.hbase.Tag> tags)
    Returns A new cell which is having the extra tags also added to it.
    static org.apache.hadoop.hbase.Cell
    RawCell.createCell(org.apache.hadoop.hbase.Cell cell, List<org.apache.hadoop.hbase.Tag> tags)
    Returns A new cell which is having the extra tags also added to it.
    static org.apache.hadoop.hbase.CellScanner
    CellUtil.createCellScanner(org.apache.hadoop.hbase.Cell[] cellArray)
    Returns CellScanner interface over cellArray
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstOnNextRow(org.apache.hadoop.hbase.Cell cell)
     
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstOnRow(org.apache.hadoop.hbase.Cell cell)
    Create a Cell that is smaller than all other possible Cells for the given Cell's row.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstOnRowCol(org.apache.hadoop.hbase.Cell cell)
     
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstOnRowCol(org.apache.hadoop.hbase.Cell cell, byte[] qArray, int qoffest, int qlength)
    Create a Cell that is smaller than all other possible Cells for the given Cell's rk:cf and passed qualifier.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstOnRowColTS(org.apache.hadoop.hbase.Cell cell, long ts)
    Creates the first cell with the row/family/qualifier of this cell and the given timestamp.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createFirstOnRowFamily(org.apache.hadoop.hbase.Cell cell, byte[] fArray, int foff, int flen)
     
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createLastOnRow(org.apache.hadoop.hbase.Cell cell)
    Create a Cell that is larger than all other possible Cells for the given Cell's row.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createLastOnRowCol(org.apache.hadoop.hbase.Cell cell)
    Create a Cell that is larger than all other possible Cells for the given Cell's rk:cf:q.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.createNextOnRowCol(org.apache.hadoop.hbase.Cell cell)
    Return a new cell is located following input cell.
    static org.apache.hadoop.hbase.Cell
    PrivateCellUtil.deepClone(org.apache.hadoop.hbase.Cell cell)
    Deep clones the given cell if the cell supports deep cloning
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.ensureKeyValue(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    without any replacement.
    static boolean
    CellUtil.equals(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b)
    equals
    static boolean
    CellUtil.equalsIgnoreMvccVersion(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b)
    Deprecated.
    As of HBase-2.0.
    static boolean
    PrivateCellUtil.equalsIgnoreMvccVersion(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b)
    special case for Cell.equals
    static long
    CellUtil.estimatedHeapSizeOf(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static int
    CellUtil.estimatedSerializedSizeOf(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static int
    PrivateCellUtil.estimatedSerializedSizeOf(org.apache.hadoop.hbase.Cell cell)
    Estimate based on keyvalue's serialization format in the RPC layer.
    static int
    CellUtil.estimatedSerializedSizeOfKey(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static int
    PrivateCellUtil.estimatedSerializedSizeOfKey(org.apache.hadoop.hbase.Cell cell)
    Calculates the serialized key size.
    static org.apache.hadoop.hbase.util.ByteRange
    CellUtil.fillFamilyRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range)
    Deprecated.
    As of HBase-2.0.
    static org.apache.hadoop.hbase.util.ByteRange
    PrivateCellUtil.fillFamilyRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range)
     
    static org.apache.hadoop.hbase.util.ByteRange
    CellUtil.fillQualifierRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range)
    Deprecated.
    As of HBase-2.0.
    static org.apache.hadoop.hbase.util.ByteRange
    PrivateCellUtil.fillQualifierRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range)
     
    static org.apache.hadoop.hbase.util.ByteRange
    CellUtil.fillRowRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range)
    Deprecated.
    As of HBase-2.0.
    static org.apache.hadoop.hbase.util.ByteRange
    PrivateCellUtil.fillRowRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range)
    ByteRange
    static org.apache.hadoop.hbase.util.ByteRange
    CellUtil.fillTagRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range)
    Deprecated.
    As of HBase-2.0.
    static org.apache.hadoop.hbase.util.ByteRange
    PrivateCellUtil.fillTagRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range)
     
    static org.apache.hadoop.hbase.util.ByteRange
    CellUtil.fillValueRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range)
    Deprecated.
    As of HBase-2.0.
    static org.apache.hadoop.hbase.util.ByteRange
    PrivateCellUtil.fillValueRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range)
     
    static int
    CellUtil.findCommonPrefixInFlatKey(org.apache.hadoop.hbase.Cell c1, org.apache.hadoop.hbase.Cell c2, boolean bypassFamilyCheck, boolean withTsType)
    Deprecated.
    As of HBase-2.0.
    static int
    PrivateCellUtil.findCommonPrefixInFlatKey(org.apache.hadoop.hbase.Cell c1, org.apache.hadoop.hbase.Cell c2, boolean bypassFamilyCheck, boolean withTsType)
    Find length of common prefix in keys of the cells, considering key as byte[] if serialized in KeyValue.
    static String
    CellUtil.getCellKeyAsString(org.apache.hadoop.hbase.Cell cell)
    Return the key portion of the passed cell as a String.
    static String
    CellUtil.getCellKeyAsString(org.apache.hadoop.hbase.Cell cell, Function<org.apache.hadoop.hbase.Cell,String> rowConverter)
    Return the Key portion of the passed cell as a String.
    static byte[]
    CellUtil.getCellKeySerializedAsKeyValueKey(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    As of HBase-2.0.
    static byte[]
    PrivateCellUtil.getCellKeySerializedAsKeyValueKey(org.apache.hadoop.hbase.Cell cell)
    This method exists just to encapsulate how we serialize keys.
    static List<org.apache.hadoop.hbase.client.RegionInfo>
    MetaTableAccessor.getMergeRegions(org.apache.hadoop.hbase.Cell[] cells)
    Returns Deserialized regioninfo values taken from column values that match the regex 'info:merge.*' in array of cells.
    static Map<String,org.apache.hadoop.hbase.client.RegionInfo>
    MetaTableAccessor.getMergeRegionsWithName(org.apache.hadoop.hbase.Cell[] cells)
    Returns Deserialized values of <qualifier,regioninfo> pairs taken from column values that match the regex 'info:merge.*' in array of cells.
    static ByteBuffer
    CellUtil.getQualifierBufferShallowCopy(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static byte
    PrivateCellUtil.getQualifierByte(org.apache.hadoop.hbase.Cell cell, int index)
     
    static int
    PrivateCellUtil.getRowAsInt(org.apache.hadoop.hbase.Cell cell)
    Converts the rowkey bytes of the given cell into an int value
    static byte
    CellUtil.getRowByte(org.apache.hadoop.hbase.Cell cell, int index)
    Deprecated.
    static byte
    PrivateCellUtil.getRowByte(org.apache.hadoop.hbase.Cell cell, int index)
    misc
    static int
    KeyValueUtil.getSerializedSize(org.apache.hadoop.hbase.Cell cell, boolean withTags)
     
    static org.apache.hadoop.hbase.Tag
    CellUtil.getTag(org.apache.hadoop.hbase.Cell cell, byte type)
    Deprecated.
    As of 2.0.0 and will be removed in HBase-3.0.0 Use RawCell.getTag(byte)
    static Optional<org.apache.hadoop.hbase.Tag>
    PrivateCellUtil.getTag(org.apache.hadoop.hbase.Cell cell, byte type)
    Retrieve Cell's first tag, matching the passed in type
    static byte[]
    CellUtil.getTagArray(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    As of HBase-2.0.
    static List<org.apache.hadoop.hbase.Tag>
    CellUtil.getTags(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    As of 2.0.0 and will be removed in 3.0.0
    static List<org.apache.hadoop.hbase.Tag>
    PrivateCellUtil.getTags(org.apache.hadoop.hbase.Cell cell)
    Return tags in the given Cell as a List
    static BigDecimal
    PrivateCellUtil.getValueAsBigDecimal(org.apache.hadoop.hbase.Cell cell)
    Converts the value bytes of the given cell into a BigDecimal
    static double
    PrivateCellUtil.getValueAsDouble(org.apache.hadoop.hbase.Cell cell)
    Converts the value bytes of the given cell into a double value
    static int
    PrivateCellUtil.getValueAsInt(org.apache.hadoop.hbase.Cell cell)
    Converts the value bytes of the given cell into a int value
    static long
    PrivateCellUtil.getValueAsLong(org.apache.hadoop.hbase.Cell cell)
    Converts the value bytes of the given cell into a long value
    static ByteBuffer
    CellUtil.getValueBufferShallowCopy(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    As of HBase-2.0.
    static ByteBuffer
    PrivateCellUtil.getValueBufferShallowCopy(org.apache.hadoop.hbase.Cell cell)
     
    static boolean
    MetaTableAccessor.hasMergeRegions(org.apache.hadoop.hbase.Cell[] cells)
    Returns True if any merge regions present in cells; i.e.
    static boolean
    CellUtil.isDelete(org.apache.hadoop.hbase.Cell cell)
    Return true if a delete type, a KeyValue.Type.Delete or a {KeyValue.Type#DeleteFamily} or a KeyValue.Type.DeleteColumn KeyValue type.
    static boolean
    CellUtil.isDeleteColumnOrFamily(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static boolean
    PrivateCellUtil.isDeleteColumnOrFamily(org.apache.hadoop.hbase.Cell cell)
    Returns True if this cell is a delete family or column type.
    static boolean
    CellUtil.isDeleteColumns(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static boolean
    PrivateCellUtil.isDeleteColumns(org.apache.hadoop.hbase.Cell cell)
     
    static boolean
    CellUtil.isDeleteColumnVersion(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static boolean
    PrivateCellUtil.isDeleteColumnVersion(org.apache.hadoop.hbase.Cell cell)
     
    static boolean
    CellUtil.isDeleteFamily(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static boolean
    PrivateCellUtil.isDeleteFamily(org.apache.hadoop.hbase.Cell cell)
     
    static boolean
    CellUtil.isDeleteFamilyVersion(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static boolean
    PrivateCellUtil.isDeleteFamilyVersion(org.apache.hadoop.hbase.Cell cell)
     
    static boolean
    CellUtil.isDeleteType(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static boolean
    PrivateCellUtil.isDeleteType(org.apache.hadoop.hbase.Cell cell)
    Returns True if this cell is a KeyValue.Type.Delete type.
    static boolean
    CellUtil.isPut(org.apache.hadoop.hbase.Cell cell)
    Returns True if this cell is a Put.
    static int
    KeyValueUtil.keyLength(org.apache.hadoop.hbase.Cell cell)
    Returns number of bytes this cell's key part would have been used if serialized as in KeyValue.
    static boolean
    CellUtil.matchingColumn(org.apache.hadoop.hbase.Cell left, byte[] fam, byte[] qual)
     
    static boolean
    CellUtil.matchingColumn(org.apache.hadoop.hbase.Cell left, byte[] fam, int foffset, int flength, byte[] qual, int qoffset, int qlength)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static boolean
    CellUtil.matchingColumn(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
     
    static boolean
    PrivateCellUtil.matchingColumn(org.apache.hadoop.hbase.Cell left, byte[] fam, int foffset, int flength, byte[] qual, int qoffset, int qlength)
     
    static boolean
    CellUtil.matchingColumnFamilyAndQualifierPrefix(org.apache.hadoop.hbase.Cell left, byte[] fam, byte[] qual)
    Returns True if matching column family and the qualifier starts with qual
    static boolean
    CellUtil.matchingFamily(org.apache.hadoop.hbase.Cell left, byte[] buf)
     
    static boolean
    CellUtil.matchingFamily(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static boolean
    CellUtil.matchingFamily(org.apache.hadoop.hbase.Cell left, byte lfamlength, org.apache.hadoop.hbase.Cell right, byte rfamlength)
     
    static boolean
    CellUtil.matchingFamily(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
     
    static boolean
    PrivateCellUtil.matchingFamily(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length)
     
    static boolean
    CellUtil.matchingQualifier(org.apache.hadoop.hbase.Cell left, byte[] buf)
    Finds if the qualifier part of the cell and the KV serialized byte[] are equal.
    static boolean
    CellUtil.matchingQualifier(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static boolean
    CellUtil.matchingQualifier(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
     
    static boolean
    PrivateCellUtil.matchingQualifier(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length)
    Finds if the qualifier part of the cell and the KV serialized byte[] are equal
    static boolean
    CellUtil.matchingRow(org.apache.hadoop.hbase.Cell left, byte[] buf)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static boolean
    CellUtil.matchingRow(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static boolean
    CellUtil.matchingRow(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static boolean
    CellUtil.matchingRowColumn(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Compares the row and column of two keyvalues for equality
    boolean
    KeyValue.KVComparator.matchingRowColumn(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Deprecated.
    Compares the row and column of two keyvalues for equality
    static boolean
    CellUtil.matchingRowColumnBytes(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Compares the row and column of two keyvalues for equality
    static boolean
    CellUtil.matchingRows(org.apache.hadoop.hbase.Cell left, byte[] buf)
     
    static boolean
    CellUtil.matchingRows(org.apache.hadoop.hbase.Cell left, short lrowlength, org.apache.hadoop.hbase.Cell right, short rrowlength)
    Compares the row of two keyvalues for equality
    static boolean
    CellUtil.matchingRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Compares the row of two keyvalues for equality
    boolean
    KeyValue.KVComparator.matchingRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Deprecated.
    Compares the row of two keyvalues for equality
    static boolean
    PrivateCellUtil.matchingRows(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length)
     
    static boolean
    CellUtil.matchingTags(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
     
    static boolean
    PrivateCellUtil.matchingTags(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right, int llength, int rlength)
     
    static boolean
    CellUtil.matchingTimestamp(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b)
     
    static boolean
    CellUtil.matchingType(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b)
    Deprecated.
    As of HBase-2.0.
    static boolean
    PrivateCellUtil.matchingType(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b)
     
    static boolean
    CellUtil.matchingValue(org.apache.hadoop.hbase.Cell left, byte[] buf)
     
    static boolean
    CellUtil.matchingValue(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
     
    static boolean
    PrivateCellUtil.matchingValue(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right, int lvlength, int rvlength)
     
    static int
    KeyValueUtil.oswrite(org.apache.hadoop.hbase.Cell cell, OutputStream out, boolean withTags)
     
    static boolean
    PrivateCellUtil.qualifierStartsWith(org.apache.hadoop.hbase.Cell left, byte[] startsWith)
    Finds if the start of the qualifier part of the Cell matches buf
    static void
    CellUtil.setSequenceId(org.apache.hadoop.hbase.Cell cell, long seqId)
    Deprecated.
    As of HBase-2.0.
    static void
    PrivateCellUtil.setSequenceId(org.apache.hadoop.hbase.Cell cell, long seqId)
    Sets the given seqId to the cell.
    static void
    CellUtil.setTimestamp(org.apache.hadoop.hbase.Cell cell, byte[] ts, int tsOffset)
    Deprecated.
    As of HBase-2.0.
    static void
    CellUtil.setTimestamp(org.apache.hadoop.hbase.Cell cell, long ts)
    Deprecated.
    As of HBase-2.0.
    static void
    PrivateCellUtil.setTimestamp(org.apache.hadoop.hbase.Cell cell, byte[] ts)
    Sets the given timestamp to the cell.
    static void
    PrivateCellUtil.setTimestamp(org.apache.hadoop.hbase.Cell cell, long ts)
    Sets the given timestamp to the cell.
    static Iterator<org.apache.hadoop.hbase.Tag>
    PrivateCellUtil.tagsIterator(org.apache.hadoop.hbase.Cell cell)
    Utility method to iterate through the tags in the given cell.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.toNewKeyCell(org.apache.hadoop.hbase.Cell cell)
    Copies the key to a new KeyValue
    static String
    CellUtil.toString(org.apache.hadoop.hbase.Cell cell, boolean verbose)
    Returns a string representation of the cell
    static boolean
    CellUtil.updateLatestStamp(org.apache.hadoop.hbase.Cell cell, byte[] ts, int tsOffset)
    Deprecated.
    As of HBase-2.0.
    static boolean
    CellUtil.updateLatestStamp(org.apache.hadoop.hbase.Cell cell, long ts)
    Deprecated.
    As of HBase-2.0.
    static boolean
    PrivateCellUtil.updateLatestStamp(org.apache.hadoop.hbase.Cell cell, byte[] ts)
    Sets the given timestamp to the cell iff current timestamp is HConstants.LATEST_TIMESTAMP.
    static boolean
    PrivateCellUtil.updateLatestStamp(org.apache.hadoop.hbase.Cell cell, long ts)
    Sets the given timestamp to the cell iff current timestamp is HConstants.LATEST_TIMESTAMP.
    static int
    PrivateCellUtil.writeCell(org.apache.hadoop.hbase.Cell cell, OutputStream out, boolean withTags)
    Writes the cell to the given OutputStream
    static void
    PrivateCellUtil.writeCellToBuffer(org.apache.hadoop.hbase.Cell cell, ByteBuffer buf, int offset)
    Writes a cell to the buffer at the given offset
    static void
    PrivateCellUtil.writeFamily(OutputStream out, org.apache.hadoop.hbase.Cell cell, byte flength)
    Writes the family from the given cell to the output stream
    static void
    CellUtil.writeFlatKey(org.apache.hadoop.hbase.Cell cell, DataOutputStream out)
    Deprecated.
    As of HBase-2.0.
    static void
    PrivateCellUtil.writeFlatKey(org.apache.hadoop.hbase.Cell cell, DataOutput out)
    Writes the Cell's key part as it would have serialized in a KeyValue.
    static int
    PrivateCellUtil.writeFlatKey(org.apache.hadoop.hbase.Cell cell, OutputStream out)
     
    static void
    PrivateCellUtil.writeQualifier(OutputStream out, org.apache.hadoop.hbase.Cell cell, int qlength)
    Writes the qualifier from the given cell to the output stream
    static void
    PrivateCellUtil.writeQualifierSkippingBytes(DataOutputStream out, org.apache.hadoop.hbase.Cell cell, int qlength, int commonPrefix)
    Writes the qualifier from the given cell to the output stream excluding the common prefix
    static void
    PrivateCellUtil.writeRow(OutputStream out, org.apache.hadoop.hbase.Cell cell, short rlength)
    Writes the row from the given cell to the output stream
    static void
    CellUtil.writeRowKeyExcludingCommon(org.apache.hadoop.hbase.Cell cell, short rLen, int commonPrefix, DataOutputStream out)
    Deprecated.
    As of HBase-2.0.
    static void
    PrivateCellUtil.writeRowKeyExcludingCommon(org.apache.hadoop.hbase.Cell cell, short rLen, int commonPrefix, DataOutputStream out)
    Write rowkey excluding the common part.
    static void
    CellUtil.writeRowSkippingBytes(DataOutputStream out, org.apache.hadoop.hbase.Cell cell, short rlength, int commonPrefix)
    Deprecated.
    As of 2.0.
    static void
    PrivateCellUtil.writeRowSkippingBytes(DataOutputStream out, org.apache.hadoop.hbase.Cell cell, short rlength, int commonPrefix)
    Writes the row from the given cell to the output stream excluding the common prefix
    static void
    PrivateCellUtil.writeTags(OutputStream out, org.apache.hadoop.hbase.Cell cell, int tagsLength)
    Writes the tag from the given cell to the output stream
    static void
    PrivateCellUtil.writeValue(OutputStream out, org.apache.hadoop.hbase.Cell cell, int vlength)
    Writes the value from the given cell to the output stream
    Method parameters in org.apache.hadoop.hbase with type arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    static void
    CellUtil.cloneIfNecessary(ArrayList<org.apache.hadoop.hbase.Cell> cells)
     
    static boolean
    KeyValueTestUtil.containsIgnoreMvccVersion(Collection<? extends org.apache.hadoop.hbase.Cell> kvCollection1, Collection<? extends org.apache.hadoop.hbase.Cell> kvCollection2)
    Checks whether KeyValues from kvCollection2 are contained in kvCollection1.
    static org.apache.hadoop.hbase.CellScanner
    CellUtil.createCellScanner(Iterable<org.apache.hadoop.hbase.Cell> cellIterable)
    Returns CellScanner interface over cellIterable
    static org.apache.hadoop.hbase.CellScanner
    CellUtil.createCellScanner(Iterator<org.apache.hadoop.hbase.Cell> cells)
    Returns CellScanner interface over cellIterable or null if cells is null
    static org.apache.hadoop.hbase.CellScanner
    CellUtil.createCellScanner(NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>> map)
    Flatten the map of cells out under the CellScanner
    static List<org.apache.hadoop.hbase.KeyValue>
    KeyValueUtil.ensureKeyValues(List<org.apache.hadoop.hbase.Cell> cells)
    Deprecated.
    static String
    CellUtil.getCellKeyAsString(org.apache.hadoop.hbase.Cell cell, Function<org.apache.hadoop.hbase.Cell,String> rowConverter)
    Return the Key portion of the passed cell as a String.
    Constructors in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier
    Constructor
    Description
     
    KeyValue(org.apache.hadoop.hbase.Cell c)
     
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.client

    Fields in org.apache.hadoop.hbase.client with type parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Field
    Description
    protected NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>>
    Mutation.familyMap
     
    Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.Cell
    Result.current()
     
    org.apache.hadoop.hbase.Cell
    Result.getColumnLatestCell(byte[] family, byte[] qualifier)
    The Cell for the most recent timestamp for a given column.
    org.apache.hadoop.hbase.Cell
    Result.getColumnLatestCell(byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength)
    The Cell for the most recent timestamp for a given column.
    org.apache.hadoop.hbase.Cell[]
    Result.rawCells()
    Return the array of Cells backing this Result instance.
    Methods in org.apache.hadoop.hbase.client that return types with arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    List<org.apache.hadoop.hbase.Cell>
    Mutation.get(byte[] family, byte[] qualifier)
    Returns a list of all KeyValue objects with matching column family and qualifier.
    List<org.apache.hadoop.hbase.Cell>
    Result.getColumnCells(byte[] family, byte[] qualifier)
    Return the Cells for the specific column.
    NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>>
    Mutation.getFamilyCellMap()
    Method for retrieving the put's familyMap
    List<org.apache.hadoop.hbase.Cell>
    Result.listCells()
    Create a sorted list of the Cell's in this result.
    Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.client.Append
    Append.add(org.apache.hadoop.hbase.Cell cell)
    Add column and value to this Append operation.
    org.apache.hadoop.hbase.client.Delete
    Delete.add(org.apache.hadoop.hbase.Cell cell)
    Add an existing delete marker to this Delete object.
    org.apache.hadoop.hbase.client.Increment
    Increment.add(org.apache.hadoop.hbase.Cell cell)
    Add the specified KeyValue to this operation.
    org.apache.hadoop.hbase.client.Put
    Put.add(org.apache.hadoop.hbase.Cell cell)
    Add the specified KeyValue to this Put operation.
    org.apache.hadoop.hbase.client.Delete
    Delete.addDeleteMarker(org.apache.hadoop.hbase.Cell kv)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    protected int
    Result.binarySearch(org.apache.hadoop.hbase.Cell[] kvs, byte[] family, byte[] qualifier)
     
    protected int
    Result.binarySearch(org.apache.hadoop.hbase.Cell[] kvs, byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength)
    Searches for the latest value for the specified column.
    static org.apache.hadoop.hbase.client.Result
    Result.create(org.apache.hadoop.hbase.Cell[] cells)
    Instantiate a Result with the specified array of KeyValues.
    static org.apache.hadoop.hbase.client.Result
    Result.create(org.apache.hadoop.hbase.Cell[] cells, Boolean exists, boolean stale)
     
    static org.apache.hadoop.hbase.client.Result
    Result.create(org.apache.hadoop.hbase.Cell[] cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow)
     
    Method parameters in org.apache.hadoop.hbase.client with type arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.client.Result
    Result.create(List<org.apache.hadoop.hbase.Cell> cells)
    Instantiate a Result with the specified List of KeyValues.
    static org.apache.hadoop.hbase.client.Result
    Result.create(List<org.apache.hadoop.hbase.Cell> cells, Boolean exists)
     
    static org.apache.hadoop.hbase.client.Result
    Result.create(List<org.apache.hadoop.hbase.Cell> cells, Boolean exists, boolean stale)
     
    static org.apache.hadoop.hbase.client.Result
    Result.create(List<org.apache.hadoop.hbase.Cell> cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow)
     
    org.apache.hadoop.hbase.client.Append
    Append.setFamilyCellMap(NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>> map)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.client.Delete
    Delete.setFamilyCellMap(NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>> map)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.client.Increment
    Increment.setFamilyCellMap(NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>> map)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.client.Mutation
    Mutation.setFamilyCellMap(NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>> map)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.client.Put
    Put.setFamilyCellMap(NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>> map)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    Constructor parameters in org.apache.hadoop.hbase.client with type arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier
    Constructor
    Description
     
    Append(byte[] row, long ts, NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>> familyMap)
    Construct the Append with user defined data.
     
    Delete(byte[] row, long ts, NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>> familyMap)
    Construct the Delete with user defined data.
     
    Increment(byte[] row, long ts, NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>> familyMap)
    Construct the Increment with user defined data.
    protected
    Mutation(byte[] row, long ts, NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>> familyMap)
    Construct the mutation with user defined data.
     
    Put(byte[] row, long ts, NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>> familyMap)
    Construct the Put with user defined data.
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.codec

    Fields in org.apache.hadoop.hbase.codec declared as org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Field
    Description
    protected org.apache.hadoop.hbase.Cell
    KeyValueCodec.ByteBuffKeyValueDecoder.current
     
    Methods in org.apache.hadoop.hbase.codec that return org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    protected org.apache.hadoop.hbase.Cell
    KeyValueCodec.ByteBuffKeyValueDecoder.createCell(byte[] buf, int offset, int len)
     
    protected org.apache.hadoop.hbase.Cell
    KeyValueCodec.ByteBuffKeyValueDecoder.createCell(ByteBuffer bb, int pos, int len)
     
    protected org.apache.hadoop.hbase.Cell
    KeyValueCodecWithTags.ByteBuffKeyValueDecoder.createCell(byte[] buf, int offset, int len)
     
    protected org.apache.hadoop.hbase.Cell
    KeyValueCodecWithTags.ByteBuffKeyValueDecoder.createCell(ByteBuffer bb, int pos, int len)
     
    org.apache.hadoop.hbase.Cell
    BaseDecoder.current()
     
    org.apache.hadoop.hbase.Cell
    KeyValueCodec.ByteBuffKeyValueDecoder.current()
     
    protected abstract org.apache.hadoop.hbase.Cell
    BaseDecoder.parseCell()
    Extract a Cell.
    protected org.apache.hadoop.hbase.Cell
    KeyValueCodec.KeyValueDecoder.parseCell()
     
    protected org.apache.hadoop.hbase.Cell
    KeyValueCodecWithTags.KeyValueDecoder.parseCell()
     
    Methods in org.apache.hadoop.hbase.codec with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    abstract void
    BaseEncoder.write(org.apache.hadoop.hbase.Cell cell)
     
    void
    KeyValueCodec.KeyValueEncoder.write(org.apache.hadoop.hbase.Cell cell)
     
    void
    KeyValueCodecWithTags.KeyValueEncoder.write(org.apache.hadoop.hbase.Cell cell)
     
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.coprocessor

    Methods in org.apache.hadoop.hbase.coprocessor that return org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    default org.apache.hadoop.hbase.Cell
    RegionObserver.postMutationBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType opType, org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell oldCell, org.apache.hadoop.hbase.Cell newCell)
    Deprecated.
    since 2.2.0 and will be removedin 4.0.0.
    Methods in org.apache.hadoop.hbase.coprocessor that return types with arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    RegionObserver.postAppendBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> cellPairs)
    Called after a list of new cells has been created during an append operation, but before they are committed to the WAL or memstore.
    default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    RegionObserver.postAppendBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> cellPairs)
    Called after a list of new cells has been created during an append operation, but before they are committed to the WAL or memstore.
    default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    RegionObserver.postIncrementBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> cellPairs)
    Called after a list of new cells has been created during an increment operation, but before they are committed to the WAL or memstore.
    default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    RegionObserver.postIncrementBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> cellPairs)
    Called after a list of new cells has been created during an increment operation, but before they are committed to the WAL or memstore.
    Methods in org.apache.hadoop.hbase.coprocessor with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    abstract T
    ColumnInterpreter.getValue(byte[] colFamily, byte[] colQualifier, org.apache.hadoop.hbase.Cell c)
    Returns value of type T
    default org.apache.hadoop.hbase.Cell
    RegionObserver.postMutationBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType opType, org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell oldCell, org.apache.hadoop.hbase.Cell newCell)
    Deprecated.
    since 2.2.0 and will be removedin 4.0.0.
    default boolean
    RegionObserver.postScannerFilterRow(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.regionserver.InternalScanner s, org.apache.hadoop.hbase.Cell curRowCell, boolean hasMore)
    This will be called by the scan flow when the current scanned row is being filtered out by the filter.
    default void
    RegionObserver.prePrepareTimeStampForDeleteVersion(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell cell, byte[] byteNow, org.apache.hadoop.hbase.client.Get get)
    Deprecated.
    Since hbase-2.0.0.
    Method parameters in org.apache.hadoop.hbase.coprocessor with type arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    RegionObserver.postAppendBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> cellPairs)
    Called after a list of new cells has been created during an append operation, but before they are committed to the WAL or memstore.
    default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    RegionObserver.postAppendBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> cellPairs)
    Called after a list of new cells has been created during an append operation, but before they are committed to the WAL or memstore.
    default void
    RegionObserver.postGetOp(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> result)
    Called after the client performs a Get
    default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    RegionObserver.postIncrementBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> cellPairs)
    Called after a list of new cells has been created during an increment operation, but before they are committed to the WAL or memstore.
    default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    RegionObserver.postIncrementBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> cellPairs)
    Called after a list of new cells has been created during an increment operation, but before they are committed to the WAL or memstore.
    default void
    RegionObserver.preGetOp(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> result)
    Called before the client performs a Get
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.filter

    Methods in org.apache.hadoop.hbase.filter that return org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.Cell
    ColumnPaginationFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    ColumnPrefixFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    ColumnRangeFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell)
     
    abstract org.apache.hadoop.hbase.Cell
    Filter.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell)
    If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is the next key it must seek to.
    org.apache.hadoop.hbase.Cell
    FilterBase.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell)
    Filters that are not sure which key must be next seeked to, can inherit this implementation that, by default, returns a null Cell.
    org.apache.hadoop.hbase.Cell
    FilterList.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell)
     
    org.apache.hadoop.hbase.Cell
    FilterListWithAND.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell)
     
    org.apache.hadoop.hbase.Cell
    FilterListWithOR.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell)
     
    org.apache.hadoop.hbase.Cell
    FilterWrapper.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell)
     
    org.apache.hadoop.hbase.Cell
    FuzzyRowFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell)
     
    org.apache.hadoop.hbase.Cell
    MultipleColumnPrefixFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    MultiRowRangeFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentKV)
     
    org.apache.hadoop.hbase.Cell
    TimestampsFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell)
    Pick the next cell that the scanner should seek to.
    abstract org.apache.hadoop.hbase.Cell
    Filter.transformCell(org.apache.hadoop.hbase.Cell v)
    Give the filter a chance to transform the passed KeyValue.
    org.apache.hadoop.hbase.Cell
    FilterBase.transformCell(org.apache.hadoop.hbase.Cell v)
    By default no transformation takes place Give the filter a chance to transform the passed KeyValue.
    org.apache.hadoop.hbase.Cell
    FilterList.transformCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.Cell
    FilterListBase.transformCell(org.apache.hadoop.hbase.Cell c)
    For FilterList, we can consider a filter list as a node in a tree.
    org.apache.hadoop.hbase.Cell
    FilterWrapper.transformCell(org.apache.hadoop.hbase.Cell v)
     
    org.apache.hadoop.hbase.Cell
    KeyOnlyFilter.transformCell(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    SkipFilter.transformCell(org.apache.hadoop.hbase.Cell v)
     
    org.apache.hadoop.hbase.Cell
    WhileMatchFilter.transformCell(org.apache.hadoop.hbase.Cell v)
     
    Methods in org.apache.hadoop.hbase.filter with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    protected int
    FilterListBase.compareCell(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b)
     
    protected boolean
    CompareFilter.compareFamily(org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell)
     
    protected boolean
    CompareFilter.compareFamily(org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    Since 2.0.0.
    protected boolean
    CompareFilter.compareQualifier(org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell)
     
    protected boolean
    CompareFilter.compareQualifier(org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    Since 2.0.0.
    protected boolean
    CompareFilter.compareRow(org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell)
     
    protected boolean
    CompareFilter.compareRow(org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    Since 2.0.0.
    protected boolean
    CompareFilter.compareValue(org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell)
     
    protected boolean
    CompareFilter.compareValue(org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    Since 2.0.0.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    ColumnCountGetFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    ColumnPaginationFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    ColumnPrefixFilter.filterCell(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    ColumnRangeFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    ColumnValueFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    DependentColumnFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    FamilyFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    Filter.filterCell(org.apache.hadoop.hbase.Cell c)
    A way to filter based on the column family, column qualifier and/or the column value.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    FilterList.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    FilterListWithAND.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    FilterListWithOR.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    FilterWrapper.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    FirstKeyOnlyFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    FirstKeyValueMatchingQualifiersFilter.filterCell(org.apache.hadoop.hbase.Cell c)
    Deprecated.
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    FuzzyRowFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    InclusiveStopFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    KeyOnlyFilter.filterCell(org.apache.hadoop.hbase.Cell ignored)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    MultipleColumnPrefixFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    MultiRowRangeFilter.filterCell(org.apache.hadoop.hbase.Cell ignored)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    PageFilter.filterCell(org.apache.hadoop.hbase.Cell ignored)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    PrefixFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    QualifierFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    RandomRowFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    RowFilter.filterCell(org.apache.hadoop.hbase.Cell v)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    SingleColumnValueFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    SkipFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    TimestampsFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    ValueFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    WhileMatchFilter.filterCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    ColumnPrefixFilter.filterColumn(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    MultipleColumnPrefixFilter.filterColumn(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    ColumnCountGetFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    ColumnPaginationFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    ColumnPrefixFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    ColumnRangeFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    DependentColumnFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    FamilyFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    Filter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    FilterList.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    FilterListBase.filterKeyValue(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    FilterWrapper.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    FirstKeyOnlyFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    FirstKeyValueMatchingQualifiersFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    FuzzyRowFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    InclusiveStopFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    KeyOnlyFilter.filterKeyValue(org.apache.hadoop.hbase.Cell ignored)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    MultipleColumnPrefixFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    MultiRowRangeFilter.filterKeyValue(org.apache.hadoop.hbase.Cell ignored)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    PageFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    PrefixFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    QualifierFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    RandomRowFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    RowFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    SingleColumnValueFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    SkipFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    TimestampsFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    ValueFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    org.apache.hadoop.hbase.filter.Filter.ReturnCode
    WhileMatchFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c)
    Deprecated.
    boolean
    ColumnCountGetFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    ColumnPaginationFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    ColumnPrefixFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    ColumnRangeFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    ColumnValueFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    CompareFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell)
     
    abstract boolean
    Filter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell)
    Filters a row based on the row key.
    boolean
    FilterBase.filterRowKey(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    FilterList.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell)
     
    boolean
    FilterListWithAND.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell)
     
    boolean
    FilterListWithOR.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell)
     
    boolean
    FilterWrapper.filterRowKey(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    FirstKeyOnlyFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    InclusiveStopFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell)
     
    boolean
    KeyOnlyFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    MultipleColumnPrefixFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    MultiRowRangeFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell)
     
    boolean
    PageFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    PrefixFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell)
     
    boolean
    RandomRowFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell)
     
    boolean
    RowFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell)
     
    boolean
    SingleColumnValueFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    SkipFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    TimestampsFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    WhileMatchFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    ColumnPaginationFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    ColumnPrefixFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    ColumnRangeFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell)
     
    abstract org.apache.hadoop.hbase.Cell
    Filter.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell)
    If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is the next key it must seek to.
    org.apache.hadoop.hbase.Cell
    FilterBase.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell)
    Filters that are not sure which key must be next seeked to, can inherit this implementation that, by default, returns a null Cell.
    org.apache.hadoop.hbase.Cell
    FilterList.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell)
     
    org.apache.hadoop.hbase.Cell
    FilterListWithAND.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell)
     
    org.apache.hadoop.hbase.Cell
    FilterListWithOR.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell)
     
    org.apache.hadoop.hbase.Cell
    FilterWrapper.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell)
     
    org.apache.hadoop.hbase.Cell
    FuzzyRowFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell)
     
    org.apache.hadoop.hbase.Cell
    MultipleColumnPrefixFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    MultiRowRangeFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentKV)
     
    org.apache.hadoop.hbase.Cell
    TimestampsFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell)
    Pick the next cell that the scanner should seek to.
    abstract org.apache.hadoop.hbase.Cell
    Filter.transformCell(org.apache.hadoop.hbase.Cell v)
    Give the filter a chance to transform the passed KeyValue.
    org.apache.hadoop.hbase.Cell
    FilterBase.transformCell(org.apache.hadoop.hbase.Cell v)
    By default no transformation takes place Give the filter a chance to transform the passed KeyValue.
    org.apache.hadoop.hbase.Cell
    FilterList.transformCell(org.apache.hadoop.hbase.Cell c)
     
    org.apache.hadoop.hbase.Cell
    FilterListBase.transformCell(org.apache.hadoop.hbase.Cell c)
    For FilterList, we can consider a filter list as a node in a tree.
    org.apache.hadoop.hbase.Cell
    FilterWrapper.transformCell(org.apache.hadoop.hbase.Cell v)
     
    org.apache.hadoop.hbase.Cell
    KeyOnlyFilter.transformCell(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    SkipFilter.transformCell(org.apache.hadoop.hbase.Cell v)
     
    org.apache.hadoop.hbase.Cell
    WhileMatchFilter.transformCell(org.apache.hadoop.hbase.Cell v)
     
    Method parameters in org.apache.hadoop.hbase.filter with type arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    void
    DependentColumnFilter.filterRowCells(List<org.apache.hadoop.hbase.Cell> kvs)
     
    abstract void
    Filter.filterRowCells(List<org.apache.hadoop.hbase.Cell> kvs)
    Chance to alter the list of Cells to be submitted.
    void
    FilterBase.filterRowCells(List<org.apache.hadoop.hbase.Cell> ignored)
    Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
    void
    FilterList.filterRowCells(List<org.apache.hadoop.hbase.Cell> cells)
    Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
    void
    FilterListBase.filterRowCells(List<org.apache.hadoop.hbase.Cell> cells)
    Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.
    void
    FilterWrapper.filterRowCells(List<org.apache.hadoop.hbase.Cell> kvs)
     
    void
    SingleColumnValueExcludeFilter.filterRowCells(List<org.apache.hadoop.hbase.Cell> kvs)
     
    org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
    FilterWrapper.filterRowCellsWithRet(List<org.apache.hadoop.hbase.Cell> kvs)
     
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.io

    Methods in org.apache.hadoop.hbase.io that return types with arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    Optional<org.apache.hadoop.hbase.Cell>
    HalfStoreFileReader.getFirstKey()
     
    Optional<org.apache.hadoop.hbase.Cell>
    HalfStoreFileReader.getLastKey()
     
    Optional<org.apache.hadoop.hbase.Cell>
    HalfStoreFileReader.midKey()
     
    Methods in org.apache.hadoop.hbase.io with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    void
    CellOutputStream.write(org.apache.hadoop.hbase.Cell cell)
    Implementation must copy the entire state of the Cell.
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.io.encoding

    Fields in org.apache.hadoop.hbase.io.encoding declared as org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Field
    Description
    protected org.apache.hadoop.hbase.Cell
    EncodingState.prevCell
    The previous Cell the encoder encoded.
    Methods in org.apache.hadoop.hbase.io.encoding that return org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    protected org.apache.hadoop.hbase.Cell
    AbstractDataBlockEncoder.createFirstKeyCell(ByteBuffer key, int keyLength)
     
    org.apache.hadoop.hbase.Cell
    DataBlockEncoder.EncodedSeeker.getCell()
    Returns the Cell at the current position.
    org.apache.hadoop.hbase.Cell
    RowIndexSeekerV1.getCell()
     
    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)
     
    org.apache.hadoop.hbase.Cell
    DataBlockEncoder.EncodedSeeker.getKey()
    From the current position creates a cell using the key part of the current buffer
    org.apache.hadoop.hbase.Cell
    RowIndexSeekerV1.getKey()
     
    Methods in org.apache.hadoop.hbase.io.encoding that return types with arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    Iterator<org.apache.hadoop.hbase.Cell>
    EncodedDataBlock.getIterator(int headerSize)
    Provides access to compressed value.
    Methods in org.apache.hadoop.hbase.io.encoding with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    protected boolean
    RowIndexEncoderV1.checkRow(org.apache.hadoop.hbase.Cell cell)
     
    int
    DataBlockEncoder.EncodedSeeker.compareKey(CellComparator comparator, org.apache.hadoop.hbase.Cell key)
    Compare the given key against the current key
    int
    RowIndexSeekerV1.compareKey(CellComparator comparator, org.apache.hadoop.hbase.Cell key)
     
    void
    DataBlockEncoder.encode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext encodingCtx, DataOutputStream out)
    Encodes a KeyValue.
    void
    RowIndexCodecV1.encode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext encodingCtx, DataOutputStream out)
     
    int
    CopyKeyDataBlockEncoder.internalEncode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out)
     
    int
    DiffKeyDeltaEncoder.internalEncode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out)
     
    int
    FastDiffDeltaEncoder.internalEncode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out)
     
    int
    PrefixKeyDeltaEncoder.internalEncode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out)
     
    int
    DataBlockEncoder.EncodedSeeker.seekToKeyInBlock(org.apache.hadoop.hbase.Cell key, boolean seekBefore)
    Moves the seeker position within the current block to: the last key that that is less than or equal to the given key if seekBefore is false the last key that is strictly less than the given key if seekBefore is true.
    int
    RowIndexSeekerV1.seekToKeyInBlock(org.apache.hadoop.hbase.Cell seekCell, boolean seekBefore)
     
    int
    NoneEncoder.write(org.apache.hadoop.hbase.Cell cell)
     
    void
    RowIndexEncoderV1.write(org.apache.hadoop.hbase.Cell cell)
     
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.io.hfile

    Fields in org.apache.hadoop.hbase.io.hfile declared as org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Field
    Description
    protected org.apache.hadoop.hbase.Cell
    HFileWriterImpl.firstCellInBlock
    First cell in a block.
    protected org.apache.hadoop.hbase.Cell
    HFileWriterImpl.lastCell
    The Cell previously appended.
    protected org.apache.hadoop.hbase.Cell
    HFileReaderImpl.HFileScannerImpl.nextIndexedKey
    The next indexed key is to keep track of the indexed key of the next data block.
    Methods in org.apache.hadoop.hbase.io.hfile that return org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.Cell
    HFileReaderImpl.EncodedScanner.getCell()
     
    org.apache.hadoop.hbase.Cell
    HFileReaderImpl.HFileScannerImpl.getCell()
     
    org.apache.hadoop.hbase.Cell
    HFileScanner.getCell()
    Returns Instance of Cell.
    protected org.apache.hadoop.hbase.Cell
    HFileReaderImpl.EncodedScanner.getFirstKeyCellInBlock(org.apache.hadoop.hbase.io.hfile.HFileBlock curBlock)
     
    protected org.apache.hadoop.hbase.Cell
    HFileReaderImpl.HFileScannerImpl.getFirstKeyCellInBlock(org.apache.hadoop.hbase.io.hfile.HFileBlock curBlock)
     
    org.apache.hadoop.hbase.Cell
    HFileReaderImpl.EncodedScanner.getKey()
     
    org.apache.hadoop.hbase.Cell
    HFileReaderImpl.HFileScannerImpl.getKey()
     
    org.apache.hadoop.hbase.Cell
    HFileScanner.getKey()
    Gets the current key in the form of a cell.
    org.apache.hadoop.hbase.Cell
    HFileWriterImpl.getLastCell()
     
    org.apache.hadoop.hbase.Cell
    HFileInfo.getLastKeyCell()
     
    static org.apache.hadoop.hbase.Cell
    HFileWriterImpl.getMidpoint(CellComparator comparator, org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Try to return a Cell that falls between left and right but that is shorter; i.e.
    org.apache.hadoop.hbase.Cell
    BlockWithScanInfo.getNextIndexedKey()
     
    org.apache.hadoop.hbase.Cell
    HFileReaderImpl.HFileScannerImpl.getNextIndexedKey()
     
    org.apache.hadoop.hbase.Cell
    HFileScanner.getNextIndexedKey()
    Returns the next key in the index (the key to seek to the next block)
    org.apache.hadoop.hbase.Cell
    CompoundBloomFilterWriter.getPrevCell()
     
    org.apache.hadoop.hbase.Cell
    HFileIndexBlockEncoder.EncodedSeeker.getRootBlockKey(int i)
     
    org.apache.hadoop.hbase.Cell
    NoOpIndexBlockEncoder.NoOpEncodedSeeker.getRootBlockKey(int i)
     
    org.apache.hadoop.hbase.Cell
    HFileIndexBlockEncoder.EncodedSeeker.midkey(org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader)
     
    org.apache.hadoop.hbase.Cell
    NoOpIndexBlockEncoder.NoOpEncodedSeeker.midkey(org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader)
     
    Methods in org.apache.hadoop.hbase.io.hfile that return types with arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    Optional<org.apache.hadoop.hbase.Cell>
    HFile.Reader.getFirstKey()
     
    Optional<org.apache.hadoop.hbase.Cell>
    HFileReaderImpl.getFirstKey()
     
    Optional<org.apache.hadoop.hbase.Cell>
    HFile.Reader.getLastKey()
     
    Optional<org.apache.hadoop.hbase.Cell>
    HFileReaderImpl.getLastKey()
     
    Optional<org.apache.hadoop.hbase.Cell>
    HFile.Reader.midKey()
     
    Optional<org.apache.hadoop.hbase.Cell>
    HFileReaderImpl.midKey()
     
    Methods in org.apache.hadoop.hbase.io.hfile with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    void
    CompoundBloomFilterWriter.append(org.apache.hadoop.hbase.Cell cell)
     
    void
    HFileWriterImpl.append(org.apache.hadoop.hbase.Cell cell)
    Add key/value to file.
    protected int
    HFileReaderImpl.HFileScannerImpl.blockSeek(org.apache.hadoop.hbase.Cell key, boolean seekBefore)
    Within a loaded block, seek looking for the last key that is smaller than (or equal to?) the key we are interested in.
    protected boolean
    HFileWriterImpl.checkKey(org.apache.hadoop.hbase.Cell cell)
    Checks that the given Cell's key does not violate the key order.
    int
    HFileReaderImpl.EncodedScanner.compareKey(CellComparator comparator, org.apache.hadoop.hbase.Cell key)
     
    int
    HFileReaderImpl.HFileScannerImpl.compareKey(CellComparator comparator, org.apache.hadoop.hbase.Cell key)
     
    boolean
    CompoundBloomFilter.contains(org.apache.hadoop.hbase.Cell keyCell, org.apache.hadoop.hbase.nio.ByteBuff bloom, org.apache.hadoop.hbase.regionserver.BloomType type)
     
    void
    HFileDataBlockEncoder.encode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext encodingCtx, DataOutputStream out)
    Encodes a KeyValue.
    void
    HFileDataBlockEncoderImpl.encode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext encodingCtx, DataOutputStream out)
     
    void
    NoOpDataBlockEncoder.encode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext encodingCtx, DataOutputStream out)
     
    static org.apache.hadoop.hbase.Cell
    HFileWriterImpl.getMidpoint(CellComparator comparator, org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Try to return a Cell that falls between left and right but that is shorter; i.e.
    protected int
    HFileReaderImpl.EncodedScanner.loadBlockAndSeekToKey(org.apache.hadoop.hbase.io.hfile.HFileBlock seekToBlock, org.apache.hadoop.hbase.Cell nextIndexedKey, boolean rewind, org.apache.hadoop.hbase.Cell key, boolean seekBefore)
     
    protected int
    HFileReaderImpl.HFileScannerImpl.loadBlockAndSeekToKey(org.apache.hadoop.hbase.io.hfile.HFileBlock seekToBlock, org.apache.hadoop.hbase.Cell nextIndexedKey, boolean rewind, org.apache.hadoop.hbase.Cell key, boolean seekBefore)
     
    org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
    HFileIndexBlockEncoder.EncodedSeeker.loadDataBlockWithScanInfo(org.apache.hadoop.hbase.Cell key, org.apache.hadoop.hbase.io.hfile.HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding expectedDataBlockEncoding, org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader)
     
    org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
    NoOpIndexBlockEncoder.NoOpEncodedSeeker.loadDataBlockWithScanInfo(org.apache.hadoop.hbase.Cell key, org.apache.hadoop.hbase.io.hfile.HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding expectedDataBlockEncoding, org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader)
     
    int
    HFileReaderImpl.HFileScannerImpl.reseekTo(org.apache.hadoop.hbase.Cell key)
     
    int
    HFileScanner.reseekTo(org.apache.hadoop.hbase.Cell cell)
    Reseek to or just before the passed cell.
    int
    HFileIndexBlockEncoder.EncodedSeeker.rootBlockContainingKey(org.apache.hadoop.hbase.Cell key)
     
    int
    NoOpIndexBlockEncoder.NoOpEncodedSeeker.rootBlockContainingKey(org.apache.hadoop.hbase.Cell key)
     
    boolean
    HFileReaderImpl.HFileScannerImpl.seekBefore(org.apache.hadoop.hbase.Cell key)
     
    boolean
    HFileScanner.seekBefore(org.apache.hadoop.hbase.Cell cell)
    Consider the cell stream of all the cells in the file, c[0] ..
    int
    HFileReaderImpl.HFileScannerImpl.seekTo(org.apache.hadoop.hbase.Cell key)
     
    int
    HFileReaderImpl.HFileScannerImpl.seekTo(org.apache.hadoop.hbase.Cell key, boolean rewind)
    An internal API function.
    int
    HFileScanner.seekTo(org.apache.hadoop.hbase.Cell cell)
    SeekTo or just before the passed cell.
    Constructors in org.apache.hadoop.hbase.io.hfile with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier
    Constructor
    Description
     
    BlockWithScanInfo(org.apache.hadoop.hbase.io.hfile.HFileBlock hFileBlock, org.apache.hadoop.hbase.Cell nextIndexedKey)
     
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.mapreduce

    Methods in org.apache.hadoop.hbase.mapreduce that return org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.Cell
    CellCreator.create(byte[] row, int roffset, int rlength, byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength, long timestamp, byte[] value, int voffset, int vlength)
     
    org.apache.hadoop.hbase.Cell
    CellCreator.create(byte[] row, int roffset, int rlength, byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength, long timestamp, byte[] value, int voffset, int vlength, String visExpression)
    Deprecated.
    since 0.98.9
    org.apache.hadoop.hbase.Cell
    CellCreator.create(byte[] row, int roffset, int rlength, byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength, long timestamp, byte[] value, int voffset, int vlength, List<org.apache.hadoop.hbase.Tag> tags)
     
    static org.apache.hadoop.hbase.Cell
    Import.filterKv(org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.Cell c)
    Attempt to filter out the keyvalue
    Methods in org.apache.hadoop.hbase.mapreduce that return types with arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.io.NullWritable,org.apache.hadoop.hbase.Cell>
    HFileInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context)
     
    org.apache.hadoop.mapreduce.RecordWriter<org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.Cell>
    HFileOutputFormat2.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context)
     
    Methods in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    protected void
    Import.Importer.addPutToKv(org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.Cell kv)
     
    org.apache.hadoop.hbase.KeyValue
    CellSerialization.CellDeserializer.deserialize(org.apache.hadoop.hbase.Cell ignore)
     
    protected boolean
    WALPlayer.WALMapper.filter(org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.wal.WALKey,org.apache.hadoop.hbase.wal.WALEdit,org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.client.Mutation>.org.apache.hadoop.mapreduce.Mapper.Context context, org.apache.hadoop.hbase.Cell cell)
     
    static org.apache.hadoop.hbase.Cell
    Import.filterKv(org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.Cell c)
    Attempt to filter out the keyvalue
    int
    Import.CellWritableComparablePartitioner.getPartition(org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable key, org.apache.hadoop.hbase.Cell value, int numPartitions)
     
    void
    CellSerialization.CellSerializer.serialize(org.apache.hadoop.hbase.Cell kv)
     
    Method parameters in org.apache.hadoop.hbase.mapreduce with type arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.mapreduce.CellSerialization.CellDeserializer
    CellSerialization.getDeserializer(Class<org.apache.hadoop.hbase.Cell> t)
     
    org.apache.hadoop.hbase.mapreduce.CellSerialization.CellSerializer
    CellSerialization.getSerializer(Class<org.apache.hadoop.hbase.Cell> c)
     
    protected void
    CellSortReducer.reduce(org.apache.hadoop.hbase.io.ImmutableBytesWritable row, Iterable<org.apache.hadoop.hbase.Cell> kvs, org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.Cell>.org.apache.hadoop.mapreduce.Reducer.Context context)
     
    protected void
    Import.CellReducer.reduce(org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable row, Iterable<org.apache.hadoop.hbase.Cell> kvs, org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable,org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.Cell>.org.apache.hadoop.mapreduce.Reducer.Context context)
     
    Constructors in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier
    Constructor
    Description
     
    CellWritableComparable(org.apache.hadoop.hbase.Cell kv)
     
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.mob

    Methods in org.apache.hadoop.hbase.mob that return org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.Cell
    MobUtils.createMobRefCell(org.apache.hadoop.hbase.Cell cell, byte[] fileName, byte[] refCellTags)
     
    static org.apache.hadoop.hbase.Cell
    MobUtils.createMobRefCell(org.apache.hadoop.hbase.Cell cell, byte[] fileName, org.apache.hadoop.hbase.Tag tableNameTag)
    Creates a mob reference KeyValue.
    org.apache.hadoop.hbase.Cell
    MobCell.getCell()
     
    Methods in org.apache.hadoop.hbase.mob with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.Cell
    MobUtils.createMobRefCell(org.apache.hadoop.hbase.Cell cell, byte[] fileName, byte[] refCellTags)
     
    static org.apache.hadoop.hbase.Cell
    MobUtils.createMobRefCell(org.apache.hadoop.hbase.Cell cell, byte[] fileName, org.apache.hadoop.hbase.Tag tableNameTag)
    Creates a mob reference KeyValue.
    static String
    MobUtils.getMobFileName(org.apache.hadoop.hbase.Cell cell)
    Gets the mob file name from the mob ref cell.
    static int
    MobUtils.getMobValueLength(org.apache.hadoop.hbase.Cell cell)
    Gets the mob value length from the mob ref cell.
    static Optional<org.apache.hadoop.hbase.TableName>
    MobUtils.getTableName(org.apache.hadoop.hbase.Cell cell)
    Get the table name from when this cell was written into a mob hfile as a TableName.
    MobUtils.getTableNameString(org.apache.hadoop.hbase.Cell cell)
    Gets the table name from when this cell was written into a mob hfile as a string.
    static boolean
    MobUtils.hasValidMobRefCellValue(org.apache.hadoop.hbase.Cell cell)
    Indicates whether the current mob ref cell has a valid value.
    static boolean
    MobUtils.isMobReferenceCell(org.apache.hadoop.hbase.Cell cell)
    Whether the current cell is a mob reference cell.
    org.apache.hadoop.hbase.mob.MobCell
    MobFile.readCell(org.apache.hadoop.hbase.Cell search, boolean cacheMobBlocks)
    Reads a cell from the mob file.
    org.apache.hadoop.hbase.mob.MobCell
    MobFile.readCell(org.apache.hadoop.hbase.Cell search, boolean cacheMobBlocks, long readPt)
    Reads a cell from the mob file.
    Constructors in org.apache.hadoop.hbase.mob with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier
    Constructor
    Description
     
    MobCell(org.apache.hadoop.hbase.Cell cell)
     
     
    MobCell(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.StoreFileScanner sfScanner)
     
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.quotas

    Methods in org.apache.hadoop.hbase.quotas with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    protected static String
    QuotaTableUtil.extractSnapshotNameFromSizeCell(org.apache.hadoop.hbase.Cell c)
     
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.regionserver

    Classes in org.apache.hadoop.hbase.regionserver that implement org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.regionserver.ByteBufferChunkKeyValue
    ByteBuffer based cell which has the chunkid at the 0th offset
    class 
    org.apache.hadoop.hbase.regionserver.NoTagByteBufferChunkKeyValue
    ByteBuffer based cell which has the chunkid at the 0th offset and with no tags
    Fields in org.apache.hadoop.hbase.regionserver declared as org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Field
    Description
    protected org.apache.hadoop.hbase.Cell
    SegmentScanner.current
     
    static final org.apache.hadoop.hbase.Cell
    KeyValueScanner.NO_NEXT_INDEXED_KEY
    The byte array represents for NO_NEXT_INDEXED_KEY; The actual value is irrelevant because this is always compared by reference.
    Fields in org.apache.hadoop.hbase.regionserver with type parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Field
    Description
    protected Iterator<org.apache.hadoop.hbase.Cell>
    SegmentScanner.iter
     
    Methods in org.apache.hadoop.hbase.regionserver that return org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.Cell
    CellSet.ceiling(org.apache.hadoop.hbase.Cell e)
     
    org.apache.hadoop.hbase.Cell
    CellFlatMap.ceilingKey(org.apache.hadoop.hbase.Cell k)
     
    org.apache.hadoop.hbase.Cell
    ImmutableMemStoreLAB.copyCellInto(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    MemStoreLAB.copyCellInto(org.apache.hadoop.hbase.Cell cell)
    Allocates slice in this LAB and copy the passed Cell into this area.
    org.apache.hadoop.hbase.Cell
    MemStoreLABImpl.copyCellInto(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    CellSet.first()
     
    org.apache.hadoop.hbase.Cell
    CellFlatMap.firstKey()
     
    org.apache.hadoop.hbase.Cell
    CellSet.floor(org.apache.hadoop.hbase.Cell e)
     
    org.apache.hadoop.hbase.Cell
    CellFlatMap.floorKey(org.apache.hadoop.hbase.Cell k)
     
    org.apache.hadoop.hbase.Cell
    ImmutableMemStoreLAB.forceCopyOfBigCellInto(org.apache.hadoop.hbase.Cell cell)
    The process of merging assumes all cells are allocated on mslab.
    org.apache.hadoop.hbase.Cell
    MemStoreLAB.forceCopyOfBigCellInto(org.apache.hadoop.hbase.Cell cell)
    Allocates slice in this LAB and copy the passed Cell into this area.
    org.apache.hadoop.hbase.Cell
    MemStoreLABImpl.forceCopyOfBigCellInto(org.apache.hadoop.hbase.Cell cell)
    When a cell's size is too big (bigger than maxAlloc), copyCellInto does not allocate it on MSLAB.
    org.apache.hadoop.hbase.Cell
    CellFlatMap.get(Object o)
     
    org.apache.hadoop.hbase.Cell
    CellSet.get(org.apache.hadoop.hbase.Cell kv)
     
    protected org.apache.hadoop.hbase.Cell
    CellArrayMap.getCell(int i)
     
    protected org.apache.hadoop.hbase.Cell
    CellChunkMap.getCell(int i)
     
    protected abstract org.apache.hadoop.hbase.Cell
    CellFlatMap.getCell(int i)
     
    protected org.apache.hadoop.hbase.Cell
    AbstractMemStore.getLowest(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b)
     
    org.apache.hadoop.hbase.Cell
    KeyValueHeap.getNextIndexedKey()
     
    org.apache.hadoop.hbase.Cell
    KeyValueScanner.getNextIndexedKey()
     
    org.apache.hadoop.hbase.Cell
    NonLazyKeyValueScanner.getNextIndexedKey()
     
    org.apache.hadoop.hbase.Cell
    SegmentScanner.getNextIndexedKey()
     
    org.apache.hadoop.hbase.Cell
    StoreFileScanner.getNextIndexedKey()
     
    org.apache.hadoop.hbase.Cell
    StoreScanner.getNextIndexedKey()
     
    protected org.apache.hadoop.hbase.Cell
    AbstractMemStore.getNextRow(org.apache.hadoop.hbase.Cell key, NavigableSet<org.apache.hadoop.hbase.Cell> set)
     
    org.apache.hadoop.hbase.Cell
    CellSet.higher(org.apache.hadoop.hbase.Cell e)
     
    org.apache.hadoop.hbase.Cell
    CellFlatMap.higherKey(org.apache.hadoop.hbase.Cell k)
     
    org.apache.hadoop.hbase.Cell
    CellSet.last()
     
    org.apache.hadoop.hbase.Cell
    CompositeImmutableSegment.last()
     
    org.apache.hadoop.hbase.Cell
    Segment.last()
     
    org.apache.hadoop.hbase.Cell
    CellFlatMap.lastKey()
     
    org.apache.hadoop.hbase.Cell
    CellSet.lower(org.apache.hadoop.hbase.Cell e)
     
    org.apache.hadoop.hbase.Cell
    CellFlatMap.lowerKey(org.apache.hadoop.hbase.Cell k)
     
    org.apache.hadoop.hbase.Cell
    CompositeImmutableSegment.maybeCloneWithAllocator(org.apache.hadoop.hbase.Cell cell, boolean forceCloneOfBigCell)
    If the segment has a memory allocator the cell is being cloned to this space, and returned; otherwise the given cell is returned
    org.apache.hadoop.hbase.Cell
    Segment.maybeCloneWithAllocator(org.apache.hadoop.hbase.Cell cell, boolean forceCloneOfBigCell)
    If the segment has a memory allocator the cell is being cloned to this space, and returned; otherwise the given cell is returned When a cell's size is too big (bigger than maxAlloc), it is not allocated on MSLAB.
    org.apache.hadoop.hbase.Cell
    KeyValueHeap.next()
     
    org.apache.hadoop.hbase.Cell
    KeyValueScanner.next()
    Return the next Cell in this scanner, iterating the scanner
    org.apache.hadoop.hbase.Cell
    MemStoreCompactorSegmentsIterator.next()
     
    org.apache.hadoop.hbase.Cell
    MemStoreMergerSegmentsIterator.next()
     
    org.apache.hadoop.hbase.Cell
    ReversedKeyValueHeap.next()
     
    org.apache.hadoop.hbase.Cell
    SegmentScanner.next()
    Return the next Cell in this scanner, iterating the scanner
    org.apache.hadoop.hbase.Cell
    SnapshotSegmentScanner.next()
     
    org.apache.hadoop.hbase.Cell
    StoreFileScanner.next()
     
    org.apache.hadoop.hbase.Cell
    KeyValueHeap.peek()
     
    org.apache.hadoop.hbase.Cell
    KeyValueScanner.peek()
    Look at the next Cell in this scanner, but do not iterate scanner.
    org.apache.hadoop.hbase.Cell
    SegmentScanner.peek()
    Look at the next Cell in this scanner, but do not iterate the scanner
    org.apache.hadoop.hbase.Cell
    SnapshotSegmentScanner.peek()
     
    org.apache.hadoop.hbase.Cell
    StoreFileScanner.peek()
     
    org.apache.hadoop.hbase.Cell
    StoreScanner.peek()
     
    org.apache.hadoop.hbase.Cell
    CellSet.pollFirst()
     
    org.apache.hadoop.hbase.Cell
    CellSet.pollLast()
     
    org.apache.hadoop.hbase.Cell
    CellFlatMap.put(org.apache.hadoop.hbase.Cell k, org.apache.hadoop.hbase.Cell v)
     
    org.apache.hadoop.hbase.Cell
    CellFlatMap.remove(Object o)
     
    Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.ceilingEntry(org.apache.hadoop.hbase.Cell k)
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.ceilingEntry(org.apache.hadoop.hbase.Cell k)
     
    Comparator<? super org.apache.hadoop.hbase.Cell>
    CellFlatMap.comparator()
     
    Comparator<? super org.apache.hadoop.hbase.Cell>
    CellSet.comparator()
     
    Iterator<org.apache.hadoop.hbase.Cell>
    CellSet.descendingIterator()
     
    NavigableSet<org.apache.hadoop.hbase.Cell>
    CellFlatMap.descendingKeySet()
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.descendingMap()
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.descendingMap()
     
    NavigableSet<org.apache.hadoop.hbase.Cell>
    CellSet.descendingSet()
     
    Set<Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    CellFlatMap.entrySet()
     
    Set<Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    CellFlatMap.entrySet()
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.firstEntry()
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.firstEntry()
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.floorEntry(org.apache.hadoop.hbase.Cell k)
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.floorEntry(org.apache.hadoop.hbase.Cell k)
     
    List<org.apache.hadoop.hbase.Cell>
    HRegion.get(org.apache.hadoop.hbase.client.Get get, boolean withCoprocessor)
     
    List<org.apache.hadoop.hbase.Cell>
    Region.get(org.apache.hadoop.hbase.client.Get get, boolean withCoprocessor)
    Do a get based on the get parameter.
    Optional<org.apache.hadoop.hbase.Cell>
    HStoreFile.getFirstKey()
     
    Optional<org.apache.hadoop.hbase.Cell>
    StoreFile.getFirstKey()
    Get the first key in this store file.
    Optional<org.apache.hadoop.hbase.Cell>
    StoreFileReader.getFirstKey()
     
    protected Iterator<org.apache.hadoop.hbase.Cell>
    SegmentScanner.getIterator(org.apache.hadoop.hbase.Cell cell)
     
    Optional<org.apache.hadoop.hbase.Cell>
    HStoreFile.getLastKey()
     
    Optional<org.apache.hadoop.hbase.Cell>
    StoreFile.getLastKey()
    Get the last key in this store file.
    Optional<org.apache.hadoop.hbase.Cell>
    StoreFileReader.getLastKey()
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.headMap(org.apache.hadoop.hbase.Cell k)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.headMap(org.apache.hadoop.hbase.Cell k)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.headMap(org.apache.hadoop.hbase.Cell toKey, boolean inclusive)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.headMap(org.apache.hadoop.hbase.Cell toKey, boolean inclusive)
     
    SortedSet<org.apache.hadoop.hbase.Cell>
    CellSet.headSet(org.apache.hadoop.hbase.Cell toElement)
     
    NavigableSet<org.apache.hadoop.hbase.Cell>
    CellSet.headSet(org.apache.hadoop.hbase.Cell toElement, boolean inclusive)
     
    SortedSet<org.apache.hadoop.hbase.Cell>
    CompositeImmutableSegment.headSet(org.apache.hadoop.hbase.Cell firstKeyOnRow)
     
    SortedSet<org.apache.hadoop.hbase.Cell>
    Segment.headSet(org.apache.hadoop.hbase.Cell firstKeyOnRow)
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.higherEntry(org.apache.hadoop.hbase.Cell k)
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.higherEntry(org.apache.hadoop.hbase.Cell k)
     
    Iterator<org.apache.hadoop.hbase.Cell>
    CellSet.iterator()
     
    Iterator<org.apache.hadoop.hbase.Cell>
    CompositeImmutableSegment.iterator()
     
    Iterator<org.apache.hadoop.hbase.Cell>
    Segment.iterator()
     
    NavigableSet<org.apache.hadoop.hbase.Cell>
    CellFlatMap.keySet()
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.lastEntry()
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.lastEntry()
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.lowerEntry(org.apache.hadoop.hbase.Cell k)
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.lowerEntry(org.apache.hadoop.hbase.Cell k)
     
    Optional<org.apache.hadoop.hbase.Cell>
    StoreFileReader.midKey()
     
    NavigableSet<org.apache.hadoop.hbase.Cell>
    CellFlatMap.navigableKeySet()
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.pollFirstEntry()
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.pollFirstEntry()
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.pollLastEntry()
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.pollLastEntry()
     
    List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    RegionCoprocessorHost.postAppendBeforeWAL(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> cellPairs)
     
    List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    RegionCoprocessorHost.postAppendBeforeWAL(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> cellPairs)
     
    List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    RegionCoprocessorHost.postIncrementBeforeWAL(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> cellPairs)
     
    List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    RegionCoprocessorHost.postIncrementBeforeWAL(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> cellPairs)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.subMap(org.apache.hadoop.hbase.Cell fromKey, boolean fromInclusive, org.apache.hadoop.hbase.Cell toKey, boolean toInclusive)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.subMap(org.apache.hadoop.hbase.Cell fromKey, boolean fromInclusive, org.apache.hadoop.hbase.Cell toKey, boolean toInclusive)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.subMap(org.apache.hadoop.hbase.Cell k1, org.apache.hadoop.hbase.Cell k2)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.subMap(org.apache.hadoop.hbase.Cell k1, org.apache.hadoop.hbase.Cell k2)
     
    NavigableSet<org.apache.hadoop.hbase.Cell>
    CellSet.subSet(org.apache.hadoop.hbase.Cell fromElement, boolean fromInclusive, org.apache.hadoop.hbase.Cell toElement, boolean toInclusive)
     
    SortedSet<org.apache.hadoop.hbase.Cell>
    CellSet.subSet(org.apache.hadoop.hbase.Cell fromElement, org.apache.hadoop.hbase.Cell toElement)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.tailMap(org.apache.hadoop.hbase.Cell k)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.tailMap(org.apache.hadoop.hbase.Cell k)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.tailMap(org.apache.hadoop.hbase.Cell fromKey, boolean inclusive)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.tailMap(org.apache.hadoop.hbase.Cell fromKey, boolean inclusive)
     
    SortedSet<org.apache.hadoop.hbase.Cell>
    CellSet.tailSet(org.apache.hadoop.hbase.Cell fromElement)
     
    NavigableSet<org.apache.hadoop.hbase.Cell>
    CellSet.tailSet(org.apache.hadoop.hbase.Cell fromElement, boolean inclusive)
     
    protected SortedSet<org.apache.hadoop.hbase.Cell>
    CompositeImmutableSegment.tailSet(org.apache.hadoop.hbase.Cell firstCell)
    Returns a subset of the segment cell set, which starts with the given cell
    protected SortedSet<org.apache.hadoop.hbase.Cell>
    Segment.tailSet(org.apache.hadoop.hbase.Cell firstCell)
    Returns a subset of the segment cell set, which starts with the given cell
    Collection<org.apache.hadoop.hbase.Cell>
    CellFlatMap.values()
     
    Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    void
    AbstractMemStore.add(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing)
     
    boolean
    CellSet.add(org.apache.hadoop.hbase.Cell e)
     
    void
    HStore.add(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing)
    Adds a value to the memstore
    void
    MemStore.add(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing)
    Write an update
    void
    MutableSegment.add(org.apache.hadoop.hbase.Cell cell, boolean mslabUsed, org.apache.hadoop.hbase.regionserver.MemStoreSizing memStoreSizing, boolean sizeAddedPreOperation)
    Adds the given cell into the segment
    void
    CellSink.append(org.apache.hadoop.hbase.Cell cell)
    Append the given cell
    void
    DateTieredMultiFileWriter.append(org.apache.hadoop.hbase.Cell cell)
     
    void
    StoreFileWriter.append(org.apache.hadoop.hbase.Cell cell)
     
    void
    StripeMultiFileWriter.BoundaryMultiWriter.append(org.apache.hadoop.hbase.Cell cell)
     
    void
    StripeMultiFileWriter.SizeMultiWriter.append(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    KeyValueScanner.backwardSeek(org.apache.hadoop.hbase.Cell key)
    Seek the scanner at or before the row of specified Cell, it firstly tries to seek the scanner at or after the specified Cell, return if peek KeyValue of scanner has the same row with specified Cell, otherwise seek the scanner at the first Cell of the row which is the previous row of specified KeyValue
    boolean
    NonReversedNonLazyKeyValueScanner.backwardSeek(org.apache.hadoop.hbase.Cell key)
     
    boolean
    ReversedKeyValueHeap.backwardSeek(org.apache.hadoop.hbase.Cell seekKey)
     
    boolean
    ReversedStoreScanner.backwardSeek(org.apache.hadoop.hbase.Cell key)
     
    boolean
    SegmentScanner.backwardSeek(org.apache.hadoop.hbase.Cell key)
    Seek the scanner at or before the row of specified Cell, it firstly tries to seek the scanner at or after the specified Cell, return if peek KeyValue of scanner has the same row with specified Cell, otherwise seek the scanner at the first Cell of the row which is the previous row of specified KeyValue
    boolean
    StoreFileScanner.backwardSeek(org.apache.hadoop.hbase.Cell key)
     
    org.apache.hadoop.hbase.Cell
    CellSet.ceiling(org.apache.hadoop.hbase.Cell e)
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.ceilingEntry(org.apache.hadoop.hbase.Cell k)
     
    org.apache.hadoop.hbase.Cell
    CellFlatMap.ceilingKey(org.apache.hadoop.hbase.Cell k)
     
    protected boolean
    CompactingMemStore.checkAndAddToActiveSize(org.apache.hadoop.hbase.regionserver.MutableSegment currActive, org.apache.hadoop.hbase.Cell cellToAdd, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing)
    Check whether anything need to be done based on the current active set size.
    protected void
    ReversedStoreScanner.checkScanOrder(org.apache.hadoop.hbase.Cell prevKV, org.apache.hadoop.hbase.Cell kv, CellComparator comparator)
     
    protected void
    StoreScanner.checkScanOrder(org.apache.hadoop.hbase.Cell prevKV, org.apache.hadoop.hbase.Cell kv, CellComparator comparator)
    Check whether scan as expected order
    int
    CompositeImmutableSegment.compare(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
     
    int
    KeyValueHeap.KVScannerComparator.compare(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
    Compares two KeyValue
    int
    Segment.compare(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
     
    int
    CompositeImmutableSegment.compareRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
     
    int
    Segment.compareRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right)
     
    org.apache.hadoop.hbase.Cell
    ImmutableMemStoreLAB.copyCellInto(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    MemStoreLAB.copyCellInto(org.apache.hadoop.hbase.Cell cell)
    Allocates slice in this LAB and copy the passed Cell into this area.
    org.apache.hadoop.hbase.Cell
    MemStoreLABImpl.copyCellInto(org.apache.hadoop.hbase.Cell cell)
     
    protected void
    AbstractMemStore.doAdd(org.apache.hadoop.hbase.regionserver.MutableSegment currentActive, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing)
     
    static boolean
    NonLazyKeyValueScanner.doRealSeek(org.apache.hadoop.hbase.regionserver.KeyValueScanner scanner, org.apache.hadoop.hbase.Cell kv, boolean forward)
     
    org.apache.hadoop.hbase.Cell
    CellSet.floor(org.apache.hadoop.hbase.Cell e)
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.floorEntry(org.apache.hadoop.hbase.Cell k)
     
    org.apache.hadoop.hbase.Cell
    CellFlatMap.floorKey(org.apache.hadoop.hbase.Cell k)
     
    org.apache.hadoop.hbase.Cell
    ImmutableMemStoreLAB.forceCopyOfBigCellInto(org.apache.hadoop.hbase.Cell cell)
    The process of merging assumes all cells are allocated on mslab.
    org.apache.hadoop.hbase.Cell
    MemStoreLAB.forceCopyOfBigCellInto(org.apache.hadoop.hbase.Cell cell)
    Allocates slice in this LAB and copy the passed Cell into this area.
    org.apache.hadoop.hbase.Cell
    MemStoreLABImpl.forceCopyOfBigCellInto(org.apache.hadoop.hbase.Cell cell)
    When a cell's size is too big (bigger than maxAlloc), copyCellInto does not allocate it on MSLAB.
    org.apache.hadoop.hbase.Cell
    CellSet.get(org.apache.hadoop.hbase.Cell kv)
     
    protected Iterator<org.apache.hadoop.hbase.Cell>
    SegmentScanner.getIterator(org.apache.hadoop.hbase.Cell cell)
     
    protected org.apache.hadoop.hbase.Cell
    AbstractMemStore.getLowest(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b)
     
    protected org.apache.hadoop.hbase.Cell
    AbstractMemStore.getNextRow(org.apache.hadoop.hbase.Cell key, NavigableSet<org.apache.hadoop.hbase.Cell> set)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.headMap(org.apache.hadoop.hbase.Cell k)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.headMap(org.apache.hadoop.hbase.Cell toKey, boolean inclusive)
     
    SortedSet<org.apache.hadoop.hbase.Cell>
    CellSet.headSet(org.apache.hadoop.hbase.Cell toElement)
     
    NavigableSet<org.apache.hadoop.hbase.Cell>
    CellSet.headSet(org.apache.hadoop.hbase.Cell toElement, boolean inclusive)
     
    SortedSet<org.apache.hadoop.hbase.Cell>
    CompositeImmutableSegment.headSet(org.apache.hadoop.hbase.Cell firstKeyOnRow)
     
    SortedSet<org.apache.hadoop.hbase.Cell>
    Segment.headSet(org.apache.hadoop.hbase.Cell firstKeyOnRow)
     
    protected long
    Segment.heapSizeChange(org.apache.hadoop.hbase.Cell cell, boolean allocated)
     
    org.apache.hadoop.hbase.Cell
    CellSet.higher(org.apache.hadoop.hbase.Cell e)
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.higherEntry(org.apache.hadoop.hbase.Cell k)
     
    org.apache.hadoop.hbase.Cell
    CellFlatMap.higherKey(org.apache.hadoop.hbase.Cell k)
     
    void
    TimeRangeTracker.includeTimestamp(org.apache.hadoop.hbase.Cell cell)
    Update the current TimestampRange to include the timestamp from cell.
    protected void
    CompositeImmutableSegment.internalAdd(org.apache.hadoop.hbase.Cell cell, boolean mslabUsed, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation)
     
    protected void
    Segment.internalAdd(org.apache.hadoop.hbase.Cell cell, boolean mslabUsed, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation)
     
    org.apache.hadoop.hbase.Cell
    CellSet.lower(org.apache.hadoop.hbase.Cell e)
     
    Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.lowerEntry(org.apache.hadoop.hbase.Cell k)
     
    org.apache.hadoop.hbase.Cell
    CellFlatMap.lowerKey(org.apache.hadoop.hbase.Cell k)
     
    org.apache.hadoop.hbase.Cell
    CompositeImmutableSegment.maybeCloneWithAllocator(org.apache.hadoop.hbase.Cell cell, boolean forceCloneOfBigCell)
    If the segment has a memory allocator the cell is being cloned to this space, and returned; otherwise the given cell is returned
    org.apache.hadoop.hbase.Cell
    Segment.maybeCloneWithAllocator(org.apache.hadoop.hbase.Cell cell, boolean forceCloneOfBigCell)
    If the segment has a memory allocator the cell is being cloned to this space, and returned; otherwise the given cell is returned When a cell's size is too big (bigger than maxAlloc), it is not allocated on MSLAB.
    protected long
    Segment.offHeapSizeChange(org.apache.hadoop.hbase.Cell cell, boolean allocated)
     
    boolean
    StoreFileReader.passesGeneralRowColBloomFilter(org.apache.hadoop.hbase.Cell cell)
    A method for checking Bloom filters.
    boolean
    RegionCoprocessorHost.postScannerFilterRow(org.apache.hadoop.hbase.regionserver.InternalScanner s, org.apache.hadoop.hbase.Cell curRowCell)
    This will be called by the scan flow when the current scanned row is being filtered out by the filter.
    boolean
    RegionCoprocessorHost.prePrepareTimeStampForDeleteVersion(org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell kv, byte[] byteNow, org.apache.hadoop.hbase.client.Get get)
    Deprecated.
    In hbase-2.0.0.
    protected abstract boolean
    AbstractMemStore.preUpdate(org.apache.hadoop.hbase.regionserver.MutableSegment currentActive, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing)
    Issue any synchronization and test needed before applying the update
    protected boolean
    CompactingMemStore.preUpdate(org.apache.hadoop.hbase.regionserver.MutableSegment currentActive, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing)
    Issue any synchronization and test needed before applying the update For compacting memstore this means checking the update can increase the size without overflow
    protected boolean
    DefaultMemStore.preUpdate(org.apache.hadoop.hbase.regionserver.MutableSegment currentActive, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing)
     
    org.apache.hadoop.hbase.Cell
    CellFlatMap.put(org.apache.hadoop.hbase.Cell k, org.apache.hadoop.hbase.Cell v)
     
    boolean
    KeyValueHeap.requestSeek(org.apache.hadoop.hbase.Cell key, boolean forward, boolean useBloom)
    Similar to KeyValueScanner.seek(org.apache.hadoop.hbase.Cell) (or KeyValueScanner.reseek(org.apache.hadoop.hbase.Cell) if forward is true) but only does a seek operation after checking that it is really necessary for the row/column combination specified by the kv parameter.
    boolean
    KeyValueScanner.requestSeek(org.apache.hadoop.hbase.Cell kv, boolean forward, boolean useBloom)
    Similar to KeyValueScanner.seek(org.apache.hadoop.hbase.Cell) (or KeyValueScanner.reseek(org.apache.hadoop.hbase.Cell) if forward is true) but only does a seek operation after checking that it is really necessary for the row/column combination specified by the kv parameter.
    boolean
    NonLazyKeyValueScanner.requestSeek(org.apache.hadoop.hbase.Cell kv, boolean forward, boolean useBloom)
     
    boolean
    ReversedKeyValueHeap.requestSeek(org.apache.hadoop.hbase.Cell key, boolean forward, boolean useBloom)
     
    boolean
    SegmentScanner.requestSeek(org.apache.hadoop.hbase.Cell c, boolean forward, boolean useBloom)
     
    boolean
    StoreFileScanner.requestSeek(org.apache.hadoop.hbase.Cell kv, boolean forward, boolean useBloom)
    Pretend we have done a seek but don't do it yet, if possible.
    boolean
    KeyValueHeap.reseek(org.apache.hadoop.hbase.Cell seekKey)
    This function is identical to the KeyValueHeap.seek(Cell) function except that scanner.seek(seekKey) is changed to scanner.reseek(seekKey).
    boolean
    KeyValueScanner.reseek(org.apache.hadoop.hbase.Cell key)
    Reseek the scanner at or after the specified KeyValue.
    boolean
    ReversedKeyValueHeap.reseek(org.apache.hadoop.hbase.Cell seekKey)
     
    boolean
    ReversedStoreScanner.reseek(org.apache.hadoop.hbase.Cell kv)
     
    boolean
    SegmentScanner.reseek(org.apache.hadoop.hbase.Cell cell)
    Reseek the scanner at or after the specified KeyValue.
    boolean
    SnapshotSegmentScanner.reseek(org.apache.hadoop.hbase.Cell seekCell)
     
    boolean
    StoreFileScanner.reseek(org.apache.hadoop.hbase.Cell key)
     
    boolean
    StoreScanner.reseek(org.apache.hadoop.hbase.Cell kv)
     
    org.apache.hadoop.hbase.mob.MobCell
    HMobStore.resolve(org.apache.hadoop.hbase.Cell reference, boolean cacheBlocks)
    Reads the cell from the mob file, and the read point does not count.
    org.apache.hadoop.hbase.mob.MobCell
    HMobStore.resolve(org.apache.hadoop.hbase.Cell reference, boolean cacheBlocks, boolean readEmptyValueOnMobCellMiss)
    Reads the cell from the mob file with readEmptyValueOnMobCellMiss
    org.apache.hadoop.hbase.mob.MobCell
    HMobStore.resolve(org.apache.hadoop.hbase.Cell reference, boolean cacheBlocks, long readPt, boolean readEmptyValueOnMobCellMiss)
    Reads the cell from the mob file.
    protected void
    HRegion.restoreEdit(org.apache.hadoop.hbase.regionserver.HStore s, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreAccounting)
    Used by tests
    protected void
    StripeMultiFileWriter.sanityCheckLeft(byte[] left, org.apache.hadoop.hbase.Cell cell)
    Subclasses can call this method to make sure the first KV is within multi-writer range.
    protected void
    StripeMultiFileWriter.sanityCheckRight(byte[] right, org.apache.hadoop.hbase.Cell cell)
    Subclasses can call this method to make sure the last KV is within multi-writer range.
    boolean
    KeyValueHeap.seek(org.apache.hadoop.hbase.Cell seekKey)
    Seeks all scanners at or below the specified seek key.
    boolean
    KeyValueScanner.seek(org.apache.hadoop.hbase.Cell key)
    Seek the scanner at or after the specified KeyValue.
    boolean
    ReversedKeyValueHeap.seek(org.apache.hadoop.hbase.Cell seekKey)
     
    boolean
    ReversedStoreScanner.seek(org.apache.hadoop.hbase.Cell key)
     
    boolean
    SegmentScanner.seek(org.apache.hadoop.hbase.Cell cell)
    Seek the scanner at or after the specified Cell.
    boolean
    SnapshotSegmentScanner.seek(org.apache.hadoop.hbase.Cell seekCell)
     
    boolean
    StoreFileScanner.seek(org.apache.hadoop.hbase.Cell key)
     
    boolean
    StoreScanner.seek(org.apache.hadoop.hbase.Cell key)
     
    protected boolean
    ReversedStoreScanner.seekAsDirection(org.apache.hadoop.hbase.Cell kv)
    Do a backwardSeek in a reversed StoreScanner(scan backward)
    protected boolean
    StoreScanner.seekAsDirection(org.apache.hadoop.hbase.Cell kv)
    Do a reseek in a normal StoreScanner(scan forward)
    static boolean
    StoreFileScanner.seekAtOrAfter(org.apache.hadoop.hbase.io.hfile.HFileScanner s, org.apache.hadoop.hbase.Cell k)
    Returns false if not found or if k is after the end.
    protected void
    ReversedStoreScanner.seekScanners(List<? extends org.apache.hadoop.hbase.regionserver.KeyValueScanner> scanners, org.apache.hadoop.hbase.Cell seekKey, boolean isLazy, boolean isParallelSeek)
     
    protected void
    StoreScanner.seekScanners(List<? extends org.apache.hadoop.hbase.regionserver.KeyValueScanner> scanners, org.apache.hadoop.hbase.Cell seekKey, boolean isLazy, boolean isParallelSeek)
    Seek the specified scanners with the given key
    protected boolean
    ReversedStoreScanner.seekToNextRow(org.apache.hadoop.hbase.Cell kv)
     
    protected boolean
    StoreScanner.seekToNextRow(org.apache.hadoop.hbase.Cell c)
     
    boolean
    KeyValueScanner.seekToPreviousRow(org.apache.hadoop.hbase.Cell key)
    Seek the scanner at the first Cell of the row which is the previous row of specified key
    boolean
    NonReversedNonLazyKeyValueScanner.seekToPreviousRow(org.apache.hadoop.hbase.Cell key)
     
    boolean
    ReversedKeyValueHeap.seekToPreviousRow(org.apache.hadoop.hbase.Cell seekKey)
     
    boolean
    ReversedStoreScanner.seekToPreviousRow(org.apache.hadoop.hbase.Cell key)
     
    boolean
    SegmentScanner.seekToPreviousRow(org.apache.hadoop.hbase.Cell cell)
    Seek the scanner at the first Cell of the row which is the previous row of specified key
    boolean
    StoreFileScanner.seekToPreviousRow(org.apache.hadoop.hbase.Cell originalKey)
     
    protected void
    StoreFileScanner.setCurrentCell(org.apache.hadoop.hbase.Cell newVal)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.subMap(org.apache.hadoop.hbase.Cell fromKey, boolean fromInclusive, org.apache.hadoop.hbase.Cell toKey, boolean toInclusive)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.subMap(org.apache.hadoop.hbase.Cell k1, org.apache.hadoop.hbase.Cell k2)
     
    NavigableSet<org.apache.hadoop.hbase.Cell>
    CellSet.subSet(org.apache.hadoop.hbase.Cell fromElement, boolean fromInclusive, org.apache.hadoop.hbase.Cell toElement, boolean toInclusive)
     
    SortedSet<org.apache.hadoop.hbase.Cell>
    CellSet.subSet(org.apache.hadoop.hbase.Cell fromElement, org.apache.hadoop.hbase.Cell toElement)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.tailMap(org.apache.hadoop.hbase.Cell k)
     
    NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>
    CellFlatMap.tailMap(org.apache.hadoop.hbase.Cell fromKey, boolean inclusive)
     
    SortedSet<org.apache.hadoop.hbase.Cell>
    CellSet.tailSet(org.apache.hadoop.hbase.Cell fromElement)
     
    NavigableSet<org.apache.hadoop.hbase.Cell>
    CellSet.tailSet(org.apache.hadoop.hbase.Cell fromElement, boolean inclusive)
     
    protected SortedSet<org.apache.hadoop.hbase.Cell>
    CompositeImmutableSegment.tailSet(org.apache.hadoop.hbase.Cell firstCell)
    Returns a subset of the segment cell set, which starts with the given cell
    protected SortedSet<org.apache.hadoop.hbase.Cell>
    Segment.tailSet(org.apache.hadoop.hbase.Cell firstCell)
    Returns a subset of the segment cell set, which starts with the given cell
    void
    StoreFileWriter.trackTimestamps(org.apache.hadoop.hbase.Cell cell)
    Record the earlest Put timestamp.
    protected boolean
    StoreScanner.trySkipToNextColumn(org.apache.hadoop.hbase.Cell cell)
    See StoreScanner.trySkipToNextRow(Cell)
    protected boolean
    StoreScanner.trySkipToNextRow(org.apache.hadoop.hbase.Cell cell)
    See if we should actually SEEK or rather just SKIP to the next Cell (see HBASE-13109).
    Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile>
    StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile> candidateFiles, org.apache.hadoop.hbase.KeyValue targetKey, org.apache.hadoop.hbase.Cell candidate)
    Updates the candidate list for finding row key before.
    Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile>
    StripeStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile> candidateFiles, org.apache.hadoop.hbase.KeyValue targetKey, org.apache.hadoop.hbase.Cell candidate)
    See StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue) and StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator, KeyValue, Cell) for details on this methods.
    protected void
    CompositeImmutableSegment.updateMetaInfo(org.apache.hadoop.hbase.Cell cellToAdd, boolean succ, boolean mslabUsed, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation)
     
    protected void
    Segment.updateMetaInfo(org.apache.hadoop.hbase.Cell cellToAdd, boolean succ, boolean mslabUsed, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation)
     
    protected void
    Segment.updateMetaInfo(org.apache.hadoop.hbase.Cell cellToAdd, boolean succ, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing)
     
    void
    MutableSegment.upsert(org.apache.hadoop.hbase.Cell cell, long readpoint, org.apache.hadoop.hbase.regionserver.MemStoreSizing memStoreSizing, boolean sizeAddedPreOperation)
     
    Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    void
    AbstractMemStore.add(Iterable<org.apache.hadoop.hbase.Cell> cells, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing)
     
    void
    HStore.add(Iterable<org.apache.hadoop.hbase.Cell> cells, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing)
    Adds the specified value to the memstore
    void
    MemStore.add(Iterable<org.apache.hadoop.hbase.Cell> cells, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing)
    Write the updates
    boolean
    CellSet.addAll(Collection<? extends org.apache.hadoop.hbase.Cell> c)
     
    void
    HRegion.checkTimestamps(Map<byte[],List<org.apache.hadoop.hbase.Cell>> familyMap, long now)
    Check the collection of families for valid timestamps
    protected org.apache.hadoop.hbase.Cell
    AbstractMemStore.getNextRow(org.apache.hadoop.hbase.Cell key, NavigableSet<org.apache.hadoop.hbase.Cell> set)
     
    default boolean
    InternalScanner.next(List<org.apache.hadoop.hbase.Cell> result)
    Grab the next row's worth of values.
    boolean
    InternalScanner.next(List<org.apache.hadoop.hbase.Cell> result, org.apache.hadoop.hbase.regionserver.ScannerContext scannerContext)
    Grab the next row's worth of values.
    boolean
    KeyValueHeap.next(List<org.apache.hadoop.hbase.Cell> result, org.apache.hadoop.hbase.regionserver.ScannerContext scannerContext)
    Gets the next row of keys from the top-most scanner.
    boolean
    MobStoreScanner.next(List<org.apache.hadoop.hbase.Cell> outResult, org.apache.hadoop.hbase.regionserver.ScannerContext ctx)
    Firstly reads the cells from the HBase.
    boolean
    ReversedMobStoreScanner.next(List<org.apache.hadoop.hbase.Cell> outResult, org.apache.hadoop.hbase.regionserver.ScannerContext ctx)
    Firstly reads the cells from the HBase.
    boolean
    StoreScanner.next(List<org.apache.hadoop.hbase.Cell> outResult, org.apache.hadoop.hbase.regionserver.ScannerContext scannerContext)
    Get the next row of values from this Store.
    boolean
    RegionScanner.nextRaw(List<org.apache.hadoop.hbase.Cell> result)
    Grab the next row's worth of values.
    boolean
    RegionScanner.nextRaw(List<org.apache.hadoop.hbase.Cell> result, org.apache.hadoop.hbase.regionserver.ScannerContext scannerContext)
    Grab the next row's worth of values.
    List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    RegionCoprocessorHost.postAppendBeforeWAL(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> cellPairs)
     
    List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    RegionCoprocessorHost.postAppendBeforeWAL(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> cellPairs)
     
    void
    RegionCoprocessorHost.postGet(org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> results)
     
    List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    RegionCoprocessorHost.postIncrementBeforeWAL(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> cellPairs)
     
    List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>>
    RegionCoprocessorHost.postIncrementBeforeWAL(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell>> cellPairs)
     
    boolean
    RegionCoprocessorHost.preGet(org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> results)
    Supports Coprocessor 'bypass'.
    void
    CellFlatMap.putAll(Map<? extends org.apache.hadoop.hbase.Cell,? extends org.apache.hadoop.hbase.Cell> map)
     
    void
    CellFlatMap.putAll(Map<? extends org.apache.hadoop.hbase.Cell,? extends org.apache.hadoop.hbase.Cell> map)
     
    void
    AbstractMemStore.upsert(Iterable<org.apache.hadoop.hbase.Cell> cells, long readpoint, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing)
     
    void
    HStore.upsert(Iterable<org.apache.hadoop.hbase.Cell> cells, long readpoint, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing)
    Adds or replaces the specified KeyValues.
    void
    MemStore.upsert(Iterable<org.apache.hadoop.hbase.Cell> cells, long readpoint, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing)
    Update or insert the specified cells.
    Constructors in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier
    Constructor
    Description
     
    CellArrayMap(Comparator<? super org.apache.hadoop.hbase.Cell> comparator, org.apache.hadoop.hbase.Cell[] b, int min, int max, boolean descending)
     
    Constructor parameters in org.apache.hadoop.hbase.regionserver with type arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier
    Constructor
    Description
     
    CellArrayMap(Comparator<? super org.apache.hadoop.hbase.Cell> comparator, org.apache.hadoop.hbase.Cell[] b, int min, int max, boolean descending)
     
     
    CellChunkMap(Comparator<? super org.apache.hadoop.hbase.Cell> comparator, org.apache.hadoop.hbase.regionserver.Chunk[] chunks, int min, int max, boolean descending)
    C-tor for creating CellChunkMap from existing Chunk array, which must be ordered (decreasingly or increasingly according to parameter "descending")
     
    CellFlatMap(Comparator<? super org.apache.hadoop.hbase.Cell> comparator, int min, int max, boolean d)
     
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.regionserver.querymatcher

    Fields in org.apache.hadoop.hbase.regionserver.querymatcher declared as org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Field
    Description
    protected org.apache.hadoop.hbase.Cell
    ScanQueryMatcher.currentRow
    Row the query is on
    protected org.apache.hadoop.hbase.Cell
    ScanDeleteTracker.deleteCell
     
    protected final org.apache.hadoop.hbase.Cell
    ScanQueryMatcher.startKey
    Key to seek to in memstore and StoreFiles
    Methods in org.apache.hadoop.hbase.regionserver.querymatcher that return org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    protected static org.apache.hadoop.hbase.Cell
    ScanQueryMatcher.createStartKeyFromRow(byte[] startRow, org.apache.hadoop.hbase.regionserver.ScanInfo scanInfo)
     
    org.apache.hadoop.hbase.Cell
    ScanQueryMatcher.currentRow()
    Returns a cell represent the current row
    org.apache.hadoop.hbase.Cell
    ScanQueryMatcher.getKeyForNextColumn(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    CompactionScanQueryMatcher.getNextKeyHint(org.apache.hadoop.hbase.Cell cell)
     
    abstract org.apache.hadoop.hbase.Cell
    ScanQueryMatcher.getNextKeyHint(org.apache.hadoop.hbase.Cell cell)
    Delegate to Filter.getNextCellHint(Cell).
    org.apache.hadoop.hbase.Cell
    UserScanQueryMatcher.getNextKeyHint(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    ScanQueryMatcher.getStartKey()
    Returns the start key
    Methods in org.apache.hadoop.hbase.regionserver.querymatcher with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    void
    DeleteTracker.add(org.apache.hadoop.hbase.Cell cell)
    Add the specified cell to the list of deletes to check against for this row operation.
    void
    NewVersionBehaviorTracker.add(org.apache.hadoop.hbase.Cell cell)
     
    void
    ScanDeleteTracker.add(org.apache.hadoop.hbase.Cell cell)
    Add the specified Cell to the list of deletes to check against for this row operation.
    void
    NewVersionBehaviorTracker.DeleteVersionsNode.addVersionDelete(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    ColumnTracker.checkColumn(org.apache.hadoop.hbase.Cell cell, byte type)
    Checks if the column is present in the list of requested columns by returning the match code instance.
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    ExplicitColumnTracker.checkColumn(org.apache.hadoop.hbase.Cell cell, byte type)
    Checks if the column is present in the list of requested columns by returning the match code instance.
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    NewVersionBehaviorTracker.checkColumn(org.apache.hadoop.hbase.Cell cell, byte type)
     
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    ScanWildcardColumnTracker.checkColumn(org.apache.hadoop.hbase.Cell cell, byte type)
    Checks if the column is present in the list of requested columns by returning the match code instance.
    protected final org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    ScanQueryMatcher.checkDeleted(org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker deletes, org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    ColumnTracker.checkVersions(org.apache.hadoop.hbase.Cell cell, long timestamp, byte type, boolean ignoreCount)
    Keeps track of the number of versions for the columns asked for.
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    ExplicitColumnTracker.checkVersions(org.apache.hadoop.hbase.Cell cell, long timestamp, byte type, boolean ignoreCount)
     
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    NewVersionBehaviorTracker.checkVersions(org.apache.hadoop.hbase.Cell cell, long timestamp, byte type, boolean ignoreCount)
     
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    ScanWildcardColumnTracker.checkVersions(org.apache.hadoop.hbase.Cell cell, long timestamp, byte type, boolean ignoreCount)
    Keeps track of the number of versions for the columns asked for.
    int
    ScanQueryMatcher.compareKeyForNextColumn(org.apache.hadoop.hbase.Cell nextIndexed, org.apache.hadoop.hbase.Cell currentCell)
     
    int
    ScanQueryMatcher.compareKeyForNextRow(org.apache.hadoop.hbase.Cell nextIndexed, org.apache.hadoop.hbase.Cell currentCell)
     
    default void
    ColumnTracker.doneWithColumn(org.apache.hadoop.hbase.Cell cell)
    This method is used to inform the column tracker that we are done with this column.
    void
    ExplicitColumnTracker.doneWithColumn(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    ScanQueryMatcher.getKeyForNextColumn(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    CompactionScanQueryMatcher.getNextKeyHint(org.apache.hadoop.hbase.Cell cell)
     
    abstract org.apache.hadoop.hbase.Cell
    ScanQueryMatcher.getNextKeyHint(org.apache.hadoop.hbase.Cell cell)
    Delegate to Filter.getNextCellHint(Cell).
    org.apache.hadoop.hbase.Cell
    UserScanQueryMatcher.getNextKeyHint(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    ColumnTracker.getNextRowOrNextColumn(org.apache.hadoop.hbase.Cell cell)
    Retrieve the MatchCode for the next row or column
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    ExplicitColumnTracker.getNextRowOrNextColumn(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    NewVersionBehaviorTracker.getNextRowOrNextColumn(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    ScanWildcardColumnTracker.getNextRowOrNextColumn(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
    DeleteTracker.isDeleted(org.apache.hadoop.hbase.Cell cell)
    Check if the specified cell buffer has been deleted by a previously seen delete.
    org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
    NewVersionBehaviorTracker.isDeleted(org.apache.hadoop.hbase.Cell cell)
    This method is not idempotent, we will save some info to judge VERSION_MASKED.
    org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
    ScanDeleteTracker.isDeleted(org.apache.hadoop.hbase.Cell cell)
    Check if the specified Cell buffer has been deleted by a previously seen delete.
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    IncludeAllCompactionQueryMatcher.match(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    MajorCompactionScanQueryMatcher.match(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    MinorCompactionScanQueryMatcher.match(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    NormalUserScanQueryMatcher.match(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    RawScanQueryMatcher.match(org.apache.hadoop.hbase.Cell cell)
     
    abstract org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    ScanQueryMatcher.match(org.apache.hadoop.hbase.Cell cell)
    Determines if the caller should do one of several things: seek/skip to the next row (MatchCode.SEEK_NEXT_ROW) seek/skip to the next column (MatchCode.SEEK_NEXT_COL) include the current KeyValue (MatchCode.INCLUDE) ignore the current KeyValue (MatchCode.SKIP) got to the next row (MatchCode.DONE)
    org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    StripeCompactionScanQueryMatcher.match(org.apache.hadoop.hbase.Cell cell)
     
    protected final org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    UserScanQueryMatcher.matchColumn(org.apache.hadoop.hbase.Cell cell, long timestamp, byte typeByte)
     
    boolean
    CompactionScanQueryMatcher.moreRowsMayExistAfter(org.apache.hadoop.hbase.Cell cell)
     
    abstract boolean
    ScanQueryMatcher.moreRowsMayExistAfter(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    UserScanQueryMatcher.moreRowsMayExistAfter(org.apache.hadoop.hbase.Cell cell)
     
    protected final org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    ScanQueryMatcher.preCheck(org.apache.hadoop.hbase.Cell cell)
    Check before the delete logic.
    protected long
    NewVersionBehaviorTracker.prepare(org.apache.hadoop.hbase.Cell cell)
    Reset the map if it is different with the last Cell.
    void
    ScanQueryMatcher.setToNewRow(org.apache.hadoop.hbase.Cell currentRow)
    Set the row when there is change in row
    protected final void
    CompactionScanQueryMatcher.trackDelete(org.apache.hadoop.hbase.Cell cell)
     
    protected final org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
    DropDeletesCompactionScanQueryMatcher.tryDropDelete(org.apache.hadoop.hbase.Cell cell)
     
    Constructors in org.apache.hadoop.hbase.regionserver.querymatcher with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier
    Constructor
    Description
    protected
    ScanQueryMatcher(org.apache.hadoop.hbase.Cell startKey, org.apache.hadoop.hbase.regionserver.ScanInfo scanInfo, org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker columns, long oldestUnexpiredTS, long now)
     
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.regionserver.throttle

    Method parameters in org.apache.hadoop.hbase.regionserver.throttle with type arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    void
    StoreHotnessProtector.finish(Map<byte[],List<org.apache.hadoop.hbase.Cell>> familyMaps)
     
    void
    StoreHotnessProtector.start(Map<byte[],List<org.apache.hadoop.hbase.Cell>> familyMaps)
     
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.regionserver.wal

    Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    void
    WALCellCodec.EnsureKvEncoder.write(org.apache.hadoop.hbase.Cell cell)
     
    Method parameters in org.apache.hadoop.hbase.regionserver.wal with type arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    static void
    WALUtil.filterCells(org.apache.hadoop.hbase.wal.WALEdit edit, Function<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> mapper)
     
    static void
    WALUtil.filterCells(org.apache.hadoop.hbase.wal.WALEdit edit, Function<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> mapper)
     
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.replication

    Methods in org.apache.hadoop.hbase.replication that return org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.Cell
    BulkLoadCellFilter.filterCell(org.apache.hadoop.hbase.Cell cell, org.apache.hbase.thirdparty.com.google.common.base.Predicate<byte[]> famPredicate)
    Filters the bulk load cell using the supplied predicate.
    org.apache.hadoop.hbase.Cell
    NamespaceTableCfWALEntryFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    ScopeWALEntryFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    WALCellFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell)
    Applies the filter, possibly returning a different Cell instance.
    Methods in org.apache.hadoop.hbase.replication with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.Cell
    BulkLoadCellFilter.filterCell(org.apache.hadoop.hbase.Cell cell, org.apache.hbase.thirdparty.com.google.common.base.Predicate<byte[]> famPredicate)
    Filters the bulk load cell using the supplied predicate.
    org.apache.hadoop.hbase.Cell
    NamespaceTableCfWALEntryFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    ScopeWALEntryFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.Cell
    WALCellFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell)
    Applies the filter, possibly returning a different Cell instance.
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.rest

    Methods in org.apache.hadoop.hbase.rest that return org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.Cell
    RowResultGenerator.next()
     
    org.apache.hadoop.hbase.Cell
    ScannerResultGenerator.next()
     
    Methods in org.apache.hadoop.hbase.rest with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    abstract void
    ResultGenerator.putBack(org.apache.hadoop.hbase.Cell kv)
     
    void
    RowResultGenerator.putBack(org.apache.hadoop.hbase.Cell kv)
     
    void
    ScannerResultGenerator.putBack(org.apache.hadoop.hbase.Cell kv)
     
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.shaded.protobuf

    Methods in org.apache.hadoop.hbase.shaded.protobuf that return org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.Cell
    ProtobufUtil.toCell(org.apache.hadoop.hbase.ExtendedCellBuilder cellBuilder, org.apache.hadoop.hbase.shaded.protobuf.generated.CellProtos.Cell cell, boolean decodeTags)
     
    Methods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.shaded.protobuf.generated.CellProtos.Cell
    ProtobufUtil.toCell(org.apache.hadoop.hbase.Cell kv, boolean encodeTags)
     
    static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Cursor
    ProtobufUtil.toCursor(org.apache.hadoop.hbase.Cell cell)
     
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.thrift

    Methods in org.apache.hadoop.hbase.thrift with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    static List<org.apache.hadoop.hbase.thrift.generated.TCell>
    ThriftUtilities.cellFromHBase(org.apache.hadoop.hbase.Cell in)
    This utility method creates a list of Thrift TCell "struct" based on an Hbase Cell object.
    static List<org.apache.hadoop.hbase.thrift.generated.TCell>
    ThriftUtilities.cellFromHBase(org.apache.hadoop.hbase.Cell[] in)
    This utility method creates a list of Thrift TCell "struct" based on an Hbase Cell array.
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.util

    Classes in org.apache.hadoop.hbase.util that implement org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.util.MapReduceExtendedCell
    A wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers.
    Methods in org.apache.hadoop.hbase.util that return org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.Cell
    BloomContext.getLastCell()
     
    org.apache.hadoop.hbase.Cell
    BloomFilterWriter.getPrevCell()
    Returns the previous cell written by this writer
    org.apache.hadoop.hbase.Cell
    CollectionBackedScanner.next()
     
    org.apache.hadoop.hbase.Cell
    CollectionBackedScanner.peek()
     
    Methods in org.apache.hadoop.hbase.util with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    void
    BloomFilterChunk.add(org.apache.hadoop.hbase.Cell cell)
     
    static int
    Bytes.binarySearch(byte[][] arr, org.apache.hadoop.hbase.Cell key, org.apache.hadoop.io.RawComparator<org.apache.hadoop.hbase.Cell> comparator)
    Deprecated.
    since 2.0.0 and will be removed in 3.0.0.
    static int
    Bytes.binarySearch(org.apache.hadoop.hbase.Cell[] arr, org.apache.hadoop.hbase.Cell key, CellComparator comparator)
    Binary search for keys in indexes.
    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(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)
     
    protected abstract boolean
    BloomContext.isNewKey(org.apache.hadoop.hbase.Cell cell)
    Returns true if the cell is a new key as per the bloom type
    protected boolean
    RowBloomContext.isNewKey(org.apache.hadoop.hbase.Cell cell)
     
    protected boolean
    RowColBloomContext.isNewKey(org.apache.hadoop.hbase.Cell cell)
     
    boolean
    CollectionBackedScanner.reseek(org.apache.hadoop.hbase.Cell seekCell)
     
    boolean
    CollectionBackedScanner.seek(org.apache.hadoop.hbase.Cell seekCell)
     
    void
    BloomContext.writeBloom(org.apache.hadoop.hbase.Cell cell)
    Bloom information from the cell is retrieved
    void
    RowPrefixFixedLengthBloomContext.writeBloom(org.apache.hadoop.hbase.Cell cell)
     
    Method parameters in org.apache.hadoop.hbase.util with type arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    static int
    Bytes.binarySearch(byte[][] arr, org.apache.hadoop.hbase.Cell key, org.apache.hadoop.io.RawComparator<org.apache.hadoop.hbase.Cell> comparator)
    Deprecated.
    since 2.0.0 and will be removed in 3.0.0.
    Constructors in org.apache.hadoop.hbase.util with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier
    Constructor
    Description
     
    CellHashKey(org.apache.hadoop.hbase.Cell cell)
     
     
    CollectionBackedScanner(CellComparator comparator, org.apache.hadoop.hbase.Cell... array)
     
     
    MapReduceExtendedCell(org.apache.hadoop.hbase.Cell cell)
     
     
    RowBloomHashKey(org.apache.hadoop.hbase.Cell cell)
     
     
    RowColBloomHashKey(org.apache.hadoop.hbase.Cell cell)
     
    Constructor parameters in org.apache.hadoop.hbase.util with type arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier
    Constructor
    Description
     
    CollectionBackedScanner(List<org.apache.hadoop.hbase.Cell> list)
     
     
    CollectionBackedScanner(List<org.apache.hadoop.hbase.Cell> list, CellComparator comparator)
     
     
    CollectionBackedScanner(SortedSet<org.apache.hadoop.hbase.Cell> set)
     
     
    CollectionBackedScanner(SortedSet<org.apache.hadoop.hbase.Cell> set, CellComparator comparator)
     
  • Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.wal

    Methods in org.apache.hadoop.hbase.wal that return types with arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    ArrayList<org.apache.hadoop.hbase.Cell>
    WALEdit.getCells()
     
    Methods in org.apache.hadoop.hbase.wal with parameters of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.wal.WALEdit
    WALEdit.add(org.apache.hadoop.hbase.Cell cell)
     
    org.apache.hadoop.hbase.wal.WALEdit
    WALEdit.add(org.apache.hadoop.hbase.Cell cell, byte[] family)
     
    static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor
    WALEdit.getBulkLoadDescriptor(org.apache.hadoop.hbase.Cell cell)
    Deserialized and returns a BulkLoadDescriptor from the passed in Cell
    static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.CompactionDescriptor
    WALEdit.getCompaction(org.apache.hadoop.hbase.Cell kv)
    Deserialized and returns a CompactionDescriptor is the KeyValue contains one.
    static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor
    WALEdit.getFlushDescriptor(org.apache.hadoop.hbase.Cell cell)
     
    static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptor
    WALEdit.getRegionEventDescriptor(org.apache.hadoop.hbase.Cell cell)
     
    static boolean
    WALEdit.isCompactionMarker(org.apache.hadoop.hbase.Cell cell)
    Returns true if the given cell is a serialized WALProtos.CompactionDescriptor
    static boolean
    WALEdit.isMetaEditFamily(org.apache.hadoop.hbase.Cell cell)
    Replaying WALs can read Cell-at-a-time so need this method in those cases.
    static Map<String,Object>
    WALPrettyPrinter.toStringMap(org.apache.hadoop.hbase.Cell cell)
     
    static Map<String,Object>
    WALPrettyPrinter.toStringMap(org.apache.hadoop.hbase.Cell cell, boolean printRowKeyOnly, String rowPrefix, String row, boolean outputValues)
     
    Method parameters in org.apache.hadoop.hbase.wal with type arguments of type org.apache.hadoop.hbase.Cell in in
    Modifier and Type
    Method
    Description
    void
    WALEdit.add(Map<byte[],List<org.apache.hadoop.hbase.Cell>> familyMap)
    Append the given map of family->edits to a WALEdit data structure.
    void
    WALEdit.setCells(ArrayList<org.apache.hadoop.hbase.Cell> cells)
    This is not thread safe.