Return-Path: X-Original-To: apmail-hbase-commits-archive@www.apache.org Delivered-To: apmail-hbase-commits-archive@www.apache.org Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by minotaur.apache.org (Postfix) with SMTP id C61E2185F2 for ; Wed, 4 Nov 2015 21:38:06 +0000 (UTC) Received: (qmail 19323 invoked by uid 500); 4 Nov 2015 21:38:06 -0000 Delivered-To: apmail-hbase-commits-archive@hbase.apache.org Received: (qmail 19036 invoked by uid 500); 4 Nov 2015 21:38:05 -0000 Mailing-List: contact commits-help@hbase.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@hbase.apache.org Delivered-To: mailing list commits@hbase.apache.org Received: (qmail 18791 invoked by uid 99); 4 Nov 2015 21:38:05 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Wed, 04 Nov 2015 21:38:05 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 854D0E01F2; Wed, 4 Nov 2015 21:38:05 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: misty@apache.org To: commits@hbase.apache.org Date: Wed, 04 Nov 2015 21:38:08 -0000 Message-Id: <621575dfa4804b78b3e7800504c3c28c@git.apache.org> In-Reply-To: <9e87bd05b0174aa28f09c18d2fbcd220@git.apache.org> References: <9e87bd05b0174aa28f09c18d2fbcd220@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [04/51] [partial] hbase git commit: Initial site commit -- trying gitpubsub http://git-wip-us.apache.org/repos/asf/hbase/blob/c4917730/apidocs/org/apache/hadoop/hbase/client/Result.html ---------------------------------------------------------------------- diff --git a/apidocs/org/apache/hadoop/hbase/client/Result.html b/apidocs/org/apache/hadoop/hbase/client/Result.html new file mode 100644 index 0000000..53035b1 --- /dev/null +++ b/apidocs/org/apache/hadoop/hbase/client/Result.html @@ -0,0 +1,1263 @@ + + + + + +Result (Apache HBase 2.0.0-SNAPSHOT API) + + + + + + + + + + +
+
org.apache.hadoop.hbase.client
+

Class Result

+
+
+ +
+
    +
  • +
    +
    All Implemented Interfaces:
    +
    org.apache.hadoop.hbase.CellScannable, org.apache.hadoop.hbase.CellScanner
    +
    +
    +
    +
    @InterfaceAudience.Public
    +@InterfaceStability.Stable
    +public class Result
    +extends Object
    +implements org.apache.hadoop.hbase.CellScannable, org.apache.hadoop.hbase.CellScanner
    +
    Single row result of a Get or Scan query.

    + + This class is NOT THREAD SAFE.

    + + Convenience methods are available that return various Map + structures and values directly.

    + + To get a complete mapping of all cells in the Result, which can include + multiple families and multiple versions, use getMap().

    + + To get a mapping of each family to its columns (qualifiers and values), + including only the latest version of each, use getNoVersionMap(). + + To get a mapping of qualifiers to latest values for an individual family use + getFamilyMap(byte[]).

    + + To get the latest value for a specific family and qualifier use + getValue(byte[], byte[]). + + A Result is backed by an array of Cell objects, each representing + an HBase cell defined by the row, family, qualifier, timestamp, and value.

    + + The underlying Cell objects can be accessed through the method listCells(). + This will create a List from the internal Cell []. Better is to exploit the fact that + a new Result instance is a primed CellScanner; just call advance() and + current() to iterate over Cells as you would any CellScanner. + Call cellScanner() to reset should you need to iterate the same Result over again + (CellScanners are one-shot). + + If you need to overwrite a Result with another Result instance -- as in the old 'mapred' + RecordReader next invocations -- then create an empty Result with the null constructor and + in then use copyFrom(Result)

    +
  • +
