From commits-return-6602-archive-asf-public=cust-asf.ponee.io@kudu.apache.org Fri Oct 26 20:56:59 2018 Return-Path: X-Original-To: archive-asf-public@cust-asf.ponee.io Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by mx-eu-01.ponee.io (Postfix) with SMTP id 24CEA1807BC for ; Fri, 26 Oct 2018 20:56:56 +0200 (CEST) Received: (qmail 22136 invoked by uid 500); 26 Oct 2018 18:56:56 -0000 Mailing-List: contact commits-help@kudu.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@kudu.apache.org Delivered-To: mailing list commits@kudu.apache.org Received: (qmail 21944 invoked by uid 99); 26 Oct 2018 18:56:56 -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; Fri, 26 Oct 2018 18:56:56 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 3E003E11F2; Fri, 26 Oct 2018 18:56:55 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: abukor@apache.org To: commits@kudu.apache.org Date: Fri, 26 Oct 2018 18:57:16 -0000 Message-Id: <9555f405e2a8423cb003d093b08679df@git.apache.org> In-Reply-To: References: X-Mailer: ASF-Git Admin Mailer Subject: [23/52] [abbrv] [partial] kudu git commit: Updating web site for Kudu 1.8.0 release http://git-wip-us.apache.org/repos/asf/kudu/blob/1fefa84c/releases/1.8.0/apidocs/org/apache/kudu/client/AsyncKuduScanner.ReadMode.html ---------------------------------------------------------------------- diff --git a/releases/1.8.0/apidocs/org/apache/kudu/client/AsyncKuduScanner.ReadMode.html b/releases/1.8.0/apidocs/org/apache/kudu/client/AsyncKuduScanner.ReadMode.html new file mode 100644 index 0000000..2902996 --- /dev/null +++ b/releases/1.8.0/apidocs/org/apache/kudu/client/AsyncKuduScanner.ReadMode.html @@ -0,0 +1,402 @@ + + + + + + +AsyncKuduScanner.ReadMode (Kudu 1.8.0 API) + + + + + + + + + + + +
+
org.apache.kudu.client
+

Enum AsyncKuduScanner.ReadMode

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

      Enum Constant Detail

      + + + +
        +
      • +

        READ_LATEST

        +
        public static final AsyncKuduScanner.ReadMode READ_LATEST
        +
        When READ_LATEST is specified the server will always return committed writes at + the time the request was received. This type of read does not return a snapshot + timestamp and is not repeatable. + + In ACID terms this corresponds to Isolation mode: "Read Committed" + + This is the default mode.
        +
      • +
      + + + +
        +
      • +

        READ_AT_SNAPSHOT

        +
        public static final AsyncKuduScanner.ReadMode READ_AT_SNAPSHOT
        +
        When READ_AT_SNAPSHOT is specified the server will attempt to perform a read + at the provided timestamp. If no timestamp is provided the server will take the + current time as the snapshot timestamp. In this mode reads are repeatable, i.e. + all future reads at the same timestamp will yield the same data. This is + performed at the expense of waiting for in-flight transactions whose timestamp + is lower than the snapshot's timestamp to complete, so it might incur a latency + penalty. + + In ACID terms this, by itself, corresponds to Isolation mode "Repeatable + Read". If all writes to the scanned tablet are made externally consistent, + then this corresponds to Isolation mode "Strict-Serializable". + + Note: there currently "holes", which happen in rare edge conditions, by which writes + are sometimes not externally consistent even when action was taken to make them so. + In these cases Isolation may degenerate to mode "Read Committed". See KUDU-430.
        +
      • +
      + + + +
        +
      • +

        READ_YOUR_WRITES

        +
        public static final AsyncKuduScanner.ReadMode READ_YOUR_WRITES
        +
        When @c READ_YOUR_WRITES is specified, the client will perform a read + such that it follows all previously known writes and reads from this client. + Specifically this mode: + (1) ensures read-your-writes and read-your-reads session guarantees, + (2) minimizes latency caused by waiting for outstanding write + transactions to complete. + + Reads in this mode are not repeatable: two READ_YOUR_WRITES reads, even if + they provide the same propagated timestamp bound, can execute at different + timestamps and thus may return different results.
        +
      • +
      +
    • +
    + +
      +
    • + + +

      Method Detail

      + + + +
        +
      • +

        values

        +
        public static AsyncKuduScanner.ReadMode[] values()
        +
        Returns an array containing the constants of this enum type, in +the order they are declared. This method may be used to iterate +over the constants as follows: +
        +for (AsyncKuduScanner.ReadMode c : AsyncKuduScanner.ReadMode.values())
        +    System.out.println(c);
        +
        +
        +
        Returns:
        +
        an array containing the constants of this enum type, in the order they are declared
        +
        +
      • +
      + + + +
        +
      • +

        valueOf

        +
        public static AsyncKuduScanner.ReadMode valueOf(String name)
        +
        Returns the enum constant of this type with the specified name. +The string must match exactly an identifier used to declare an +enum constant in this type. (Extraneous whitespace characters are +not permitted.)
        +
        +
        Parameters:
        +
        name - the name of the enum constant to be returned.
        +
        Returns:
        +
        the enum constant with the specified name
        +
        Throws:
        +
        IllegalArgumentException - if this enum type has no constant with the specified name
        +
        NullPointerException - if the argument is null
        +
        +
      • +
      +
    • +
    +
  • +
