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 D426B200D03 for ; Sat, 9 Sep 2017 17:13:59 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id D2DBF1609D7; Sat, 9 Sep 2017 15:13:59 +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 1EE951609D5 for ; Sat, 9 Sep 2017 17:13:56 +0200 (CEST) Received: (qmail 34146 invoked by uid 500); 9 Sep 2017 15:13:56 -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 32755 invoked by uid 99); 9 Sep 2017 15:13:54 -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; Sat, 09 Sep 2017 15:13:54 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 0DD62F5715; Sat, 9 Sep 2017 15:13:54 +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: Sat, 09 Sep 2017 15:13:58 -0000 Message-Id: <4ff5230f28a64d90bfb7a2f0c23162fe@git.apache.org> In-Reply-To: <66995acc0cf745738afee05fa04155ea@git.apache.org> References: <66995acc0cf745738afee05fa04155ea@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [06/51] [partial] hbase-site git commit: Published site at . archived-at: Sat, 09 Sep 2017 15:13:59 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/1490b3ab/devapidocs/org/apache/hadoop/hbase/client/RawAsyncHBaseAdmin.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/RawAsyncHBaseAdmin.html b/devapidocs/org/apache/hadoop/hbase/client/RawAsyncHBaseAdmin.html index 341730a..9043e21 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/RawAsyncHBaseAdmin.html +++ b/devapidocs/org/apache/hadoop/hbase/client/RawAsyncHBaseAdmin.html @@ -114,7 +114,7 @@ var activeTableTab = "activeTableTab";

@InterfaceAudience.Private
-public class RawAsyncHBaseAdmin
+public class RawAsyncHBaseAdmin
 extends Object
 implements AsyncAdmin