+
+
+
    +
  • + +
      +
    • + + +

      Field Summary

      + + + + + + + + + + +
      Fields 
      Modifier and TypeField and Description
      static ResultEMPTY_RESULT 
      +
    • +
    + +
      +
    • + + +

      Constructor Summary

      + + + + + + + + +
      Constructors 
      Constructor and Description
      Result() +
      Creates an empty Result w/ no KeyValue payload; returns null if you call rawCells().
      +
      +
    • +
    + +
      +
    • + + +

      Method Summary

      + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
      Methods 
      Modifier and TypeMethod and Description
      booleanadvance() +
      Advance the scanner 1 cell.
      +
      protected intbinarySearch(Cell[] kvs, + byte[] family, + byte[] qualifier) 
      protected intbinarySearch(Cell[] kvs, + byte[] family, + int foffset, + int flength, + byte[] qualifier, + int qoffset, + int qlength) +
      Searches for the latest value for the specified column.
      +
      org.apache.hadoop.hbase.CellScannercellScanner() 
      static voidcompareResults(Result res1, + Result res2) +
      Does a deep comparison of two Results, down to the byte arrays.
      +
      booleancontainsColumn(byte[] family, + byte[] qualifier) +
      Checks for existence of a value for the specified column (empty or not).
      +
      booleancontainsColumn(byte[] family, + int foffset, + int flength, + byte[] qualifier, + int qoffset, + int qlength) +
      Checks for existence of a value for the specified column (empty or not).
      +
      booleancontainsEmptyColumn(byte[] family, + byte[] qualifier) +
      Checks if the specified column contains an empty value (a zero-length byte array).
      +
      booleancontainsEmptyColumn(byte[] family, + int foffset, + int flength, + byte[] qualifier, + int qoffset, + int qlength) +
      Checks if the specified column contains an empty value (a zero-length byte array).
      +
      booleancontainsNonEmptyColumn(byte[] family, + byte[] qualifier) +
      Checks if the specified column contains a non-empty value (not a zero-length byte array).
      +
      booleancontainsNonEmptyColumn(byte[] family, + int foffset, + int flength, + byte[] qualifier, + int qoffset, + int qlength) +
      Checks if the specified column contains a non-empty value (not a zero-length byte array).
      +
      voidcopyFrom(Result other) +
      Copy another Result into this one.
      +
      static Resultcreate(Cell[] cells) +
      Instantiate a Result with the specified array of KeyValues.
      +
      static Resultcreate(Cell[] cells, + Boolean exists, + boolean stale) 
      static Resultcreate(Cell[] cells, + Boolean exists, + boolean stale, + boolean partial) 
      static Resultcreate(List<Cell> cells) +
      Instantiate a Result with the specified List of KeyValues.
      +
      static Resultcreate(List<Cell> cells, + Boolean exists) 
      static Resultcreate(List<Cell> cells, + Boolean exists, + boolean stale) 
      static Resultcreate(List<Cell> cells, + Boolean exists, + boolean stale, + boolean partial) 
      static ResultcreateCompleteResult(List<Result> partialResults) +
      Forms a single result from the partial results in the partialResults list.
      +
      Cellcurrent() 
      List<Cell>getColumnCells(byte[] family, + byte[] qualifier) +
      Return the Cells for the specific column.
      +
      CellgetColumnLatestCell(byte[] family, + byte[] qualifier) +
      The Cell for the most recent timestamp for a given column.
      +
      CellgetColumnLatestCell(byte[] family, + int foffset, + int flength, + byte[] qualifier, + int qoffset, + int qlength) +
      The Cell for the most recent timestamp for a given column.
      +
      BooleangetExists() 
      NavigableMap<byte[],byte[]>getFamilyMap(byte[] family) +
      Map of qualifiers to values.
      +
      NavigableMap<byte[],NavigableMap<byte[],NavigableMap<Long,byte[]>>>getMap() +
      Map of families to all versions of its qualifiers and values.
      +
      NavigableMap<byte[],NavigableMap<byte[],byte[]>>getNoVersionMap() +
      Map of families to their most recent qualifiers and values.
      +
      byte[]getRow() +
      Method for retrieving the row key that corresponds to + the row from which this Result was created.
      +
      org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStatsgetStats() 
      static longgetTotalSizeOfCells(Result result) +
      Get total size of raw cells
      +
      byte[]getValue(byte[] family, + byte[] qualifier) +
      Get the latest version of the specified column.
      +
      ByteBuffergetValueAsByteBuffer(byte[] family, + byte[] qualifier) +
      Returns the value wrapped in a new ByteBuffer.
      +
      ByteBuffergetValueAsByteBuffer(byte[] family, + int foffset, + int flength, + byte[] qualifier, + int qoffset, + int qlength) +
      Returns the value wrapped in a new ByteBuffer.
      +
      booleanisEmpty() +
      Check if the underlying Cell [] is empty or not
      +
      booleanisPartial() +
      Whether or not the result is a partial result.
      +
      booleanisStale() +
      Whether or not the results are coming from possibly stale data.
      +
      List<Cell>listCells() +
      Create a sorted list of the Cell's in this result.
      +
      booleanloadValue(byte[] family, + byte[] qualifier, + ByteBuffer dst) +
      Loads the latest version of the specified column into the provided ByteBuffer.
      +
      booleanloadValue(byte[] family, + int foffset, + int flength, + byte[] qualifier, + int qoffset, + int qlength, + ByteBuffer dst) +
      Loads the latest version of the specified column into the provided ByteBuffer.
      +
      Cell[]rawCells() +
      Return the array of Cells backing this Result instance.
      +
      voidsetExists(Boolean exists) 
      intsize() 
      StringtoString() 
      byte[]value() +
      Returns the value of the first column in the Result.
      +
      + +
    • +
    +
  • +