+
+
+ + + + + +

Copyright © 2018 The Apache Software Foundation. All rights reserved.

+ + http://git-wip-us.apache.org/repos/asf/kudu/blob/1fefa84c/releases/1.8.0/apidocs/org/apache/kudu/client/AsyncKuduScanner.html ---------------------------------------------------------------------- diff --git a/releases/1.8.0/apidocs/org/apache/kudu/client/AsyncKuduScanner.html b/releases/1.8.0/apidocs/org/apache/kudu/client/AsyncKuduScanner.html new file mode 100644 index 0000000..fdbe44d --- /dev/null +++ b/releases/1.8.0/apidocs/org/apache/kudu/client/AsyncKuduScanner.html @@ -0,0 +1,537 @@ + + + + + + +AsyncKuduScanner (Kudu 1.8.0 API) + + + + + + + + + + + +
+
org.apache.kudu.client
+

Class AsyncKuduScanner

+
+
+ +
+
    +
  • +
    +
    +
    @InterfaceAudience.Public
    + @InterfaceStability.Unstable
    +public final class AsyncKuduScanner
    +extends Object
    +
    Creates a scanner to read data from Kudu. +

    + This class is not synchronized as it's expected to be + used from a single thread at a time. It's rarely (if ever?) useful to + scan concurrently from a shared scanner using multiple threads. If you + want to optimize large table scans using extra parallelism, create a few + scanners through the KuduScanToken API. Or use MapReduce. +

    + There's no method in this class to explicitly open the scanner. It will open + itself automatically when you start scanning by calling nextRows(). + Also, the scanner will automatically call close() when it reaches the + end key. If, however, you would like to stop scanning before reaching the + end key, you must call close() before disposing of the scanner. + Note that it's always safe to call close() on a scanner. +

    + A AsyncKuduScanner is not re-usable. Should you want to scan the same rows + or the same table again, you must create a new one. + +

    A note on passing byte arrays in argument

    + None of the method that receive a byte[] in argument will copy it. + For more info, please refer to the documentation of KuduRpc. +

    A note on passing Strings in argument

    + All strings are assumed to use the platform's default charset.
    +
  • +
