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 E5EB5200B61 for ; Mon, 25 Jul 2016 18:02:33 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id E49EF160A67; Mon, 25 Jul 2016 16:02:33 +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 2CC66160AA0 for ; Mon, 25 Jul 2016 18:02:31 +0200 (CEST) Received: (qmail 78543 invoked by uid 500); 25 Jul 2016 16:02:27 -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 77211 invoked by uid 99); 25 Jul 2016 16:02:26 -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, 25 Jul 2016 16:02:26 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 80871E95B4; Mon, 25 Jul 2016 16:02:26 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: busbey@apache.org To: commits@hbase.apache.org Date: Mon, 25 Jul 2016 16:02:45 -0000 Message-Id: In-Reply-To: <3242cbd452c7491bb09e946805ded54c@git.apache.org> References: <3242cbd452c7491bb09e946805ded54c@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [21/52] [partial] hbase-site git commit: Published site at bdd7782f054a4740bb63f4d9781ffe083d51e4bf. archived-at: Mon, 25 Jul 2016 16:02:34 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/5513910e/devapidocs/org/apache/hadoop/hbase/client/Admin.html ---------------------------------------------------------------------- diff --git a/devapidocs/org/apache/hadoop/hbase/client/Admin.html b/devapidocs/org/apache/hadoop/hbase/client/Admin.html index d8e999e..655154f 100644 --- a/devapidocs/org/apache/hadoop/hbase/client/Admin.html +++ b/devapidocs/org/apache/hadoop/hbase/client/Admin.html @@ -662,11 +662,17 @@ extends boolean +isMasterInMaintenanceMode() +
Check whether Master is in maintenance mode
+ + + +boolean isNormalizerEnabled()
Query the current state of the region normalizer
- + boolean isProcedureFinished(String signature, String instance, @@ -674,23 +680,23 @@ extends Check the current state of the specified procedure. - + boolean isSnapshotFinished(SnapshotDescription snapshot)
Check the current state of the passed snapshot.
- + boolean isSplitOrMergeEnabled(MasterSwitchType switchType)
Query the current state of the switch
- + boolean isTableAvailable(TableName tableName)  - + boolean isTableAvailable(TableName tableName, byte[][] splitKeys) @@ -698,121 +704,121 @@ extends + boolean isTableDisabled(TableName tableName)  - + boolean isTableEnabled(TableName tableName)  - + NamespaceDescriptor[] listNamespaceDescriptors()
List available namespace descriptors
- + ProcedureInfo[] listProcedures()
List procedures
- + List<SnapshotDescription> listSnapshots()
List completed snapshots.
- + List<SnapshotDescription> listSnapshots(Pattern pattern)
List all the completed snapshots matching the given pattern.
- + List<SnapshotDescription> listSnapshots(String regex)
List all the completed snapshots matching the given regular expression.
- + HTableDescriptor[] listTableDescriptorsByNamespace(String name)
Get list of table descriptors by namespace
- + TableName[] listTableNames()
List all of the names of userspace tables.
- + TableName[] listTableNames(Pattern pattern)
List all of the names of userspace tables.
- + TableName[] listTableNames(Pattern pattern, boolean includeSysTables)
List all of the names of userspace tables.
- + TableName[] listTableNames(String regex)
List all of the names of userspace tables.
- + TableName[] listTableNames(String regex, boolean includeSysTables)
List all of the names of userspace tables.
- + TableName[] listTableNamesByNamespace(String name)
Get list of table names by namespace
- + HTableDescriptor[] listTables()
List all the userspace tables.
- + HTableDescriptor[] listTables(Pattern pattern)
List all the userspace tables matching the given pattern.
- + HTableDescriptor[] listTables(Pattern pattern, boolean includeSysTables)
List all the tables matching the given pattern.
- + HTableDescriptor[] listTables(String regex)
List all the userspace tables matching the given regular expression.
- + HTableDescriptor[] listTables(String regex, boolean includeSysTables)
List all the tables matching the given pattern.
- + List<SnapshotDescription> listTableSnapshots(Pattern tableNamePattern, Pattern snapshotNamePattern) @@ -820,7 +826,7 @@ extends + List<SnapshotDescription> listTableSnapshots(String tableNameRegex, String snapshotNameRegex) @@ -828,20 +834,20 @@ extends + void majorCompact(TableName tableName)
Major compact a table.
- + void majorCompact(TableName tableName, byte[] columnFamily)
Major compact a column family within a table.
- + void majorCompact(TableName tableName, byte[] columnFamily, @@ -849,27 +855,27 @@ extends Major compact a column family within a table. - + void majorCompact(TableName tableName, CompactType compactType)
Major compact a table.
- + void majorCompactRegion(byte[] regionName)
Major compact a table or an individual region.
- + void majorCompactRegion(byte[] regionName, byte[] columnFamily)
Major compact a column family within region.
- + void mergeRegions(byte[] nameOfRegionA, byte[] nameOfRegionB, @@ -880,7 +886,7 @@ extends + Future<Void> mergeRegionsAsync(byte[] nameOfRegionA, byte[] nameOfRegionB, @@ -888,7 +894,7 @@ extends Merge two regions. - + void modifyColumn(TableName tableName, HColumnDescriptor columnFamily) @@ -900,60 +906,51 @@ extends + Future<Void> modifyColumnFamily(TableName tableName, HColumnDescriptor columnFamily)
Modify an existing column family on a table.
- + void modifyNamespace(NamespaceDescriptor descriptor)
Modify an existing namespace.
- + Future<Void> modifyNamespaceAsync(NamespaceDescriptor descriptor)
Modify an existing namespace
- + Future<Void> modifyTable(TableName tableName, HTableDescriptor htd)
Modify an existing table, more IRB friendly version.
- + void move(byte[] encodedRegionName, byte[] destServerName)
Move the region r to dest.
- + boolean normalize()
Invoke region normalizer.
- + void offline(byte[] regionName)
Offline specified region from master's in-memory state.
- -void -releaseSplitOrMergeLockAndRollback() -
You should call this method after you call - setSplitOrMergeEnabled(boolean, boolean, boolean, MasterSwitchType...) - with skipLock be false, this method will release the lock created by above method - and rollback the switch state to be original state before you change switch
- - void restoreSnapshot(byte[] snapshotName) @@ -1019,9 +1016,8 @@ extends boolean[] -setSplitOrMergeEnabled(boolean enabled, +setSplitOrMergeEnabled(boolean enabled, boolean synchronous, - boolean skipLock, MasterSwitchType... switchTypes)
Turn the Split or Merge switches on or off.
@@ -2554,13 +2550,26 @@ void IOException
- if a remote or network exception occurs
See Also:
shutdown()
+ + + + @@ -2598,7 +2607,7 @@ void 
  • createNamespace

    -
    void createNamespace(NamespaceDescriptor descriptor)
    +
    void createNamespace(NamespaceDescriptor descriptor)
                          throws IOException
    Create a new namespace. Blocks until namespace has been successfully created or an exception is thrown.
    @@ -2613,7 +2622,7 @@ void 
  • createNamespaceAsync

    -
    Future<VoidcreateNamespaceAsync(NamespaceDescriptor descriptor)
    +
    Future<VoidcreateNamespaceAsync(NamespaceDescriptor descriptor)
                                       throws IOException
    Create a new namespace
    Parameters:
    descriptor - descriptor which describes the new namespace
    @@ -2629,7 +2638,7 @@ void 
  • modifyNamespace

    -
    void modifyNamespace(NamespaceDescriptor descriptor)
    +
    void modifyNamespace(NamespaceDescriptor descriptor)
                          throws IOException
    Modify an existing namespace. Blocks until namespace has been successfully modified or an exception is thrown.
    @@ -2644,7 +2653,7 @@ void 
  • modifyNamespaceAsync

    -
    Future<VoidmodifyNamespaceAsync(NamespaceDescriptor descriptor)
    +
    Future<VoidmodifyNamespaceAsync(NamespaceDescriptor descriptor)
                                       throws IOException
    Modify an existing namespace
    Parameters:
    descriptor - descriptor which describes the new namespace
    @@ -2660,7 +2669,7 @@ void 
  • deleteNamespace

    -
    void deleteNamespace(String name)
    +
    void deleteNamespace(String name)
                          throws IOException
    Delete an existing namespace. Only empty namespaces (no tables) can be removed. Blocks until namespace has been successfully deleted or an @@ -2676,7 +2685,7 @@ void 
  • deleteNamespaceAsync

    -
    Future<VoiddeleteNamespaceAsync(String name)
    +
    Future<VoiddeleteNamespaceAsync(String name)
                                       throws IOException
    Delete an existing namespace. Only empty namespaces (no tables) can be removed.
    Parameters:
    name - namespace name
    @@ -2692,7 +2701,7 @@ void 
  • getNamespaceDescriptor

    -
    NamespaceDescriptor getNamespaceDescriptor(String name)
    +
    NamespaceDescriptor getNamespaceDescriptor(String name)
                                                throws IOException
    Get a namespace descriptor by name
    Parameters:
    name - name of namespace descriptor
    @@ -2707,7 +2716,7 @@ void 
  • listNamespaceDescriptors

    -
    NamespaceDescriptor[] listNamespaceDescriptors()
    +
    NamespaceDescriptor[] listNamespaceDescriptors()
                                                    throws IOException
    List available namespace descriptors
    Returns:
    List of descriptors
    @@ -2721,7 +2730,7 @@ void 
  • listTableDescriptorsByNamespace

    -
    HTableDescriptor[] listTableDescriptorsByNamespace(String name)
    +
    HTableDescriptor[] listTableDescriptorsByNamespace(String name)
                                                        throws IOException
    Get list of table descriptors by namespace
    Parameters:
    name - namespace name
    @@ -2736,7 +2745,7 @@ void 
  • listTableNamesByNamespace

    -
    TableName[] listTableNamesByNamespace(String name)
    +
    TableName[] listTableNamesByNamespace(String name)
                                           throws IOException
    Get list of table names by namespace
    Parameters:
    name - namespace name
    @@ -2751,7 +2760,7 @@ void 
  • getTableRegions

    -
    List<HRegionInfogetTableRegions(TableName tableName)
    +
    List<HRegionInfogetTableRegions(TableName tableName)
                                       throws IOException
    Get the regions of a given table.
    Parameters:
    tableName - the name of the table
    @@ -2766,7 +2775,7 @@ void 
  • close

    -
    void close()
    +
    void close()
                throws IOException
    Specified by:
    @@ -2783,7 +2792,7 @@ void 
  • getTableDescriptorsByTableName

    -
    HTableDescriptor[] getTableDescriptorsByTableName(List<TableName> tableNames)
    +
    HTableDescriptor[] getTableDescriptorsByTableName(List<TableName> tableNames)
                                                       throws IOException
    Get tableDescriptors
    Parameters:
    tableNames - List of table names
    @@ -2798,7 +2807,7 @@ void 
  • getTableDescriptors

    -
    HTableDescriptor[] getTableDescriptors(List<String> names)
    +
    HTableDescriptor[] getTableDescriptors(List<String> names)
                                            throws IOException
    Get tableDescriptors
    Parameters:
    names - List of table names
    @@ -2813,7 +2822,7 @@ void 
  • abortProcedure

    -
    boolean abortProcedure(long procId,
    +
    boolean abortProcedure(long procId,
                          boolean mayInterruptIfRunning)
                            throws IOException
    abort a procedure
    @@ -2829,7 +2838,7 @@ void 
  • abortProcedureAsync

    -
    Future<BooleanabortProcedureAsync(long procId,
    +
    Future<BooleanabortProcedureAsync(long procId,
                                       boolean mayInterruptIfRunning)
                                         throws IOException
    Abort a procedure but does not block and wait for it be completely removed. @@ -2849,7 +2858,7 @@ void 
  • listProcedures

    -
    ProcedureInfo[] listProcedures()
    +
    ProcedureInfo[] listProcedures()
                                    throws IOException
    List procedures
    Returns:
    procedure list
    @@ -2863,7 +2872,7 @@ void 
  • rollWALWriter

    -
    void rollWALWriter(ServerName serverName)
    +
    void rollWALWriter(ServerName serverName)
                        throws IOException,
                               FailedLogCloseException
    Roll the log writer. I.e. for filesystem based write ahead logs, start writing to a new file. @@ -2883,7 +2892,7 @@ void 
  • getMasterCoprocessors

    -
    String[] getMasterCoprocessors()
    +
    String[] getMasterCoprocessors()
                                    throws IOException
    Helper delegage to getClusterStatus().getMasterCoprocessors().
    Returns:
    an array of master coprocessors
    @@ -2897,7 +2906,7 @@ void 
  • getCompactionState

    -
    CompactionState getCompactionState(TableName tableName)
    +
    CompactionState getCompactionState(TableName tableName)
                                        throws IOException
    Get the current compaction state of a table. It could be in a major compaction, a minor compaction, both, or none.
    @@ -2913,7 +2922,7 @@ void 
  • getCompactionStateForRegion

    -
    CompactionState getCompactionStateForRegion(byte[] regionName)
    +
    CompactionState getCompactionStateForRegion(byte[] regionName)
                                                 throws IOException
    Get the current compaction state of region. It could be in a major compaction, a minor compaction, both, or none.
    @@ -2929,7 +2938,7 @@ void 
  • getLastMajorCompactionTimestamp

    -
    long getLastMajorCompactionTimestamp(TableName tableName)
    +
    long getLastMajorCompactionTimestamp(TableName tableName)
                                          throws IOException
    Get the timestamp of the last major compaction for the passed table @@ -2947,7 +2956,7 @@ void 
  • getLastMajorCompactionTimestampForRegion

    -
    long getLastMajorCompactionTimestampForRegion(byte[] regionName)
    +
    long getLastMajorCompactionTimestampForRegion(byte[] regionName)
                                                   throws IOException
    Get the timestamp of the last major compaction for the passed region. @@ -2965,7 +2974,7 @@ void 
  • snapshot

    -
    void snapshot(String snapshotName,
    +
    void snapshot(String snapshotName,
                 TableName tableName)
                   throws IOException,
                          SnapshotCreationException,
    @@ -2988,7 +2997,7 @@ void 
     
  • snapshot

    -
    void snapshot(byte[] snapshotName,
    +
    void snapshot(byte[] snapshotName,
                 TableName tableName)
                   throws IOException,
                          SnapshotCreationException,
    @@ -3011,7 +3020,7 @@ void 
     
  • snapshot

    -
    void snapshot(String snapshotName,
    +
    void snapshot(String snapshotName,
                 TableName tableName,
                 SnapshotType type)
                   throws IOException,
    @@ -3036,7 +3045,7 @@ void 
     
  • snapshot

    -
    void snapshot(SnapshotDescription snapshot)
    +
    void snapshot(SnapshotDescription snapshot)
                   throws IOException,
                          SnapshotCreationException,
                          IllegalArgumentException
    @@ -3063,7 +3072,7 @@ void 
  • takeSnapshotAsync

    -
    void takeSnapshotAsync(SnapshotDescription snapshot)
    +
    void takeSnapshotAsync(SnapshotDescription snapshot)
                            throws IOException,
                                   SnapshotCreationException
    Take a snapshot without waiting for the server to complete that snapshot (asynchronous) Only a @@ -3081,7 +3090,7 @@ void 
  • isSnapshotFinished

    -
    boolean isSnapshotFinished(SnapshotDescription snapshot)
    +
    boolean isSnapshotFinished(SnapshotDescription snapshot)
                                throws IOException,
                                       HBaseSnapshotException,
                                       UnknownSnapshotException
    @@ -3106,7 +3115,7 @@ void 
  • restoreSnapshot

    -
    void restoreSnapshot(byte[] snapshotName)
    +
    void restoreSnapshot(byte[] snapshotName)
                          throws IOException,
                                 RestoreSnapshotException
    Restore the specified snapshot on the original table. (The table must be disabled) If the @@ -3128,7 +3137,7 @@ void 
  • restoreSnapshot

    -
    void restoreSnapshot(String snapshotName)
    +
    void restoreSnapshot(String snapshotName)
                          throws IOException,
                                 RestoreSnapshotException
    Restore the specified snapshot on the original table. (The table must be disabled) If the @@ -3149,7 +3158,7 @@ void 
  • restoreSnapshotAsync

    -
    Future<VoidrestoreSnapshotAsync(String snapshotName)
    +
    Future<VoidrestoreSnapshotAsync(String snapshotName)
                                       throws IOException,
                                              RestoreSnapshotException
    Restore the specified snapshot on the original table. (The table must be disabled) If the @@ -3171,7 +3180,7 @@ void 
  • restoreSnapshot

    -
    void restoreSnapshot(byte[] snapshotName,
    +
    void restoreSnapshot(byte[] snapshotName,
                        boolean takeFailSafeSnapshot)
                          throws IOException,
                                 RestoreSnapshotException
    @@ -3194,7 +3203,7 @@ void 
  • restoreSnapshot

    -
    void restoreSnapshot(String snapshotName,
    +
    void restoreSnapshot(String snapshotName,
                        boolean takeFailSafeSnapshot)
                          throws IOException,
                                 RestoreSnapshotException
    @@ -3217,7 +3226,7 @@ void 
  • cloneSnapshot

    -
    void cloneSnapshot(byte[] snapshotName,
    +
    void cloneSnapshot(byte[] snapshotName,
                      TableName tableName)
                        throws IOException,
                               TableExistsException,
    @@ -3237,7 +3246,7 @@ void 
     
  • cloneSnapshot

    -
    void cloneSnapshot(String snapshotName,
    +
    void cloneSnapshot(String snapshotName,
                      TableName tableName)
                        throws IOException,
                               TableExistsException,
    @@ -3257,7 +3266,7 @@ void 
     
  • cloneSnapshotAsync

    -
    Future<VoidcloneSnapshotAsync(String snapshotName,
    +
    Future<VoidcloneSnapshotAsync(String snapshotName,
                                   TableName tableName)
                                     throws IOException,
                                            TableExistsException
    @@ -3281,7 +3290,7 @@ void 
  • execProcedure

    -
    void execProcedure(String signature,
    +
    void execProcedure(String signature,
                      String instance,
                      Map<String,String> props)
                        throws IOException
    @@ -3299,7 +3308,7 @@ void 
  • execProcedureWithRet

    -
    byte[] execProcedureWithRet(String signature,
    +
    byte[] execProcedureWithRet(String signature,
                               String instance,
                               Map<String,String> props)
                                 throws IOException
    @@ -3318,7 +3327,7 @@ void 
  • isProcedureFinished

    -
    boolean isProcedureFinished(String signature,
    +
    boolean isProcedureFinished(String signature,
                               String instance,
                               Map<String,String> props)
                                 throws IOException
    @@ -3337,7 +3346,7 @@ void 
  • listSnapshots

    -
    List<SnapshotDescriptionlistSnapshots()
    +
    List<SnapshotDescriptionlistSnapshots()
                                             throws IOException
    List completed snapshots.
    Returns:
    a list of snapshot descriptors for completed snapshots
    @@ -3351,7 +3360,7 @@ void 
  • listSnapshots

    -
    List<SnapshotDescriptionlistSnapshots(String regex)
    +
    List<SnapshotDescriptionlistSnapshots(String regex)
                                             throws IOException
    List all the completed snapshots matching the given regular expression.
    Parameters:
    regex - The regular expression to match against
    @@ -3366,7 +3375,7 @@ void 
  • listSnapshots

    -
    List<SnapshotDescriptionlistSnapshots(Pattern pattern)
    +
    List<SnapshotDescriptionlistSnapshots(