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 0B07C200CC5 for ; Mon, 26 Jun 2017 17:01:29 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id 09C30160BD9; Mon, 26 Jun 2017 15:01:29 +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 9219A160BF5 for ; Mon, 26 Jun 2017 17:01:26 +0200 (CEST) Received: (qmail 80425 invoked by uid 500); 26 Jun 2017 15:01:21 -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 78232 invoked by uid 99); 26 Jun 2017 15:01:19 -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; Mon, 26 Jun 2017 15:01:19 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 6E01BE96E3; Mon, 26 Jun 2017 15:01: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: Mon, 26 Jun 2017 15:01:53 -0000 Message-Id: <0a302b6aceff44d0b02578b9c43c0544@git.apache.org> In-Reply-To: <7f7d7944d7124677bf1e8939f6b5d72a@git.apache.org> References: <7f7d7944d7124677bf1e8939f6b5d72a@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [37/51] [partial] hbase-site git commit: Published site at 82d554e3783372cc6b05489452c815b57c06f6cd. archived-at: Mon, 26 Jun 2017 15:01:29 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/aecb1286/devapidocs/org/apache/hadoop/hbase/class-use/TableName.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/class-use/TableName.html b/devapidocs/org/apache/hadoop/hbase/class-use/TableName.html index b60c322..f422fb0 100644 --- a/devapidocs/org/apache/hadoop/hbase/class-use/TableName.html +++ b/devapidocs/org/apache/hadoop/hbase/class-use/TableName.html @@ -701,14 +701,14 @@ service. -static CompletableFuture<List<Pair<HRegionInfo,ServerName>>> -AsyncMetaTableAccessor.getTableRegionsAndLocations(RawAsyncTable metaTable, - Optional<TableName> tableName) -
Used to get table regions' info and server.
+static CompletableFuture<List<HRegionLocation>> +AsyncMetaTableAccessor.getTableHRegionLocations(RawAsyncTable metaTable, + Optional<TableName> tableName) +
Used to get all region locations for the specific table.
-static CompletableFuture<List<Pair<HRegionInfo,ServerName>>> +private static CompletableFuture<List<Pair<HRegionInfo,ServerName>>> AsyncMetaTableAccessor.getTableRegionsAndLocations(RawAsyncTable metaTable, Optional<TableName> tableName, boolean excludeOfflinedSplitParents) @@ -2282,6 +2282,24 @@ service. AsyncHBaseAdmin.checkRegionsAndGetTableName(byte[] encodeRegionNameA, byte[] encodeRegionNameB)  + +default CompletableFuture<List<TableName>> +AsyncAdmin.listTableNames() +
List all of the names of userspace tables.
+ + + +CompletableFuture<List<TableName>> +AsyncHBaseAdmin.listTableNames(Optional<Pattern> pattern, + boolean includeSysTables)  + + +CompletableFuture<List<TableName>> +AsyncAdmin.listTableNames(Optional<Pattern> pattern, + boolean includeSysTables) +
List all of the names of userspace tables.
+ + @@ -2520,32 +2538,23 @@ service.TableName tableName)  - - - - - + - - + + - - - - - - - - - - - - + + + + + + + + + + + + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - + - +
CompletableFuture<Void>AsyncHBaseAdmin.compact(TableName tableName) 
void Admin.compact(TableName tableName)
Compact a table.
void HBaseAdmin.compact(TableName tableName)
Compact a table.
CompletableFuture<Void>
default CompletableFuture<Void> AsyncAdmin.compact(TableName tableName)
Compact a table.
CompletableFuture<Void>AsyncHBaseAdmin.compact(TableName tableName, - byte[] columnFamily) 
void Admin.compact(TableName tableName, @@ -2561,22 +2570,6 @@ service.
CompletableFuture<Void>AsyncAdmin.compact(TableName tableName, - byte[] columnFamily) -
Compact a column family within a table.
-
private CompletableFuture<Void>AsyncHBaseAdmin.compact(TableName tableName, - byte[] columnFamily, - boolean major, - CompactType compactType) -
Compact column family of a table, Asynchronous operation even if CompletableFuture.get()
-
private void HBaseAdmin.compact(TableName tableName, byte[] columnFamily, @@ -2616,20 +2609,41 @@ service.
CompletableFuture<Void>AsyncHBaseAdmin.compact(TableName tableName, + Optional<byte[]> columnFamily) 
CompletableFuture<Void>AsyncAdmin.compact(TableName tableName, + Optional<byte[]> columnFamily) +
Compact a column family within a table.
+
private CompletableFuture<Void>AsyncHBaseAdmin.compact(TableName tableName, + Optional<byte[]> columnFamily, + boolean major, + CompactType compactType) +
Compact column family of a table, Asynchronous operation even if CompletableFuture.get()
+
private void AsyncNonMetaRegionLocator.complete(TableName tableName, AsyncNonMetaRegionLocator.LocateRequest req, HRegionLocation loc, Throwable error) 
static TableState TableState.convert(TableName tableName, org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.TableState tableState)
Covert from PB version of TableState
private MultiServerCallable AsyncRequestFutureImpl.createCallable(ServerName server, TableName tableName, @@ -2637,14 +2651,14 @@ service.
Create a callable.
static Table HTableWrapper.createWrapper(List<Table> openTables, TableName tableName, CoprocessorHost.Environment env, ExecutorService pool) 
void Admin.deleteColumn(TableName tableName, byte[] columnFamily) @@ -2656,7 +2670,7 @@ service.
void HBaseAdmin.deleteColumn(TableName tableName, byte[] columnFamily) @@ -2666,113 +2680,113 @@ service.
CompletableFuture<Void> AsyncHBaseAdmin.deleteColumnFamily(TableName tableName, byte[] columnFamily) 
void Admin.deleteColumnFamily(TableName tableName, byte[] columnFamily)
Delete a column family from a table.
void HBaseAdmin.deleteColumnFamily(TableName tableName, byte[] columnFamily) 
CompletableFuture<Void> AsyncAdmin.deleteColumnFamily(TableName tableName, byte[] columnFamily)
Delete a column family from a table.
Future<Void> Admin.deleteColumnFamilyAsync(TableName tableName, byte[] columnFamily)
Delete a column family from a table.
Future<Void> HBaseAdmin.deleteColumnFamilyAsync(TableName tableName, byte[] columnFamily) 
CompletableFuture<Void> AsyncHBaseAdmin.deleteTable(TableName tableName) 
void Admin.deleteTable(TableName tableName)
Deletes a table.
void HBaseAdmin.deleteTable(TableName tableName) 
CompletableFuture<Void> AsyncAdmin.deleteTable(TableName tableName)
Deletes a table.
Future<Void> Admin.deleteTableAsync(TableName tableName)
Deletes the table but does not block and wait for it be completely removed.
Future<Void> HBaseAdmin.deleteTableAsync(TableName tableName) 
CompletableFuture<Void> AsyncHBaseAdmin.disableTable(TableName tableName) 
void Admin.disableTable(TableName tableName)
Disable table and wait on completion.
void HBaseAdmin.disableTable(TableName tableName) 
CompletableFuture<Void> AsyncAdmin.disableTable(TableName tableName)
Disable a table.
Future<Void> Admin.disableTableAsync(TableName tableName)
Disable the table but does not block and wait for it be completely disabled.
Future<Void> HBaseAdmin.disableTableAsync(TableName tableName) 
void Admin.disableTableReplication(TableName tableName)
Disable a table's replication switch.
void HBaseAdmin.disableTableReplication(TableName tableName) 
static <R> void HTable.doBatchWithCallback(List<? extends Row> actions, Object[] results, @@ -2781,138 +2795,138 @@ service. ExecutorService pool, TableName tableName) 
CompletableFuture<Void> AsyncHBaseAdmin.enableTable(TableName tableName) 
void Admin.enableTable(TableName tableName)
Enable a table.
void HBaseAdmin.enableTable(TableName tableName) 
CompletableFuture<Void> AsyncAdmin.enableTable(TableName tableName)
Enable a table.
Future<Void> Admin.enableTableAsync(TableName tableName)
Enable the table but does not block and wait for it be completely enabled.
Future<Void> HBaseAdmin.enableTableAsync(TableName tableName) 
void Admin.enableTableReplication(TableName tableName)
Enable a table's replication switch.
void HBaseAdmin.enableTableReplication(TableName tableName) 
CompletableFuture<Void> AsyncHBaseAdmin.flush(TableName tableName) 
void Admin.flush(TableName tableName)
Flush a table.
void HBaseAdmin.flush(TableName tableName) 
CompletableFuture<Void> AsyncAdmin.flush(TableName tableName)
Flush a table.
CompletableFuture<Pair<Integer,Integer>> AsyncHBaseAdmin.getAlterStatus(TableName tableName) 
Pair<Integer,Integer> Admin.getAlterStatus(TableName tableName)
Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
Pair<Integer,Integer> HBaseAdmin.getAlterStatus(TableName tableName) 
CompletableFuture<Pair<Integer,Integer>> AsyncAdmin.getAlterStatus(TableName tableName)
Get the status of alter command - indicates how many regions have received the updated schema Asynchronous operation.
BufferedMutator ConnectionImplementation.getBufferedMutator(TableName tableName) 
BufferedMutator Connection.getBufferedMutator(TableName tableName)
Retrieve a BufferedMutator for performing client-side buffering of writes.
RegionLocations MetaCache.getCachedLocation(TableName tableName, byte[] row)
Search the cache for a location that fits our table and row key.
(package private) RegionLocations ConnectionImplementation.getCachedLocation(TableName tableName, byte[] row)
Search the cache for a location that fits our table and row key.
CompactionState Admin.getCompactionState(TableName tableName)
Get the current compaction state of a table.
CompactionState HBaseAdmin.getCompactionState(TableName tableName) 
CompactionState Admin.getCompactionState(TableName tableName, CompactType compactType)
Get the current compaction state of a table.
CompactionState HBaseAdmin.getCompactionState(TableName tableName, CompactType compactType)
Get the current compaction state of a table.
long Admin.getLastMajorCompactionTimestamp(TableName tableName)
Get the timestamp of the last major compaction for the passed table @@ -2921,64 +2935,64 @@ service.
or 0 if no such HFile could be found.
long HBaseAdmin.getLastMajorCompactionTimestamp(TableName tableName) 
private Consumer<Long> AsyncProcess.getLogger(TableName tableName, long max) 
private HRegionInfo HBaseAdmin.getMobRegionInfo(TableName tableName) 
int MetaCache.getNumberOfCachedRegionLocations(TableName tableName)
Return the number of cached region for a table.
(package private) int ConnectionImplementation.getNumberOfCachedRegionLocations(TableName tableName) 
default RawAsyncTable AsyncConnection.getRawTable(TableName tableName)
Retrieve an RawAsyncTable implementation for accessing a table.
AsyncTableBuilder<RawAsyncTable> AsyncConnection.getRawTableBuilder(TableName tableName)
Returns an AsyncTableBuilder for creating RawAsyncTable.
AsyncTableBuilder<RawAsyncTable> AsyncConnectionImpl.getRawTableBuilder(TableName tableName) 
Map<byte[],RegionLoad> Admin.getRegionLoad(ServerName sn, TableName tableName)
Get RegionLoad of all regions hosted on a regionserver for a table.
Map<byte[],RegionLoad> HBaseAdmin.getRegionLoad(ServerName sn, TableName tableName) 
HRegionLocation ConnectionImplementation.getRegionLocation(TableName tableName, byte[] row, boolean reload) 
HRegionLocation ClusterConnection.getRegionLocation(TableName tableName, byte[] row, @@ -2986,26 +3000,26 @@ service.
Find region location hosting passed row
(package private) CompletableFuture<HRegionLocation> AsyncNonMetaRegionLocator.getRegionLocation(TableName tableName, byte[] row, RegionLocateType locateType) 
(package private) CompletableFuture<HRegionLocation> AsyncRegionLocator.getRegionLocation(TableName tableName, byte[] row, RegionLocateType type, long timeoutNs) 
private CompletableFuture<HRegionLocation> AsyncNonMetaRegionLocator.getRegionLocationInternal(TableName tableName, byte[] row, RegionLocateType locateType) 
(package private) static RegionLocations RpcRetryingCallerWithReadReplicas.getRegionLocations(boolean useCache, int replicaId, @@ -3013,7 +3027,7 @@ service. TableName tableName, byte[] row) 
static RegionLocations RegionAdminServiceCallable.getRegionLocations(ClusterConnection connection, TableName tableName, @@ -3021,99 +3035,99 @@ service. boolean useCache, int replicaId) 
RegionLocator ConnectionImplementation.getRegionLocator(TableName tableName) 
AsyncTableRegionLocator AsyncConnection.getRegionLocator(TableName tableName)
Retrieve a AsyncRegionLocator implementation to inspect region information on a table.
AsyncTableRegionLocator AsyncConnectionImpl.getRegionLocator(TableName tableName) 
RegionLocator Connection.getRegionLocator(TableName tableName)
Retrieve a RegionLocator implementation to inspect region information on a table.
Table ConnectionImplementation.getTable(TableName tableName) 
default Table Connection.getTable(TableName tableName)
Retrieve a Table implementation for accessing a table.
default AsyncTable AsyncConnection.getTable(TableName tableName, ExecutorService pool)
Retrieve an AsyncTable implementation for accessing a table.
default Table Connection.getTable(TableName tableName, ExecutorService pool)
Retrieve a Table implementation for accessing a table.
TableBuilder ConnectionImplementation.getTableBuilder(TableName tableName, ExecutorService pool) 
AsyncTableBuilder<AsyncTable> AsyncConnection.getTableBuilder(TableName tableName, ExecutorService pool)
Returns an AsyncTableBuilder for creating AsyncTable.
AsyncTableBuilder<AsyncTable> AsyncConnectionImpl.getTableBuilder(TableName tableName, ExecutorService pool) 
TableBuilder Connection.getTableBuilder(TableName tableName, ExecutorService pool)
Returns an TableBuilder for creating Table.
private AsyncNonMetaRegionLocator.TableCache AsyncNonMetaRegionLocator.getTableCache(TableName tableName) 
CompletableFuture<TableDescriptor> AsyncHBaseAdmin.getTableDescriptor(TableName tableName)