+
+
+ +
+
+
    +
  • + +
      +
    • + + +

      Method Detail

      + + + +
        +
      • +

        getLimit

        +
        public long getLimit()
        +
        Returns the maximum number of rows that this scanner was configured to return.
        +
        +
        Returns:
        +
        a long representing the maximum number of rows that can be returned
        +
        +
      • +
      + + + +
        +
      • +

        hasMoreRows

        +
        public boolean hasMoreRows()
        +
        Tells if the last rpc returned that there might be more rows to scan.
        +
        +
        Returns:
        +
        true if there might be more data to scan, else false
        +
        +
      • +
      + + + +
        +
      • +

        getCacheBlocks

        +
        public boolean getCacheBlocks()
        +
        Returns if this scanner was configured to cache data blocks or not.
        +
        +
        Returns:
        +
        true if this scanner will cache blocks, else else.
        +
        +
      • +
      + + + +
        +
      • +

        getBatchSizeBytes

        +
        public long getBatchSizeBytes()
        +
        Returns the maximum number of bytes returned by the scanner, on each batch.
        +
        +
        Returns:
        +
        a long representing the maximum number of bytes that a scanner can receive at once + from a tablet server
        +
        +
      • +
      + + + +
        +
      • +

        getReadMode

        +
        public AsyncKuduScanner.ReadMode getReadMode()
        +
        Returns the ReadMode for this scanner.
        +
        +
        Returns:
        +
        the configured read mode for this scanner
        +
        +
      • +
      + + + +
        +
      • +

        getScanRequestTimeout

        +
        public long getScanRequestTimeout()
        +
        Returns the scan request timeout for this scanner.
        +
        +
        Returns:
        +
        the scan request timeout, in milliseconds
        +
        +
      • +
      + + + +
        +
      • +

        getProjectionSchema

        +
        public Schema getProjectionSchema()
        +
        Returns the projection schema of this scanner. If specific columns were + not specified during scanner creation, the table schema is returned.
        +
        +
        Returns:
        +
        the projection schema for this scanner
        +
        +
      • +
      + + + +
        +
      • +

        nextRows

        +
        public com.stumbleupon.async.Deferred<RowResultIterator> nextRows()
        +
        Scans a number of rows. +

        + Once this method returns null once (which indicates that this + Scanner is done scanning), calling it again leads to an undefined + behavior.

        +
        +
        Returns:
        +
        a deferred list of rows.
        +
        +
      • +
      + + + +
        +
      • +

        isClosed

        +
        public boolean isClosed()
        +
        +
        Returns:
        +
        true if the scanner has been closed.
        +
        +
      • +
      + + + +
        +
      • +

        close

        +
        public com.stumbleupon.async.Deferred<RowResultIterator> close()
        +
        Closes this scanner (don't forget to call this when you're done with it!). +

        + Closing a scanner already closed has no effect. The deferred returned + will be called back immediately.

        +
        +
        Returns:
        +
        A deferred object that indicates the completion of the request. + The Object can be null, a RowResultIterator if there was data left + in the scanner, or an Exception.
        +
        +
      • +
      + + + + + + + +
        +
      • +

        keepAlive

        +
        public com.stumbleupon.async.Deferred<Void> keepAlive()
        +
        Keep the current remote scanner alive. +

        + Keep the current remote scanner alive on the Tablet server for an + additional time-to-live. This is useful if the interval in between + nextRows() calls is big enough that the remote scanner might be garbage + collected. The scanner time-to-live can be configured on the tablet + server via the --scanner_ttl_ms configuration flag and has a default + of 60 seconds. +

        + This does not invalidate any previously fetched results. +

        + Note that an error returned by this method should not be taken as indication + that the scan has failed. Subsequent calls to nextRows() might still be successful, + particularly if the scanner is configured to be fault tolerant.

        +
        +
        Returns:
        +
        A deferred object that indicates the completion of the request.
        +
        Throws:
        +
        IllegalStateException - if the scanner is already closed.
        +
        +
      • +
      +
    • +
    +
  • +
+
+
+ + + + + +

Copyright © 2018 The Apache Software Foundation. All rights reserved.

+ +