+
+
+
    +
  • + + + +
      +
    • + + +

      Constructor Detail

      + + + +
        +
      • +

        Result

        +
        public Result()
        +
        Creates an empty Result w/ no KeyValue payload; returns null if you call rawCells(). + Use this to represent no results if null won't do or in old 'mapred' as opposed + to 'mapreduce' package MapReduce where you need to overwrite a Result instance with a + copyFrom(Result) call.
        +
      • +
      +
    • +
    + +
      +
    • + + +

      Method Detail

      + + + +
        +
      • +

        create

        +
        public static Result create(List<Cell> cells)
        +
        Instantiate a Result with the specified List of KeyValues. +
        Note: You must ensure that the keyvalues are already sorted.
        +
        Parameters:
        cells - List of cells
        +
      • +
      + + + + + + + + + + + + + + + +
        +
      • +

        create

        +
        public static Result create(Cell[] cells)
        +
        Instantiate a Result with the specified array of KeyValues. +
        Note: You must ensure that the keyvalues are already sorted.
        +
        Parameters:
        cells - array of cells
        +
      • +
      + + + + + + + +
        +
      • +

        create

        +
        public static Result create(Cell[] cells,
        +            Boolean exists,
        +            boolean stale,
        +            boolean partial)
        +
      • +
      + + + +
        +
      • +

        getRow

        +
        public byte[] getRow()
        +
        Method for retrieving the row key that corresponds to + the row from which this Result was created.
        +
        Returns:
        row
        +
      • +
      + + + +
        +
      • +

        rawCells

        +
        public Cell[] rawCells()
        +
        Return the array of Cells backing this Result instance. + + The array is sorted from smallest -> largest using the + CellComparator.COMPARATOR. + + The array only contains what your Get or Scan specifies and no more. + For example if you request column "A" 1 version you will have at most 1 + Cell in the array. If you request column "A" with 2 version you will + have at most 2 Cells, with the first one being the newer timestamp and + the second being the older timestamp (this is the sort order defined by + CellComparator.COMPARATOR). If columns don't exist, they won't be + present in the result. Therefore if you ask for 1 version all columns, + it is safe to iterate over this array and expect to see 1 Cell for + each column and no more. + + This API is faster than using getFamilyMap() and getMap()
        +
        Returns:
        array of Cells; can be null if nothing in the result
        +
      • +
      + + + +
        +
      • +

        listCells

        +
        public List<CelllistCells()
        +
        Create a sorted list of the Cell's in this result. + + Since HBase 0.20.5 this is equivalent to raw().
        +
        Returns:
        sorted List of Cells; can be null if no cells in the result
        +
      • +
      + + + +
        +
      • +

        getColumnCells

        +
        public List<CellgetColumnCells(byte[] family,
        +                        byte[] qualifier)
        +
        Return the Cells for the specific column. The Cells are sorted in + the CellComparator.COMPARATOR order. That implies the first entry in + the list is the most recent column. If the query (Scan or Get) only + requested 1 version the list will contain at most 1 entry. If the column + did not exist in the result set (either the column does not exist + or the column was not selected in the query) the list will be empty. + + Also see getColumnLatest which returns just a Cell
        +
        Parameters:
        family - the family
        qualifier -
        +
        Returns:
        a list of Cells for this column or empty list if the column + did not exist in the result set
        +
      • +
      + + + +
        +
      • +

        binarySearch

        +
        protected int binarySearch(Cell[] kvs,
        +               byte[] family,
        +               byte[] qualifier)
        +
      • +
      + + + +
        +
      • +

        binarySearch

        +
        protected int binarySearch(Cell[] kvs,
        +               byte[] family,
        +               int foffset,
        +               int flength,
        +               byte[] qualifier,
        +               int qoffset,
        +               int qlength)
        +
        Searches for the latest value for the specified column.
        +
        Parameters:
        kvs - the array to search
        family - family name
        foffset - family offset
        flength - family length
        qualifier - column qualifier
        qoffset - qualifier offset
        qlength - qualifier length
        +
        Returns:
        the index where the value was found, or -1 otherwise
        +
      • +
      + + + +
        +
      • +

        getColumnLatestCell

        +
        public Cell getColumnLatestCell(byte[] family,
        +                       byte[] qualifier)
        +
        The Cell for the most recent timestamp for a given column.
        +
        Parameters:
        family -
        qualifier -
        +
        Returns:
        the Cell for the column, or null if no value exists in the row or none have been + selected in the query (Get/Scan)
        +
      • +
      + + + +
        +
      • +

        getColumnLatestCell

        +
        public Cell getColumnLatestCell(byte[] family,
        +                       int foffset,
        +                       int flength,
        +                       byte[] qualifier,
        +                       int qoffset,
        +                       int qlength)
        +
        The Cell for the most recent timestamp for a given column.
        +
        Parameters:
        family - family name
        foffset - family offset
        flength - family length
        qualifier - column qualifier
        qoffset - qualifier offset
        qlength - qualifier length
        +
        Returns:
        the Cell for the column, or null if no value exists in the row or none have been + selected in the query (Get/Scan)
        +
      • +
      + + + +
        +
      • +

        getValue

        +
        public byte[] getValue(byte[] family,
        +              byte[] qualifier)
        +
        Get the latest version of the specified column. + Note: this call clones the value content of the hosting Cell. See + getValueAsByteBuffer(byte[], byte[]), etc., or listCells() if you would + avoid the cloning.
        +
        Parameters:
        family - family name
        qualifier - column qualifier
        +
        Returns:
        value of latest version of column, null if none found
        +
      • +
      + + + +
        +
      • +

        getValueAsByteBuffer

        +
        public ByteBuffer getValueAsByteBuffer(byte[] family,
        +                              byte[] qualifier)
        +
        Returns the value wrapped in a new ByteBuffer.
        +
        Parameters:
        family - family name
        qualifier - column qualifier
        +
        Returns:
        the latest version of the column, or null if none found
        +
      • +
      + + + +
        +
      • +

        getValueAsByteBuffer

        +
        public ByteBuffer getValueAsByteBuffer(byte[] family,
        +                              int foffset,
        +                              int flength,
        +                              byte[] qualifier,
        +                              int qoffset,
        +                              int qlength)
        +
        Returns the value wrapped in a new ByteBuffer.
        +
        Parameters:
        family - family name
        foffset - family offset
        flength - family length
        qualifier - column qualifier
        qoffset - qualifier offset
        qlength - qualifier length
        +
        Returns:
        the latest version of the column, or null if none found
        +
      • +
      + + + +
        +
      • +

        loadValue

        +
        public boolean loadValue(byte[] family,
        +                byte[] qualifier,
        +                ByteBuffer dst)
        +                  throws BufferOverflowException
        +
        Loads the latest version of the specified column into the provided ByteBuffer. +

        + Does not clear or flip the buffer.

        +
        Parameters:
        family - family name
        qualifier - column qualifier
        dst - the buffer where to write the value
        +
        Returns:
        true if a value was found, false otherwise
        +
        Throws:
        +
        BufferOverflowException - there is insufficient space remaining in the buffer
        +
      • +
      + + + +
        +
      • +

        loadValue

        +
        public boolean loadValue(byte[] family,
        +                int foffset,
        +                int flength,
        +                byte[] qualifier,
        +                int qoffset,
        +                int qlength,
        +                ByteBuffer dst)
        +                  throws BufferOverflowException
        +
        Loads the latest version of the specified column into the provided ByteBuffer. +

        + Does not clear or flip the buffer.

        +
        Parameters:
        family - family name
        foffset - family offset
        flength - family length
        qualifier - column qualifier
        qoffset - qualifier offset
        qlength - qualifier length
        dst - the buffer where to write the value
        +
        Returns:
        true if a value was found, false otherwise
        +
        Throws:
        +
        BufferOverflowException - there is insufficient space remaining in the buffer
        +
      • +
      + + + +
        +
      • +

        containsNonEmptyColumn

        +
        public boolean containsNonEmptyColumn(byte[] family,
        +                             byte[] qualifier)
        +
        Checks if the specified column contains a non-empty value (not a zero-length byte array).
        +
        Parameters:
        family - family name
        qualifier - column qualifier
        +
        Returns:
        whether or not a latest value exists and is not empty
        +
      • +
      + + + +
        +
      • +

        containsNonEmptyColumn

        +
        public boolean containsNonEmptyColumn(byte[] family,
        +                             int foffset,
        +                             int flength,
        +                             byte[] qualifier,
        +                             int qoffset,
        +                             int qlength)
        +
        Checks if the specified column contains a non-empty value (not a zero-length byte array).
        +
        Parameters:
        family - family name
        foffset - family offset
        flength - family length
        qualifier - column qualifier
        qoffset - qualifier offset
        qlength - qualifier length
        +
        Returns:
        whether or not a latest value exists and is not empty
        +
      • +
      + + + +
        +
      • +

        containsEmptyColumn

        +
        public boolean containsEmptyColumn(byte[] family,
        +                          byte[] qualifier)
        +
        Checks if the specified column contains an empty value (a zero-length byte array).
        +
        Parameters:
        family - family name
        qualifier - column qualifier
        +
        Returns:
        whether or not a latest value exists and is empty
        +
      • +
      + + + +
        +
      • +

        containsEmptyColumn

        +
        public boolean containsEmptyColumn(byte[] family,
        +                          int foffset,
        +                          int flength,
        +                          byte[] qualifier,
        +                          int qoffset,
        +                          int qlength)
        +
        Checks if the specified column contains an empty value (a zero-length byte array).
        +
        Parameters:
        family - family name
        foffset - family offset
        flength - family length
        qualifier - column qualifier
        qoffset - qualifier offset
        qlength - qualifier length
        +
        Returns:
        whether or not a latest value exists and is empty
        +
      • +
      + + + +
        +
      • +

        containsColumn

        +
        public boolean containsColumn(byte[] family,
        +                     byte[] qualifier)
        +
        Checks for existence of a value for the specified column (empty or not).
        +
        Parameters:
        family - family name
        qualifier - column qualifier
        +
        Returns:
        true if at least one value exists in the result, false if not
        +
      • +
      + + + +
        +
      • +

        containsColumn

        +
        public boolean containsColumn(byte[] family,
        +                     int foffset,
        +                     int flength,
        +                     byte[] qualifier,
        +                     int qoffset,
        +                     int qlength)
        +
        Checks for existence of a value for the specified column (empty or not).
        +
        Parameters:
        family - family name
        foffset - family offset
        flength - family length
        qualifier - column qualifier
        qoffset - qualifier offset
        qlength - qualifier length
        +
        Returns:
        true if at least one value exists in the result, false if not
        +
      • +
      + + + +
        +
      • +

        getMap

        +
        public NavigableMap<byte[],NavigableMap<byte[],NavigableMap<Long,byte[]>>> getMap()
        +
        Map of families to all versions of its qualifiers and values. +

        + Returns a three level Map of the form: + Map&family,Map<qualifier,Map<timestamp,value>>> +

        + Note: All other map returning methods make use of this map internally.

        +
        Returns:
        map from families to qualifiers to versions
        +
      • +
      + + + +
        +
      • +

        getNoVersionMap

        +
        public NavigableMap<byte[],NavigableMap<byte[],byte[]>> getNoVersionMap()
        +
        Map of families to their most recent qualifiers and values. +

        + Returns a two level Map of the form: Map&family,Map<qualifier,value>> +

        + The most recent version of each qualifier will be used.

        +
        Returns:
        map from families to qualifiers and value
        +
      • +
      + + + +
        +
      • +

        getFamilyMap

        +
        public NavigableMap<byte[],byte[]> getFamilyMap(byte[] family)
        +
        Map of qualifiers to values. +

        + Returns a Map of the form: Map<qualifier,value>

        +
        Parameters:
        family - column family to get
        +
        Returns:
        map of qualifiers to values
        +
      • +
      + + + +
        +
      • +

        value

        +
        public byte[] value()
        +
        Returns the value of the first column in the Result.
        +
        Returns:
        value of the first column
        +
      • +
      + + + +
        +
      • +

        isEmpty

        +
        public boolean isEmpty()
        +
        Check if the underlying Cell [] is empty or not
        +
        Returns:
        true if empty
        +
      • +
      + + + +
        +
      • +

        size

        +
        public int size()
        +
        Returns:
        the size of the underlying Cell []
        +
      • +
      + + + + + + + +
        +
      • +

        compareResults

        +
        public static void compareResults(Result res1,
        +                  Result res2)
        +                           throws Exception
        +
        Does a deep comparison of two Results, down to the byte arrays.
        +
        Parameters:
        res1 - first result to compare
        res2 - second result to compare
        +
        Throws:
        +
        Exception - Every difference is throwing an exception
        +
      • +
      + + + +
        +
      • +

        createCompleteResult

        +
        public static Result createCompleteResult(List<Result> partialResults)
        +                                   throws IOException
        +
        Forms a single result from the partial results in the partialResults list. This method is + useful for reconstructing partial results on the client side.
        +
        Parameters:
        partialResults - list of partial results
        +
        Returns:
        The complete result that is formed by combining all of the partial results together
        +
        Throws:
        +
        IOException - A complete result cannot be formed because the results in the partial list + come from different rows
        +
      • +
      + + + +
        +
      • +

        getTotalSizeOfCells

        +
        public static long getTotalSizeOfCells(Result result)
        +
        Get total size of raw cells
        +
        Parameters:
        result -
        +
        Returns:
        Total size.
        +
      • +
      + + + +
        +
      • +

        copyFrom

        +
        public void copyFrom(Result other)
        +
        Copy another Result into this one. Needed for the old Mapred framework
        +
        Parameters:
        other -
        +
        Throws:
        +
        UnsupportedOperationException - if invoked on instance of EMPTY_RESULT + (which is supposed to be immutable).
        +
      • +
      + + + +
        +
      • +

        cellScanner

        +
        public org.apache.hadoop.hbase.CellScanner cellScanner()
        +
        +
        Specified by:
        +
        cellScanner in interface org.apache.hadoop.hbase.CellScannable
        +
        Returns:
        A CellScanner over the contained Cells
        +
      • +
      + + + +
        +
      • +

        current

        +
        public Cell current()
        +
        +
        Specified by:
        +
        current in interface org.apache.hadoop.hbase.CellScanner
        +
        Returns:
        the current Cell which may be mutable
        +
      • +
      + + + +
        +
      • +

        advance

        +
        public boolean advance()
        +
        Description copied from interface: org.apache.hadoop.hbase.CellScanner
        +
        Advance the scanner 1 cell.
        +
        +
        Specified by:
        +
        advance in interface org.apache.hadoop.hbase.CellScanner
        +
        Returns:
        true if the next cell is found and CellScanner.current() will return a valid Cell
        +
      • +
      + + + + + + + + + + + +
        +
      • +

        isStale

        +
        public boolean isStale()
        +
        Whether or not the results are coming from possibly stale data. Stale results + might be returned if Consistency is not STRONG for the query.
        +
        Returns:
        Whether or not the results are coming from possibly stale data.
        +
      • +
      + + + +
        +
      • +

        isPartial

        +
        public boolean isPartial()
        +
        Whether or not the result is a partial result. Partial results contain a subset of the cells + for a row and should be combined with a result representing the remaining cells in that row to + form a complete (non-partial) result.
        +
        Returns:
        Whether or not the result is a partial result
        +
      • +
      + + + +
        +
      • +

        getStats

        +
        public org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats getStats()
        +
        Returns:
        the associated statistics about the region from which this was returned. Can be + null if stats are disabled.
        +
      • +
      +
    • +
    +
  • +
+
+
+ + + + + +

Copyright © 2007–2015 The Apache Software Foundation. All rights reserved.

+ +