The implementation of AsyncAdmin.
@@ -628,7 +628,7 @@ implements CompletableFuture<ClusterStatus> -getClusterStatus(ClusterStatus.Options options)  +getClusterStatus(EnumSet<ClusterStatus.Option> options)  CompletableFuture<CompactionState> @@ -655,127 +655,139 @@ implements +CompletableFuture<String> +getLocks() +
List locks.
+ + + CompletableFuture<NamespaceDescriptor> getNamespaceDescriptor(String name)
Get a namespace descriptor by name
- + CompletableFuture<List<HRegionInfo>> getOnlineRegions(ServerName serverName)
Get all the online regions on a region server.
- + private void getProcedureResult(long procId, CompletableFuture<Void> future)  - + +CompletableFuture<String> +getProcedures() +
List procedures
+ + + CompletableFuture<List<QuotaSettings>> getQuota(QuotaFilter filter)
List the quotas based on the filter.
- + private CompletableFuture<HRegionInfo> getRegionInfo(byte[] regionNameOrEncodedRegionName)
Get the region info for the passed region name.
- + CompletableFuture<List<RegionLoad>> getRegionLoads(ServerName serverName, Optional<TableName> tableName)
Get a list of RegionLoad of all regions hosted on a region seerver for a table.
- + (package private) CompletableFuture<HRegionLocation> getRegionLocation(byte[] regionNameOrEncodedRegionName)
Get the region location for the passed region name.
- + CompletableFuture<ReplicationPeerConfig> getReplicationPeerConfig(String peerId)
Returns the configured ReplicationPeerConfig for the specified peer
- + CompletableFuture<List<SecurityCapability>> getSecurityCapabilities()  - + private byte[][] getSplitKeys(byte[] startKey, byte[] endKey, int numRegions)  - + CompletableFuture<TableDescriptor> getTableDescriptor(TableName tableName)
Method for getting the tableDescriptor
- + private CompletableFuture<List<HRegionLocation>> getTableHRegionLocations(TableName tableName)
List all region locations for the specific table.
- + CompletableFuture<List<HRegionInfo>> getTableRegions(TableName tableName)
Get the regions of a given table.
- + private CompletableFuture<Void> internalDeleteSnapshot(SnapshotDescription snapshot)  - + private CompletableFuture<Void> internalRestoreSnapshot(String snapshotName, TableName tableName)  - + CompletableFuture<Boolean> isBalancerOn()
Query the current state of the balancer.
- + CompletableFuture<Boolean> isCatalogJanitorOn()
Query on the catalog janitor state.
- + CompletableFuture<Boolean> isCleanerChoreOn()
Query the current state of the cleaner chore.
- + CompletableFuture<Boolean> isMasterInMaintenanceMode()
Check whether master is in maintenance mode
- + CompletableFuture<Boolean> isMergeOn()
Query the current state of the Merge switch.
- + CompletableFuture<Boolean> isNormalizerOn()
Query the current state of the region normalizer
- + CompletableFuture<Boolean> isProcedureFinished(String signature, String instance, @@ -783,27 +795,27 @@ implements Check the current state of the specified procedure. - + CompletableFuture<Boolean> isSnapshotFinished(SnapshotDescription snapshot)
Check the current state of the passed snapshot.
- + CompletableFuture<Boolean> isSplitOn()
Query the current state of the Split switch.
- + private CompletableFuture<Boolean> isSplitOrMergeOn(MasterSwitchType switchType)  - + CompletableFuture<Boolean> isTableAvailable(TableName tableName)  - + CompletableFuture<Boolean> isTableAvailable(TableName tableName, byte[][] splitKeys) @@ -811,38 +823,26 @@ implements + CompletableFuture<Boolean> isTableDisabled(TableName tableName)  - + CompletableFuture<Boolean> isTableEnabled(TableName tableName)  - + CompletableFuture<List<ServerName>> listDrainingRegionServers()
List region servers marked as draining to not get additional regions assigned to them.
- + CompletableFuture<List<NamespaceDescriptor>> listNamespaceDescriptors()
List available namespace descriptors
- -CompletableFuture<List<LockInfo>> -listProcedureLocks() -
List procedure locks.
- - - -CompletableFuture<List<ProcedureInfo>> -listProcedures() -
List procedures
- - CompletableFuture<List<TableCFs>> listReplicatedTableCFs() @@ -1199,7 +1199,7 @@ implements
  • FLUSH_TABLE_PROCEDURE_SIGNATURE

    -
    public static final String FLUSH_TABLE_PROCEDURE_SIGNATURE
    +
    public static final String FLUSH_TABLE_PROCEDURE_SIGNATURE
    See Also:
    Constant Field Values
    @@ -1212,7 +1212,7 @@ implements
  • LOG

    -
    private static final org.apache.commons.logging.Log LOG
    +
    private static final org.apache.commons.logging.Log LOG
  • @@ -1221,7 +1221,7 @@ implements
  • connection

    -
    private final AsyncConnectionImpl connection
    +
    private final AsyncConnectionImpl connection
  • @@ -1230,7 +1230,7 @@ implements
  • metaTable

    -
    private final RawAsyncTable metaTable
    +
    private final RawAsyncTable metaTable
  • @@ -1239,7 +1239,7 @@ implements
  • rpcTimeoutNs

    -
    private final long rpcTimeoutNs
    +
    private final long rpcTimeoutNs
  • @@ -1248,7 +1248,7 @@ implements
  • operationTimeoutNs

    -
    private final long operationTimeoutNs
    +
    private final long operationTimeoutNs
  • @@ -1257,7 +1257,7 @@ implements
  • pauseNs

    -
    private final long pauseNs
    +
    private final long pauseNs
  • @@ -1266,7 +1266,7 @@ implements
  • maxAttempts

    -
    private final int maxAttempts
    +
    private final int maxAttempts
  • @@ -1275,7 +1275,7 @@ implements
  • startLogErrorsCnt

    -
    private final int startLogErrorsCnt
    +
    private final int startLogErrorsCnt
  • @@ -1284,7 +1284,7 @@ implements
  • ng

    -
    private final NonceGenerator ng
    +
    private final NonceGenerator ng
  • @@ -1301,7 +1301,7 @@ implements
  • RawAsyncHBaseAdmin

    -
    RawAsyncHBaseAdmin(AsyncConnectionImpl connection,
    +
    RawAsyncHBaseAdmin(AsyncConnectionImpl connection,
                        AsyncAdminBuilderBase builder)
  • @@ -1319,7 +1319,7 @@ implements
  • newMasterCaller

    -
    private <T> AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder<T> newMasterCaller()
    +
    private <T> AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder<T> newMasterCaller()
  • @@ -1328,7 +1328,7 @@ implements
  • newAdminCaller

    -
    private <T> AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder<T> newAdminCaller()
    +
    private <T> AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder<T> newAdminCaller()
  • @@ -1339,7 +1339,7 @@ implements
  • call

    -
    private <PREQ,PRESP,RESP> CompletableFuture<RESP> call(HBaseRpcController controller,
    +
    private <PREQ,PRESP,RESP> CompletableFuture<RESP> call(HBaseRpcController controller,
                                                            org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.Interface stub,
                                                            PREQ preq,
                                                            RawAsyncHBaseAdmin.MasterRpcCall<PRESP,PREQ> rpcCall,
    @@ -1354,7 +1354,7 @@ implements 
     
  • adminCall

    -
    private <PREQ,PRESP,RESP> CompletableFuture<RESP> adminCall(HBaseRpcController controller,
    +
    private <PREQ,PRESP,RESP> CompletableFuture<RESP> adminCall(HBaseRpcController controller,
                                                                 org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.Interface stub,
                                                                 PREQ preq,
                                                                 RawAsyncHBaseAdmin.AdminRpcCall<PRESP,PREQ> rpcCall,
    @@ -1369,7 +1369,7 @@ implements 
     
  • procedureCall

    -
    private <PREQ,PRESP> CompletableFuture<VoidprocedureCall(PREQ preq,
    +
    private <PREQ,PRESP> CompletableFuture<VoidprocedureCall(PREQ preq,
                                                                RawAsyncHBaseAdmin.MasterRpcCall<PRESP,PREQ> rpcCall,
                                                                RawAsyncHBaseAdmin.Converter<Long,PRESP> respConverter,
                                                                RawAsyncHBaseAdmin.ProcedureBiConsumer consumer)
    @@ -1381,7 +1381,7 @@ implements
  • batchTableOperations

    -
    private CompletableFuture<List<TableDescriptor>> batchTableOperations(Pattern pattern,
    +
    private CompletableFuture<List<TableDescriptor>> batchTableOperations(Pattern pattern,
                                                                           RawAsyncHBaseAdmin.TableOperator operator,
                                                                           String operationType)
  • @@ -1392,7 +1392,7 @@ implements
  • tableExists

    -
    public CompletableFuture<BooleantableExists(TableName tableName)
    +
    public CompletableFuture<BooleantableExists(TableName tableName)
    Specified by:
    tableExists in interface AsyncAdmin
    @@ -1410,7 +1410,7 @@ implements
  • listTables

    -
    public CompletableFuture<List<TableDescriptor>> listTables(Optional<Pattern> pattern,
    +
    public CompletableFuture<List<TableDescriptor>> listTables(Optional<Pattern> pattern,
                                                                boolean includeSysTables)
    Description copied from interface: AsyncAdmin
    List all the tables matching the given pattern.
    @@ -1431,7 +1431,7 @@ implements
  • listTableNames

    -
    public CompletableFuture<List<TableName>> listTableNames(Optional<Pattern> pattern,
    +
    public CompletableFuture<List<TableName>> listTableNames(Optional<Pattern> pattern,
                                                              boolean includeSysTables)
    Description copied from interface: AsyncAdmin
    List all of the names of userspace tables.
    @@ -1452,7 +1452,7 @@ implements
  • getTableDescriptor

    -
    public CompletableFuture<TableDescriptorgetTableDescriptor(TableName tableName)
    +
    public CompletableFuture<TableDescriptorgetTableDescriptor(TableName tableName)
    Description copied from interface: AsyncAdmin
    Method for getting the tableDescriptor
    @@ -1471,7 +1471,7 @@ implements
  • createTable

    -
    public CompletableFuture<VoidcreateTable(TableDescriptor desc,
    +
    public CompletableFuture<VoidcreateTable(TableDescriptor desc,
                                                byte[] startKey,
                                                byte[] endKey,
                                                int numRegions)
    @@ -1498,7 +1498,7 @@ implements
  • createTable

    -
    public CompletableFuture<VoidcreateTable(TableDescriptor desc,
    +
    public CompletableFuture<VoidcreateTable(TableDescriptor desc,
                                                Optional<byte[][]> splitKeys)
    Description copied from interface: AsyncAdmin
    Creates a new table with an initial set of empty regions defined by the specified split keys. @@ -1519,7 +1519,7 @@ implements
  • deleteTable

    -
    public CompletableFuture<VoiddeleteTable(TableName tableName)
    +
    public CompletableFuture<VoiddeleteTable(TableName tableName)
    Description copied from interface: AsyncAdmin
    Deletes a table.
    @@ -1536,7 +1536,7 @@ implements
  • deleteTables

    -
    public CompletableFuture<List<TableDescriptor>> deleteTables(Pattern pattern)
    +
    public CompletableFuture<List<TableDescriptor>> deleteTables(Pattern pattern)
    Description copied from interface: AsyncAdmin
    Delete tables matching the passed in pattern and wait on completion. Warning: Use this method carefully, there is no prompting and the effect is immediate. Consider using @@ -1559,7 +1559,7 @@ implements
  • truncateTable

    -
    public CompletableFuture<VoidtruncateTable(TableName tableName,
    +
    public CompletableFuture<VoidtruncateTable(TableName tableName,
                                                  boolean preserveSplits)
    Description copied from interface: AsyncAdmin
    Truncate a table.
    @@ -1578,7 +1578,7 @@ implements
  • enableTable

    -
    public CompletableFuture<VoidenableTable(TableName tableName)
    +
    public CompletableFuture<VoidenableTable(TableName tableName)
    Description copied from interface: AsyncAdmin
    Enable a table. The table has to be in disabled state for it to be enabled.
    @@ -1595,7 +1595,7 @@ implements
  • enableTables

    -
    public CompletableFuture<List<TableDescriptor>> enableTables(Pattern pattern)
    +
    public CompletableFuture<List<TableDescriptor>> enableTables(Pattern pattern)
    Description copied from interface: AsyncAdmin
    Enable tables matching the passed in pattern. Warning: Use this method carefully, there is no prompting and the effect is immediate. Consider using AsyncAdmin.listTables(Optional, boolean) and @@ -1617,7 +1617,7 @@ implements
  • disableTable

    -
    public CompletableFuture<VoiddisableTable(TableName tableName)
    +
    public CompletableFuture<VoiddisableTable(TableName tableName)
    Description copied from interface: AsyncAdmin
    Disable a table. The table has to be in enabled state for it to be disabled.
    @@ -1632,7 +1632,7 @@ implements
  • disableTables

    -
    public CompletableFuture<List<TableDescriptor>> disableTables(Pattern pattern)
    +
    public CompletableFuture<List<TableDescriptor>> disableTables(Pattern pattern)
    Description copied from interface: AsyncAdmin
    Disable tables matching the passed in pattern. Warning: Use this method carefully, there is no prompting and the effect is immediate. Consider using AsyncAdmin.listTables(Optional, boolean) and @@ -1654,7 +1654,7 @@ implements
  • isTableEnabled

    -
    public CompletableFuture<BooleanisTableEnabled(TableName tableName)
    +
    public CompletableFuture<BooleanisTableEnabled(TableName tableName)
    Specified by:
    isTableEnabled in interface AsyncAdmin
    @@ -1672,7 +1672,7 @@ implements
  • isTableDisabled

    -
    public CompletableFuture<BooleanisTableDisabled(TableName tableName)
    +
    public CompletableFuture<BooleanisTableDisabled(TableName tableName)
    Specified by:
    isTableDisabled in interface AsyncAdmin
    @@ -1690,7 +1690,7 @@ implements
  • isTableAvailable

    -
    public CompletableFuture<BooleanisTableAvailable(TableName tableName)
    +
    public CompletableFuture<BooleanisTableAvailable(TableName tableName)
    Specified by:
    isTableAvailable in interface AsyncAdmin
    @@ -1708,7 +1708,7 @@ implements
  • isTableAvailable

    -
    public CompletableFuture<BooleanisTableAvailable(TableName tableName,
    +
    public CompletableFuture<BooleanisTableAvailable(TableName tableName,
                                                        byte[][] splitKeys)
    Description copied from interface: AsyncAdmin
    Use this api to check if the table has been created with the specified number of splitkeys @@ -1730,7 +1730,7 @@ implements
  • getAlterStatus

    -
    public CompletableFuture<Pair<Integer,Integer>> getAlterStatus(TableName tableName)
    +
    public CompletableFuture<Pair<Integer,Integer>> getAlterStatus(TableName tableName)
    Description copied from interface: AsyncAdmin
    Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
    @@ -1752,7 +1752,7 @@ implements
  • addColumnFamily

    -
    public CompletableFuture<VoidaddColumnFamily(TableName tableName,
    +
    public CompletableFuture<VoidaddColumnFamily(TableName tableName,
                                                    ColumnFamilyDescriptor columnFamily)
    Description copied from interface: AsyncAdmin
    Add a column family to an existing table.
    @@ -1771,7 +1771,7 @@ implements
  • deleteColumnFamily

    -
    public