| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.filter | Provides row-level filters applied to HRegion scan results during calls to
  ResultScanner.next(). | 
| org.apache.hadoop.hbase.mapreduce | Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods. | 
| org.apache.hadoop.hbase.util | 
| Modifier and Type | Method and Description | 
|---|---|
| Cell | CellBuilder. build() | 
| static Cell | CellUtil. cloneIfNecessary(Cell cell) | 
| static Cell | CellUtil. createCell(byte[] row)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. Use  CellBuilderinstead | 
| static Cell | CellUtil. createCell(byte[] row,
          byte[] value)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. Use  CellBuilderinstead | 
| static 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. Use  CellBuilderinstead | 
| static 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. Use  CellBuilderinstead | 
| static 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. Use
              ExtendedCellBuilderinstead | 
| static 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. Use
              ExtendedCellBuilderinstead | 
| static 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. Use
              ExtendedCellBuilderinstead | 
| static 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. Use  CellBuilderinstead | 
| static Cell | CellUtil. createCell(Cell cell,
          byte[] tags)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| static Cell | CellUtil. createCell(Cell cell,
          byte[] value,
          byte[] tags)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| static Cell | CellUtil. createCell(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. | 
| Cell | CellScanner. current()Returns the current Cell which may be mutable | 
| Modifier and Type | Method and Description | 
|---|---|
| Comparator<Cell> | CellComparator. getSimpleComparator()Return a dumbed-down, fast comparator for hbase2 base-type, the  ByteBufferKeyValue. | 
| Modifier and Type | Method and Description | 
|---|---|
| static byte[] | CellUtil. cloneFamily(Cell cell) | 
| static Cell | CellUtil. cloneIfNecessary(Cell cell) | 
| static byte[] | CellUtil. cloneQualifier(Cell cell) | 
| static byte[] | CellUtil. cloneRow(Cell cell)get individual arrays for tests | 
| static byte[] | CellUtil. cloneTags(Cell cell)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0. Use  RawCell.cloneTags() | 
| static byte[] | CellUtil. cloneValue(Cell cell) | 
| int | CellComparator. compare(Cell leftCell,
       Cell rightCell)Lexographically compares two cells. | 
| int | CellComparator. compare(Cell leftCell,
       Cell rightCell,
       boolean ignoreSequenceid)Compare cells. | 
| static int | CellUtil. compare(CellComparator comparator,
       Cell left,
       byte[] key,
       int offset,
       int length)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0 | 
| static int | CellUtil. compareColumns(Cell left,
              byte[] right,
              int rfoffset,
              int rflength,
              int rqoffset,
              int rqlength)Compares the cell's column (family and qualifier) with the given byte[] | 
| static int | CellUtil. compareFamilies(Cell left,
               byte[] right,
               int roffset,
               int rlength)Compares the cell's family with the given byte[] | 
| int | CellComparator. compareFamilies(Cell leftCell,
               Cell rightCell)Lexicographically compares the families of the two cells | 
| static int | CellUtil. compareQualifiers(Cell left,
                 byte[] right,
                 int rOffset,
                 int rLength)Compares the cell's qualifier with the given byte[] | 
| int | CellComparator. compareQualifiers(Cell leftCell,
                 Cell rightCell)Lexicographically compares the qualifiers of the two cells | 
| default int | CellComparator. compareRows(ByteBuffer row,
           Cell cell)Lexicographically compare two rows | 
| int | CellComparator. compareRows(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(Cell leftCell,
           Cell rightCell)Lexographically compares the rows of two cells. | 
| int | CellComparator. compareTimestamps(Cell leftCell,
                 Cell rightCell)Compares cell's timestamps in DESCENDING order. | 
| int | CellComparator. compareWithoutRow(Cell leftCell,
                 Cell rightCell)Lexicographically compares the two cells excluding the row part. | 
| static int | CellUtil. copyFamilyTo(Cell cell,
            byte[] destination,
            int destinationOffset)Copies the family to the given byte[] | 
| static int | CellUtil. copyFamilyTo(Cell cell,
            ByteBuffer destination,
            int destinationOffset)Copies the family to the given bytebuffer | 
| static int | CellUtil. copyQualifierTo(Cell cell,
               byte[] destination,
               int destinationOffset)Copies the qualifier to the given byte[] | 
| static int | CellUtil. copyQualifierTo(Cell cell,
               ByteBuffer destination,
               int destinationOffset)Copies the qualifier to the given bytebuffer | 
| static byte[] | CellUtil. copyRow(Cell cell)Copies the row to a new byte[] | 
| static int | CellUtil. copyRowTo(Cell cell,
         byte[] destination,
         int destinationOffset)Copies the row to the given byte[] | 
| static int | CellUtil. copyRowTo(Cell cell,
         ByteBuffer destination,
         int destinationOffset)Copies the row to the given bytebuffer | 
| static int | CellUtil. copyTagTo(Cell cell,
         byte[] destination,
         int destinationOffset)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0. | 
| static int | CellUtil. copyTagTo(Cell cell,
         ByteBuffer destination,
         int destinationOffset)Deprecated. 
 As of HBase-2.0. Will be removed in 3.0. | 
| static int | CellUtil. copyValueTo(Cell cell,
           byte[] destination,
           int destinationOffset)Copies the value to the given byte[] | 
| static int | CellUtil. copyValueTo(Cell cell,
           ByteBuffer destination,
           int destinationOffset)Copies the value to the given bytebuffer | 
| static Cell | CellUtil. createCell(Cell cell,
          byte[] tags)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| static Cell | CellUtil. createCell(Cell cell,
          byte[] value,
          byte[] tags)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| static Cell | CellUtil. createCell(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 CellScanner | CellUtil. createCellScanner(Cell[] cellArray)Return CellScanner interface over  cellArray | 
| static boolean | CellUtil. equals(Cell a,
      Cell b)equals | 
| static boolean | CellUtil. equalsIgnoreMvccVersion(Cell a,
                       Cell b)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0 | 
| static long | CellUtil. estimatedHeapSizeOf(Cell cell)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. Use
              RawCell.getTags() | 
| static int | CellUtil. estimatedSerializedSizeOf(Cell cell)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| static int | CellUtil. estimatedSerializedSizeOfKey(Cell cell)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| static ByteRange | CellUtil. fillFamilyRange(Cell cell,
               ByteRange range)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0. | 
| static ByteRange | CellUtil. fillQualifierRange(Cell cell,
                  ByteRange range)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0. | 
| static ByteRange | CellUtil. fillRowRange(Cell cell,
            ByteRange range)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0. | 
| static ByteRange | CellUtil. fillTagRange(Cell cell,
            ByteRange range)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0. | 
| static ByteRange | CellUtil. fillValueRange(Cell cell,
              ByteRange range)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0. | 
| static int | CellUtil. findCommonPrefixInFlatKey(Cell c1,
                         Cell c2,
                         boolean bypassFamilyCheck,
                         boolean withTsType)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0 | 
| static String | CellUtil. getCellKeyAsString(Cell cell)Return the key portion of the passed  cellas a String. | 
| static String | CellUtil. getCellKeyAsString(Cell cell,
                  Function<Cell,String> rowConverter)Return the Key portion of the passed  cellas a String. | 
| static byte[] | CellUtil. getCellKeySerializedAsKeyValueKey(Cell cell)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0 | 
| static ByteBuffer | CellUtil. getQualifierBufferShallowCopy(Cell cell)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| static byte | CellUtil. getRowByte(Cell cell,
          int index)Deprecated.  | 
| static org.apache.hadoop.hbase.Tag | CellUtil. getTag(Cell cell,
      byte type)Deprecated. 
 As of 2.0.0 and will be removed in HBase-3.0.0 Use  RawCell.getTag(byte) | 
| static byte[] | CellUtil. getTagArray(Cell cell)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0 | 
| static List<org.apache.hadoop.hbase.Tag> | CellUtil. getTags(Cell cell)Deprecated. 
 As of 2.0.0 and will be removed in 3.0.0 | 
| static ByteBuffer | CellUtil. getValueBufferShallowCopy(Cell cell)Deprecated. 
 As of HBase-2.0. Will be removed in 3.0. | 
| static boolean | CellUtil. isDelete(Cell cell)Return true if a delete type, a  KeyValue.Type.Deleteor a {KeyValue.Type#DeleteFamily}
 or aKeyValue.Type.DeleteColumnKeyValue type. | 
| static boolean | CellUtil. isDeleteColumnOrFamily(Cell cell)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| static boolean | CellUtil. isDeleteColumns(Cell cell)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| static boolean | CellUtil. isDeleteColumnVersion(Cell cell)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| static boolean | CellUtil. isDeleteFamily(Cell cell)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| static boolean | CellUtil. isDeleteFamilyVersion(Cell cell)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| static boolean | CellUtil. isDeleteType(Cell cell)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. | 
| static boolean | CellUtil. isPut(Cell cell)Returns True if this cell is a Put. | 
| static boolean | CellUtil. matchingColumn(Cell left,
              byte[] fam,
              byte[] qual) | 
| static boolean | CellUtil. matchingColumn(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(Cell left,
              Cell right) | 
| static boolean | CellUtil. matchingColumnFamilyAndQualifierPrefix(Cell left,
                                      byte[] fam,
                                      byte[] qual)Returns True if matching column family and the qualifier starts with  qual | 
| static boolean | CellUtil. matchingFamily(Cell left,
              byte[] buf) | 
| static boolean | CellUtil. matchingFamily(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(Cell left,
              byte lfamlength,
              Cell right,
              byte rfamlength) | 
| static boolean | CellUtil. matchingFamily(Cell left,
              Cell right) | 
| static boolean | CellUtil. matchingQualifier(Cell left,
                 byte[] buf)Finds if the qualifier part of the cell and the KV serialized byte[] are equal. | 
| static boolean | CellUtil. matchingQualifier(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(Cell left,
                 Cell right) | 
| static boolean | CellUtil. matchingRow(Cell left,
           byte[] buf)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use
              CellUtil.matchingRows(Cell, byte[]) | 
| static boolean | CellUtil. matchingRow(Cell left,
           byte[] buf,
           int offset,
           int length)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use
              CellUtil.matchingRows(Cell, Cell) | 
| static boolean | CellUtil. matchingRow(Cell left,
           Cell right)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use
              CellUtil.matchingRows(Cell, Cell) | 
| static boolean | CellUtil. matchingRowColumn(Cell left,
                 Cell right)Compares the row and column of two keyvalues for equality | 
| static boolean | CellUtil. matchingRowColumnBytes(Cell left,
                      Cell right)Compares the row and column of two keyvalues for equality | 
| static boolean | CellUtil. matchingRows(Cell left,
            byte[] buf) | 
| static boolean | CellUtil. matchingRows(Cell left,
            Cell right)Compares the row of two keyvalues for equality | 
| static boolean | CellUtil. matchingRows(Cell left,
            short lrowlength,
            Cell right,
            short rrowlength)Compares the row of two keyvalues for equality | 
| static boolean | CellUtil. matchingTags(Cell left,
            Cell right) | 
| static boolean | CellUtil. matchingTimestamp(Cell a,
                 Cell b) | 
| static boolean | CellUtil. matchingType(Cell a,
            Cell b)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0 | 
| static boolean | CellUtil. matchingValue(Cell left,
             byte[] buf) | 
| static boolean | CellUtil. matchingValue(Cell left,
             Cell right) | 
| static void | CellUtil. setSequenceId(Cell cell,
             long seqId)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0 | 
| static void | CellUtil. setTimestamp(Cell cell,
            byte[] ts,
            int tsOffset)Deprecated. 
 As of HBase-2.0. Will be a LimitedPrivate API in HBase-3.0. | 
| static void | CellUtil. setTimestamp(Cell cell,
            long ts)Deprecated. 
 As of HBase-2.0. Will be a LimitedPrivate API in HBase-3.0. | 
| static String | CellUtil. toString(Cell cell,
        boolean verbose)Returns a string representation of the cell | 
| static boolean | CellUtil. updateLatestStamp(Cell cell,
                 byte[] ts,
                 int tsOffset)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0 | 
| static boolean | CellUtil. updateLatestStamp(Cell cell,
                 long ts)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0 | 
| static void | CellUtil. writeFlatKey(Cell cell,
            DataOutputStream out)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0 | 
| static void | CellUtil. writeRowKeyExcludingCommon(Cell cell,
                          short rLen,
                          int commonPrefix,
                          DataOutputStream out)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0 | 
| static void | CellUtil. writeRowSkippingBytes(DataOutputStream out,
                     Cell cell,
                     short rlength,
                     int commonPrefix)Deprecated. 
 As of 2.0. Will be removed in hbase-3.0 | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | CellUtil. cloneIfNecessary(ArrayList<Cell> cells) | 
| static CellScanner | CellUtil. createCellScanner(Iterable<Cell> cellIterable)Return CellScanner interface over  cellIterable | 
| static CellScanner | CellUtil. createCellScanner(Iterator<Cell> cells)Return CellScanner interface over  cellIterableor null ifcellsis
 null | 
| static CellScanner | CellUtil. createCellScanner(NavigableMap<byte[],List<Cell>> map)Flatten the map of cells out under the CellScanner | 
| static String | CellUtil. getCellKeyAsString(Cell cell,
                  Function<Cell,String> rowConverter)Return the Key portion of the passed  cellas a String. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected NavigableMap<byte[],List<Cell>> | Mutation. familyMap | 
| Modifier and Type | Method and Description | 
|---|---|
| Cell | Result. current() | 
| Cell | Result. getColumnLatestCell(byte[] family,
                   byte[] qualifier)The Cell for the most recent timestamp for a given column. | 
| 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. | 
| Cell[] | Result. rawCells()Return the array of Cells backing this Result instance. | 
| Modifier and Type | Method and Description | 
|---|---|
| List<Cell> | Mutation. get(byte[] family,
   byte[] qualifier)Returns a list of all KeyValue objects with matching column family and qualifier. | 
| List<Cell> | Result. getColumnCells(byte[] family,
              byte[] qualifier)Return the Cells for the specific column. | 
| NavigableMap<byte[],List<Cell>> | Mutation. getFamilyCellMap()Method for retrieving the put's familyMap n | 
| List<Cell> | Result. listCells()Create a sorted list of the Cell's in this result. | 
| Modifier and Type | Method and Description | 
|---|---|
| Put | Put. add(Cell cell)Add the specified KeyValue to this Put operation. | 
| Append | Append. add(Cell cell)Add column and value to this Append operation. | 
| Increment | Increment. add(Cell cell)Add the specified KeyValue to this operation. | 
| Delete | Delete. add(Cell cell)Add an existing delete marker to this Delete object. | 
| Delete | Delete. addDeleteMarker(Cell kv)Deprecated.  | 
| protected int | Result. binarySearch(Cell[] kvs,
            byte[] family,
            byte[] qualifier) | 
| protected int | Result. binarySearch(Cell[] kvs,
            byte[] family,
            int foffset,
            int flength,
            byte[] qualifier,
            int qoffset,
            int qlength)Searches for the latest value for the specified column. | 
| static Result | Result. create(Cell[] cells)Instantiate a Result with the specified array of KeyValues. | 
| static Result | Result. create(Cell[] cells,
      Boolean exists,
      boolean stale) | 
| static Result | Result. create(Cell[] cells,
      Boolean exists,
      boolean stale,
      boolean mayHaveMoreCellsInRow) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Result | Result. create(List<Cell> cells)Instantiate a Result with the specified List of KeyValues. | 
| static Result | Result. create(List<Cell> cells,
      Boolean exists) | 
| static Result | Result. create(List<Cell> cells,
      Boolean exists,
      boolean stale) | 
| static Result | Result. create(List<Cell> cells,
      Boolean exists,
      boolean stale,
      boolean mayHaveMoreCellsInRow) | 
| Put | Put. setFamilyCellMap(NavigableMap<byte[],List<Cell>> map)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. Use
              Put(byte[], long, NavigableMap)instead | 
| Append | Append. setFamilyCellMap(NavigableMap<byte[],List<Cell>> map)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. Use
              Append(byte[], long, NavigableMap)instead | 
| Increment | Increment. setFamilyCellMap(NavigableMap<byte[],List<Cell>> map)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. Use
              Increment(byte[], long, NavigableMap)instead | 
| Mutation | Mutation. setFamilyCellMap(NavigableMap<byte[],List<Cell>> map)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. Use
              Mutation(byte[], long, NavigableMap)instead | 
| Delete | Delete. setFamilyCellMap(NavigableMap<byte[],List<Cell>> map)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. Use
              Delete(byte[], long, NavigableMap)instead | 
| Constructor and Description | 
|---|
| Append(byte[] row,
      long ts,
      NavigableMap<byte[],List<Cell>> familyMap)Construct the Append with user defined data. | 
| Delete(byte[] row,
      long ts,
      NavigableMap<byte[],List<Cell>> familyMap)Construct the Delete with user defined data. | 
| Increment(byte[] row,
         long ts,
         NavigableMap<byte[],List<Cell>> familyMap)Construct the Increment with user defined data. | 
| Mutation(byte[] row,
        long ts,
        NavigableMap<byte[],List<Cell>> familyMap)Construct the mutation with user defined data. | 
| Put(byte[] row,
   long ts,
   NavigableMap<byte[],List<Cell>> familyMap)Construct the Put with user defined data. | 
| Modifier and Type | Method and Description | 
|---|---|
| Cell | ColumnPaginationFilter. getNextCellHint(Cell cell) | 
| Cell | ColumnRangeFilter. getNextCellHint(Cell cell) | 
| Cell | FilterList. getNextCellHint(Cell currentCell) | 
| Cell | FuzzyRowFilter. getNextCellHint(Cell currentCell) | 
| abstract Cell | Filter. getNextCellHint(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. | 
| Cell | ColumnPrefixFilter. getNextCellHint(Cell cell) | 
| Cell | MultiRowRangeFilter. getNextCellHint(Cell currentKV) | 
| Cell | TimestampsFilter. getNextCellHint(Cell currentCell)Pick the next cell that the scanner should seek to. | 
| Cell | MultipleColumnPrefixFilter. getNextCellHint(Cell cell) | 
| Cell | SkipFilter. transformCell(Cell v) | 
| Cell | WhileMatchFilter. transformCell(Cell v) | 
| Cell | FilterList. transformCell(Cell c) | 
| abstract Cell | Filter. transformCell(Cell v)Give the filter a chance to transform the passed KeyValue. | 
| Cell | KeyOnlyFilter. transformCell(Cell cell) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected boolean | CompareFilter. compareFamily(CompareFilter.CompareOp compareOp,
             ByteArrayComparable comparator,
             Cell cell)Deprecated. 
 Since 2.0.0. Will be removed in 3.0.0. Use
              CompareFilter.compareFamily(CompareOperator, ByteArrayComparable, Cell) | 
| protected boolean | CompareFilter. compareFamily(CompareOperator op,
             ByteArrayComparable comparator,
             Cell cell) | 
| protected boolean | CompareFilter. compareQualifier(CompareFilter.CompareOp compareOp,
                ByteArrayComparable comparator,
                Cell cell)Deprecated. 
 Since 2.0.0. Will be removed in 3.0.0. Use
              CompareFilter.compareQualifier(CompareOperator, ByteArrayComparable, Cell) | 
| protected boolean | CompareFilter. compareQualifier(CompareOperator op,
                ByteArrayComparable comparator,
                Cell cell) | 
| protected boolean | CompareFilter. compareRow(CompareFilter.CompareOp compareOp,
          ByteArrayComparable comparator,
          Cell cell)Deprecated. 
 Since 2.0.0. Will be removed in 3.0.0. Use
              CompareFilter.compareRow(CompareOperator, ByteArrayComparable, Cell) | 
| protected boolean | CompareFilter. compareRow(CompareOperator op,
          ByteArrayComparable comparator,
          Cell cell) | 
| protected boolean | CompareFilter. compareValue(CompareFilter.CompareOp compareOp,
            ByteArrayComparable comparator,
            Cell cell)Deprecated. 
 Since 2.0.0. Will be removed in 3.0.0. Use
              CompareFilter.compareValue(CompareOperator, ByteArrayComparable, Cell) | 
| protected boolean | CompareFilter. compareValue(CompareOperator op,
            ByteArrayComparable comparator,
            Cell cell) | 
| Filter.ReturnCode | FirstKeyOnlyFilter. filterCell(Cell c) | 
| Filter.ReturnCode | SkipFilter. filterCell(Cell c) | 
| Filter.ReturnCode | ColumnCountGetFilter. filterCell(Cell c) | 
| Filter.ReturnCode | WhileMatchFilter. filterCell(Cell c) | 
| Filter.ReturnCode | ColumnPaginationFilter. filterCell(Cell c) | 
| Filter.ReturnCode | ColumnRangeFilter. filterCell(Cell c) | 
| Filter.ReturnCode | FilterList. filterCell(Cell c) | 
| Filter.ReturnCode | FuzzyRowFilter. filterCell(Cell c) | 
| Filter.ReturnCode | Filter. filterCell(Cell c)A way to filter based on the column family, column qualifier and/or the column value. | 
| Filter.ReturnCode | DependentColumnFilter. filterCell(Cell c) | 
| Filter.ReturnCode | ColumnPrefixFilter. filterCell(Cell cell) | 
| Filter.ReturnCode | ColumnValueFilter. filterCell(Cell c) | 
| Filter.ReturnCode | MultiRowRangeFilter. filterCell(Cell ignored) | 
| Filter.ReturnCode | RandomRowFilter. filterCell(Cell c) | 
| Filter.ReturnCode | FirstKeyValueMatchingQualifiersFilter. filterCell(Cell c)Deprecated.  | 
| Filter.ReturnCode | ValueFilter. filterCell(Cell c) | 
| Filter.ReturnCode | SingleColumnValueFilter. filterCell(Cell c) | 
| Filter.ReturnCode | InclusiveStopFilter. filterCell(Cell c) | 
| Filter.ReturnCode | QualifierFilter. filterCell(Cell c) | 
| Filter.ReturnCode | TimestampsFilter. filterCell(Cell c) | 
| Filter.ReturnCode | PageFilter. filterCell(Cell ignored) | 
| Filter.ReturnCode | PrefixFilter. filterCell(Cell c) | 
| Filter.ReturnCode | FamilyFilter. filterCell(Cell c) | 
| Filter.ReturnCode | KeyOnlyFilter. filterCell(Cell ignored) | 
| Filter.ReturnCode | RowFilter. filterCell(Cell v) | 
| Filter.ReturnCode | MultipleColumnPrefixFilter. filterCell(Cell c) | 
| Filter.ReturnCode | ColumnPrefixFilter. filterColumn(Cell cell) | 
| Filter.ReturnCode | MultipleColumnPrefixFilter. filterColumn(Cell cell) | 
| Filter.ReturnCode | FirstKeyOnlyFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | SkipFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | ColumnCountGetFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | WhileMatchFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | ColumnPaginationFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | ColumnRangeFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | FilterList. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | FuzzyRowFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | Filter. filterKeyValue(Cell c)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use
             filterCell(Cell) | 
| Filter.ReturnCode | DependentColumnFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | ColumnPrefixFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | MultiRowRangeFilter. filterKeyValue(Cell ignored)Deprecated.  | 
| Filter.ReturnCode | RandomRowFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | FirstKeyValueMatchingQualifiersFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | ValueFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | SingleColumnValueFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | InclusiveStopFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | QualifierFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | TimestampsFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | PageFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | PrefixFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | FamilyFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | KeyOnlyFilter. filterKeyValue(Cell ignored)Deprecated.  | 
| Filter.ReturnCode | RowFilter. filterKeyValue(Cell c)Deprecated.  | 
| Filter.ReturnCode | MultipleColumnPrefixFilter. filterKeyValue(Cell c)Deprecated.  | 
| boolean | FirstKeyOnlyFilter. filterRowKey(Cell cell) | 
| boolean | SkipFilter. filterRowKey(Cell cell) | 
| boolean | ColumnCountGetFilter. filterRowKey(Cell cell) | 
| boolean | WhileMatchFilter. filterRowKey(Cell cell) | 
| boolean | ColumnPaginationFilter. filterRowKey(Cell cell) | 
| boolean | ColumnRangeFilter. filterRowKey(Cell cell) | 
| boolean | FilterList. filterRowKey(Cell firstRowCell) | 
| abstract boolean | Filter. filterRowKey(Cell firstRowCell)Filters a row based on the row key. | 
| boolean | CompareFilter. filterRowKey(Cell cell) | 
| boolean | ColumnPrefixFilter. filterRowKey(Cell cell) | 
| boolean | ColumnValueFilter. filterRowKey(Cell cell) | 
| boolean | MultiRowRangeFilter. filterRowKey(Cell firstRowCell) | 
| boolean | RandomRowFilter. filterRowKey(Cell firstRowCell) | 
| boolean | SingleColumnValueFilter. filterRowKey(Cell cell) | 
| boolean | InclusiveStopFilter. filterRowKey(Cell firstRowCell) | 
| boolean | TimestampsFilter. filterRowKey(Cell cell) | 
| boolean | PageFilter. filterRowKey(Cell cell) | 
| boolean | PrefixFilter. filterRowKey(Cell firstRowCell) | 
| boolean | KeyOnlyFilter. filterRowKey(Cell cell) | 
| boolean | RowFilter. filterRowKey(Cell firstRowCell) | 
| boolean | MultipleColumnPrefixFilter. filterRowKey(Cell cell) | 
| Cell | ColumnPaginationFilter. getNextCellHint(Cell cell) | 
| Cell | ColumnRangeFilter. getNextCellHint(Cell cell) | 
| Cell | FilterList. getNextCellHint(Cell currentCell) | 
| Cell | FuzzyRowFilter. getNextCellHint(Cell currentCell) | 
| abstract Cell | Filter. getNextCellHint(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. | 
| Cell | ColumnPrefixFilter. getNextCellHint(Cell cell) | 
| Cell | MultiRowRangeFilter. getNextCellHint(Cell currentKV) | 
| Cell | TimestampsFilter. getNextCellHint(Cell currentCell)Pick the next cell that the scanner should seek to. | 
| Cell | MultipleColumnPrefixFilter. getNextCellHint(Cell cell) | 
| Cell | SkipFilter. transformCell(Cell v) | 
| Cell | WhileMatchFilter. transformCell(Cell v) | 
| Cell | FilterList. transformCell(Cell c) | 
| abstract Cell | Filter. transformCell(Cell v)Give the filter a chance to transform the passed KeyValue. | 
| Cell | KeyOnlyFilter. transformCell(Cell cell) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | FilterList. filterRowCells(List<Cell> cells)Filters that never filter by modifying the returned List of Cells can inherit this
 implementation that does nothing. | 
| abstract void | Filter. filterRowCells(List<Cell> kvs)Chance to alter the list of Cells to be submitted. | 
| void | DependentColumnFilter. filterRowCells(List<Cell> kvs) | 
| void | SingleColumnValueExcludeFilter. filterRowCells(List<Cell> kvs) | 
| Modifier and Type | Method and Description | 
|---|---|
| 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) | 
| 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) | 
| 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.  | 
| static Cell | Import. filterKv(Filter filter,
        Cell c)Attempt to filter out the keyvalue | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.mapreduce.RecordWriter<ImmutableBytesWritable,Cell> | HFileOutputFormat2. getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Cell | Import. filterKv(Filter filter,
        Cell c)Attempt to filter out the keyvalue | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.hbase.mapreduce.CellSerialization.CellDeserializer | CellSerialization. getDeserializer(Class<Cell> t) | 
| org.apache.hadoop.hbase.mapreduce.CellSerialization.CellSerializer | CellSerialization. getSerializer(Class<Cell> c) | 
| protected void | CellSortReducer. reduce(ImmutableBytesWritable row,
      Iterable<Cell> kvs,
      org.apache.hadoop.mapreduce.Reducer.Context context) | 
| Modifier and Type | Method and Description | 
|---|---|
| static int | Bytes. binarySearch(byte[][] arr,
            Cell key,
            org.apache.hadoop.io.RawComparator<Cell> comparator)Deprecated. 
 since 2.0.0 and will be removed in 3.0.0. Use
              Bytes.binarySearch(Cell[], Cell, CellComparator)instead. | 
| static int | Bytes. binarySearch(Cell[] arr,
            Cell key,
            CellComparator comparator)Binary search for keys in indexes. | 
| static int | Bytes. binarySearch(Cell[] arr,
            Cell key,
            CellComparator comparator)Binary search for keys in indexes. | 
| Modifier and Type | Method and Description | 
|---|---|
| static int | Bytes. binarySearch(byte[][] arr,
            Cell key,
            org.apache.hadoop.io.RawComparator<Cell> comparator)Deprecated. 
 since 2.0.0 and will be removed in 3.0.0. Use
              Bytes.binarySearch(Cell[], Cell, CellComparator)instead. | 
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.