Return-Path: X-Original-To: archive-asf-public-internal@cust-asf2.ponee.io Delivered-To: archive-asf-public-internal@cust-asf2.ponee.io Received: from cust-asf.ponee.io (cust-asf.ponee.io [163.172.22.183]) by cust-asf2.ponee.io (Postfix) with ESMTP id BE822200CD9 for ; Thu, 20 Jul 2017 00:07:31 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id BD07B16A0B1; Wed, 19 Jul 2017 22:07:31 +0000 (UTC) Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by cust-asf.ponee.io (Postfix) with SMTP id 9B46416A0BB for ; Thu, 20 Jul 2017 00:07:29 +0200 (CEST) Received: (qmail 49411 invoked by uid 500); 19 Jul 2017 22:07:22 -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 46373 invoked by uid 99); 19 Jul 2017 22:07:20 -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, 19 Jul 2017 22:07:20 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 6DF52F5EC3; Wed, 19 Jul 2017 22:07:18 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: git-site-role@apache.org To: commits@hbase.apache.org Date: Wed, 19 Jul 2017 22:08:03 -0000 Message-Id: <528b5cd3dc7b41c4812941c03f46b199@git.apache.org> In-Reply-To: <06eabf77f2c545f393210f621f2f13a5@git.apache.org> References: <06eabf77f2c545f393210f621f2f13a5@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [47/51] [partial] hbase-site git commit: Published site at 82d554e3783372cc6b05489452c815b57c06f6cd. archived-at: Wed, 19 Jul 2017 22:07:31 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9eba7fcf/devapidocs/org/apache/hadoop/hbase/client/ConnectionUtils.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/ConnectionUtils.html b/devapidocs/org/apache/hadoop/hbase/client/ConnectionUtils.html index a047f6a..e678daa 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/ConnectionUtils.html +++ b/devapidocs/org/apache/hadoop/hbase/client/ConnectionUtils.html @@ -18,7 +18,7 @@ catch(err) { } //--> -var methods = {"i0":9,"i1":9,"i2":9,"i3":9,"i4":9,"i5":9,"i6":9,"i7":9,"i8":9,"i9":9,"i10":9,"i11":9,"i12":9,"i13":9,"i14":9,"i15":9,"i16":9,"i17":9,"i18":9,"i19":9,"i20":9,"i21":9,"i22":9,"i23":9,"i24":9,"i25":9,"i26":9,"i27":9,"i28":9,"i29":9,"i30":9}; +var methods = {"i0":9,"i1":9,"i2":9,"i3":9,"i4":9,"i5":9,"i6":9,"i7":9,"i8":9,"i9":9,"i10":9,"i11":9,"i12":9,"i13":9,"i14":9,"i15":9,"i16":9,"i17":9,"i18":9,"i19":9,"i20":9,"i21":9,"i22":9,"i23":9,"i24":9,"i25":9,"i26":9,"i27":9,"i28":9,"i29":9}; var tabs = {65535:["t0","All Methods"],1:["t1","Static Methods"],8:["t4","Concrete Methods"]}; var altColor = "altColor"; var rowColor = "rowColor"; @@ -209,41 +209,34 @@ extends Method and Description -static long -addJitter(long pause, - float jitter) -
Adds / subs an up to 50% jitter to a pause time.
- - - (package private) static <T> CompletableFuture<List<T>> allOf(List<CompletableFuture<T>> futures)  - + (package private) static long calcEstimatedSize(Result rs)  - + (package private) static void checkHasFamilies(Mutation mutation)  - + (package private) static byte[] createCloseRowBefore(byte[] row)
Create a row before the specified row and very close to the specified row.
- + (package private) static byte[] createClosestRowAfter(byte[] row)
Create the closest row after the specified row
- + static ScanResultCache createScanResultCache(Scan scan)  - + static ClusterConnection createShortCircuitConnection(org.apache.hadoop.conf.Configuration conf, ExecutorService pool, @@ -255,27 +248,27 @@ extends + (package private) static Result filterCells(Result result, Cell keepCellsAfter)  - + (package private) static RegionLocateType getLocateType(Scan scan)  - + private static String getMyAddress()  - + static long getPauseTime(long pause, int tries)
Calculate pause time.
- + (package private) static String getStubKey(String serviceName, ServerName serverName, @@ -283,59 +276,59 @@ extends Get a unique key for the rpc stub to the given server. - + (package private) static void incRegionCountMetrics(ScanMetrics scanMetrics)  - + (package private) static void incRPCCallsMetrics(ScanMetrics scanMetrics, boolean isRegionServerRemote)  - + (package private) static void incRPCRetriesMetrics(ScanMetrics scanMetrics, boolean isRegionServerRemote)  - + static NonceGenerator injectNonceGeneratorForTesting(ClusterConnection conn, NonceGenerator cnm)  - + (package private) static boolean isEmptyStartRow(byte[] row)  - + (package private) static boolean isEmptyStopRow(byte[] row)  - + (package private) static boolean isRemote(String host)  - + (package private) static boolean noMoreResultsForReverseScan(Scan scan, HRegionInfo info)  - + (package private) static boolean noMoreResultsForScan(Scan scan, HRegionInfo info)  - + (package private) static void resetController(HBaseRpcController controller, long timeoutNs)  - + (package private) static int retries2Attempts(int retries)
Return retires + 1.
- + static void setServerSideHConnectionRetriesConfig(org.apache.hadoop.conf.Configuration c, String sn, @@ -344,31 +337,31 @@ extends + static void setupMasterlessConnection(org.apache.hadoop.conf.Configuration conf)
Setup the connection class, so that it will not depend on master being online.
- + (package private) static Get toCheckExistenceOnly(Get get)  - + (package private) static List<Get> toCheckExistenceOnly(List<Get> gets)  - + (package private) static Throwable translateException(Throwable t)  - + (package private) static void updateResultsMetrics(ScanMetrics scanMetrics, Result[] rrs, boolean isRegionServerRemote)  - + (package private) static void updateServerSideMetrics(ScanMetrics scanMetrics, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponse response) @@ -413,7 +406,7 @@ extends
  • NO_NONCE_GENERATOR

    -
    static final NonceGenerator NO_NONCE_GENERATOR
    +
    static final NonceGenerator NO_NONCE_GENERATOR
    Dummy nonce generator for disabled nonces.
  • @@ -423,7 +416,7 @@ extends
  • MAX_BYTE_ARRAY

    -
    static final byte[] MAX_BYTE_ARRAY
    +
    static final byte[] MAX_BYTE_ARRAY
  • @@ -432,7 +425,7 @@ extends
  • SLEEP_DELTA_NS

    -
    static final long SLEEP_DELTA_NS
    +
    static final long SLEEP_DELTA_NS
  • @@ -441,7 +434,7 @@ extends
  • MY_ADDRESS

    -
    private static final String MY_ADDRESS
    +
    private static final String MY_ADDRESS
  • @@ -487,29 +480,13 @@ extends - - -
      -
    • -

      addJitter

      -
      public static long addJitter(long pause,
      -                             float jitter)
      -
      Adds / subs an up to 50% jitter to a pause time. Minimum is 1.
      -
      -
      Parameters:
      -
      pause - the expected pause.
      -
      jitter - the jitter ratio, between 0 and 1, exclusive.
      -
      -
    • -
    @@ -598,7 +575,7 @@ extends
  • getStubKey

    -
    static String getStubKey(String serviceName,
    +
    static String getStubKey(String serviceName,
                              ServerName serverName,
                              boolean hostnameCanChange)
    Get a unique key for the rpc stub to the given server.
    @@ -610,7 +587,7 @@ extends
  • checkHasFamilies

    -
    static void checkHasFamilies(Mutation mutation)
    +
    static void checkHasFamilies(Mutation mutation)
  • @@ -619,7 +596,7 @@ extends
  • createClosestRowAfter

    -
    static byte[] createClosestRowAfter(byte[] row)
    +
    static byte[] createClosestRowAfter(byte[] row)
    Create the closest row after the specified row
  • @@ -629,7 +606,7 @@ extends
  • createCloseRowBefore

    -
    static byte[] createCloseRowBefore(byte[] row)
    +
    static byte[] createCloseRowBefore(byte[] row)
    Create a row before the specified row and very close to the specified row.
  • @@ -639,7 +616,7 @@ extends
  • isEmptyStartRow

    -
    static boolean isEmptyStartRow(byte[] row)
    +
    static boolean isEmptyStartRow(byte[] row)
  • @@ -648,7 +625,7 @@ extends
  • isEmptyStopRow

    -
    static boolean isEmptyStopRow(byte[] row)
    +
    static boolean isEmptyStopRow(byte[] row)
  • @@ -657,7 +634,7 @@ extends
  • resetController

    -
    static void resetController(HBaseRpcController controller,
    +
    static void resetController(HBaseRpcController controller,
                                 long timeoutNs)
  • @@ -667,7 +644,7 @@ extends
  • translateException

    -
    static Throwable translateException(Throwable t)
    +
    static Throwable translateException(Throwable t)
  • @@ -676,7 +653,7 @@ extends
  • calcEstimatedSize

    -
    static long calcEstimatedSize(Result rs)
    +
    static long calcEstimatedSize(Result rs)
  • @@ -685,7 +662,7 @@ extends
  • filterCells

    -
    static Result filterCells(Result result,
    +
    static Result filterCells(Result result,
                               Cell keepCellsAfter)
  • @@ -695,7 +672,7 @@ extends
  • toCheckExistenceOnly

    -
    static Get toCheckExistenceOnly(Get get)
    +
    static Get toCheckExistenceOnly(Get get)
  • @@ -704,7 +681,7 @@ extends
  • toCheckExistenceOnly

    -
    static List<GettoCheckExistenceOnly(List<Get> gets)
    +
    static List<GettoCheckExistenceOnly(List<Get> gets)
  • @@ -713,7 +690,7 @@ extends
  • getLocateType

    -
    static RegionLocateType getLocateType(Scan scan)
    +
    static RegionLocateType getLocateType(Scan scan)
  • @@ -722,7 +699,7 @@ extends
  • noMoreResultsForScan

    -
    static boolean noMoreResultsForScan(Scan scan,
    +
    static boolean noMoreResultsForScan(Scan scan,
                                         HRegionInfo info)
  • @@ -732,7 +709,7 @@ extends
  • noMoreResultsForReverseScan

    -
    static boolean noMoreResultsForReverseScan(Scan scan,
    +
    static boolean noMoreResultsForReverseScan(Scan scan,
                                                HRegionInfo info)
  • @@ -742,7 +719,7 @@ extends
  • allOf

    -
    static <T> CompletableFuture<List<T>> allOf(List<CompletableFuture<T>> futures)
    +
    static <T> CompletableFuture<List<T>> allOf(List<CompletableFuture<T>> futures)
  • @@ -751,7 +728,7 @@ extends
  • createScanResultCache

    -
    public static ScanResultCache createScanResultCache(Scan scan)
    +
    public static ScanResultCache createScanResultCache(Scan scan)
  • @@ -760,7 +737,7 @@ extends
  • getMyAddress

    -
    private static String getMyAddress()
    +
    private static String getMyAddress()
  • @@ -769,7 +746,7 @@ extends
  • isRemote

    -
    static boolean isRemote(String host)
    +
    static boolean isRemote(String host)
  • @@ -778,7 +755,7 @@ extends
  • incRPCCallsMetrics

    -
    static void incRPCCallsMetrics(ScanMetrics scanMetrics,
    +
    static void incRPCCallsMetrics(ScanMetrics scanMetrics,
                                    boolean isRegionServerRemote)
  • @@ -788,7 +765,7 @@ extends
  • incRPCRetriesMetrics

    -
    static void incRPCRetriesMetrics(ScanMetrics scanMetrics,
    +
    static void incRPCRetriesMetrics(ScanMetrics scanMetrics,
                                      boolean isRegionServerRemote)
  • @@ -798,7 +775,7 @@ extends
  • updateResultsMetrics

    -
    static void updateResultsMetrics(ScanMetrics scanMetrics,
    +
    static void updateResultsMetrics(ScanMetrics scanMetrics,
                                      Result[] rrs,
                                      boolean isRegionServerRemote)
  • @@ -809,7 +786,7 @@ extends
  • updateServerSideMetrics

    -
    static void updateServerSideMetrics(ScanMetrics scanMetrics,
    +
    static void updateServerSideMetrics(ScanMetrics scanMetrics,
                                         org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponse response)
    Use the scan metrics returned by the server to add to the identically named counters in the client side metrics. If a counter does not exist with the same name as the server side metric, @@ -822,7 +799,7 @@ extends
  • incRegionCountMetrics

    -
    static void incRegionCountMetrics(ScanMetrics scanMetrics)
    +
    static void incRegionCountMetrics(ScanMetrics scanMetrics)
  • http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9eba7fcf/devapidocs/org/apache/hadoop/hbase/client/FlushRegionCallable.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/FlushRegionCallable.html b/devapidocs/org/apache/hadoop/hbase/client/FlushRegionCallable.html index 86e893e..016a56c 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/FlushRegionCallable.html +++ b/devapidocs/org/apache/hadoop/hbase/client/FlushRegionCallable.html @@ -162,7 +162,7 @@ extends RegionAdminServiceCallable -connection, location, MIN_WAIT_DEAD_SERVER, replicaId, row, rpcControllerFactory, stub, tableName
  • +connection, location, replicaId, row, rpcControllerFactory, stub, tableName http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9eba7fcf/devapidocs/org/apache/hadoop/hbase/client/MultiServerCallable.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/MultiServerCallable.html b/devapidocs/org/apache/hadoop/hbase/client/MultiServerCallable.html index a45ba7c..6648f56 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/MultiServerCallable.html +++ b/devapidocs/org/apache/hadoop/hbase/client/MultiServerCallable.html @@ -170,7 +170,7 @@ extends RegionServerCallable -location, MIN_WAIT_DEAD_SERVER, rpcController, stub +location, rpcController, stub http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9eba7fcf/devapidocs/org/apache/hadoop/hbase/client/NoncedRegionServerCallable.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/NoncedRegionServerCallable.html b/devapidocs/org/apache/hadoop/hbase/client/NoncedRegionServerCallable.html index c653960..63ddc80 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/NoncedRegionServerCallable.html +++ b/devapidocs/org/apache/hadoop/hbase/client/NoncedRegionServerCallable.html @@ -170,7 +170,7 @@ extends RegionServerCallable -location, MIN_WAIT_DEAD_SERVER, rpcController, stub +location, rpcController, stub http://git-wip-us.apache.org/repos/asf/hbase-site/blob/9eba7fcf/devapidocs/org/apache/hadoop/hbase/client/RegionAdminServiceCallable.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/RegionAdminServiceCallable.html b/devapidocs/org/apache/hadoop/hbase/client/RegionAdminServiceCallable.html index e0ec60a..60f6e94 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/RegionAdminServiceCallable.html +++ b/devapidocs/org/apache/hadoop/hbase/client/RegionAdminServiceCallable.html @@ -155,26 +155,22 @@ implements location  -protected static int -MIN_WAIT_DEAD_SERVER  - - protected int replicaId  - + protected byte[] row  - + protected RpcControllerFactory rpcControllerFactory  - + protected org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface stub  - + protected TableName tableName  @@ -379,25 +375,12 @@ implements - @@ -412,7 +395,7 @@ implements
  • RegionAdminServiceCallable

    -
    public RegionAdminServiceCallable(ClusterConnection connection,
    +
    public RegionAdminServiceCallable(ClusterConnection connection,
                                       RpcControllerFactory rpcControllerFactory,
                                       TableName tableName,
                                       byte[] row)
    @@ -424,7 +407,7 @@ implements
  • RegionAdminServiceCallable

    -
    public RegionAdminServiceCallable(ClusterConnection connection,
    +
    public RegionAdminServiceCallable(ClusterConnection connection,
                                       RpcControllerFactory rpcControllerFactory,
                                       HRegionLocation location,
                                       TableName tableName,
    @@ -437,7 +420,7 @@ implements 
     
  • RegionAdminServiceCallable

    -
    public RegionAdminServiceCallable(ClusterConnection connection,
    +
    public RegionAdminServiceCallable(ClusterConnection connection,
                                       RpcControllerFactory rpcControllerFactory,
                                       HRegionLocation location,
                                       TableName tableName,
    @@ -459,7 +442,7 @@ implements 
     
  • prepare

    -
    public void prepare(boolean reload)
    +
    public void prepare(boolean reload)
                  throws IOException
    Description copied from interface: RetryingCallable
    Prepare by setting up any connections to servers, etc., ahead of call invocation. @@ -480,7 +463,7 @@ implements
  • setStub

    -
    protected void setStub(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface stub)
    +
    protected void setStub(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface stub)
  • @@ -489,7 +472,7 @@ implements
  • getLocation

    -
    public HRegionLocation getLocation(boolean useCache)
    +
    public HRegionLocation getLocation(boolean useCache)
                                 throws IOException
    Throws:
    @@ -503,7 +486,7 @@ implements
  • throwable

    -
    public void throwable(Throwable t,
    +
    public void throwable(Throwable t,
                           boolean retrying)
    Description copied from interface: RetryingCallable
    Called when call throws an exception and we are going to retry; take action to @@ -525,7 +508,7 @@ implements
  • getConnection

    -
    Connection getConnection()
    +
    Connection getConnection()
    Returns:
    Connection instance used by this Callable.
    @@ -538,7 +521,7 @@ implements
  • getExceptionMessage

    -
    protected String getExceptionMessage()
    +
    protected String getExceptionMessage()
  • @@ -547,7 +530,7 @@ implements
  • getExceptionMessageAdditionalDetail

    -
    public String getExceptionMessageAdditionalDetail()
    +
    public String getExceptionMessageAdditionalDetail()
    Specified by:
    getExceptionMessageAdditionalDetail in interface RetryingCallable<T>
    @@ -564,7 +547,7 @@ implements
  • sleep

    -
    public long sleep(long pause,
    +
    public long sleep(long pause,
                       int tries)
    Specified by:
    @@ -583,7 +566,7 @@ implements
  • getRegionLocations

    -
    public static RegionLocations getRegionLocations(ClusterConnection connection,
    +
    public static RegionLocations getRegionLocations(ClusterConnection connection,
                                                      TableName tableName,
                                                      byte[] row,
                                                      boolean useCache,
    @@ -605,7 +588,7 @@ implements 
     
  • call

    -
    public T call(int callTimeout)
    +
    public T call(int callTimeout)
            throws IOException
    Override that changes Exception from Exception to IOException. It also does setup of an rpcController and calls through to the unimplemented @@ -628,7 +611,7 @@ implements
  • getCurrentPayloadCarryingRpcController

    -
    HBaseRpcController getCurrentPayloadCarryingRpcController()
    +
    HBaseRpcController getCurrentPayloadCarryingRpcController()
  • @@ -637,7 +620,7 @@ implements
  • call

    -
    protected abstract T call(HBaseRpcController rpcController)
    +
    protected abstract T call(HBaseRpcController rpcController)
                        throws Exception
    Run RPC call.