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 B2102200D25 for ; Sun, 22 Oct 2017 17:15:54 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id B0840160BF1; Sun, 22 Oct 2017 15:15:54 +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 AD54F160BF8 for ; Sun, 22 Oct 2017 17:15:52 +0200 (CEST) Received: (qmail 79215 invoked by uid 500); 22 Oct 2017 15:15:49 -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 78344 invoked by uid 99); 22 Oct 2017 15:15:48 -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; Sun, 22 Oct 2017 15:15:48 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 383FCE0287; Sun, 22 Oct 2017 15:15:44 +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: Sun, 22 Oct 2017 15:15:48 -0000 Message-Id: In-Reply-To: References: X-Mailer: ASF-Git Admin Mailer Subject: [05/51] [partial] hbase-site git commit: Published site at . archived-at: Sun, 22 Oct 2017 15:15:54 -0000 http://git-wip-us.apache.org/repos/asf/hbase-site/blob/4f94a4c5/devapidocs/src-html/org/apache/hadoop/hbase/master/MasterServices.html ---------------------------------------------------------------------- diff --git a/devapidocs/src-html/org/apache/hadoop/hbase/master/MasterServices.html b/devapidocs/src-html/org/apache/hadoop/hbase/master/MasterServices.html index def1ce9..26ac140 100644 --- a/devapidocs/src-html/org/apache/hadoop/hbase/master/MasterServices.html +++ b/devapidocs/src-html/org/apache/hadoop/hbase/master/MasterServices.html @@ -6,7 +6,7 @@
-
001/**
+
001/*
 002 *
 003 * Licensed to the Apache Software Foundation (ASF) under one
 004 * or more contributor license agreements.  See the NOTICE file
@@ -63,445 +63,443 @@
 055import com.google.protobuf.Service;
 056
 057/**
-058 * Services Master supplies
-059 */
-060@InterfaceAudience.Private
-061public interface MasterServices extends Server {
-062  /**
-063   * @return the underlying snapshot manager
-064   */
-065  SnapshotManager getSnapshotManager();
-066
-067  /**
-068   * @return the underlying MasterProcedureManagerHost
-069   */
-070  MasterProcedureManagerHost getMasterProcedureManagerHost();
-071
-072  /**
-073   * @return Master's instance of {@link ClusterSchema}
-074   */
-075  ClusterSchema getClusterSchema();
-076
-077  /**
-078   * @return Master's instance of the {@link AssignmentManager}
-079   */
-080  AssignmentManager getAssignmentManager();
-081
-082  /**
-083   * @return Master's filesystem {@link MasterFileSystem} utility class.
-084   */
-085  MasterFileSystem getMasterFileSystem();
-086
-087  /**
-088   * @return Master's WALs {@link MasterWalManager} utility class.
-089   */
-090  MasterWalManager getMasterWalManager();
-091
-092  /**
-093   * @return Master's {@link ServerManager} instance.
-094   */
-095  ServerManager getServerManager();
-096
-097  /**
-098   * @return Master's instance of {@link ExecutorService}
-099   */
-100  ExecutorService getExecutorService();
-101
-102  /**
-103   * @return Master's instance of {@link TableStateManager}
-104   */
-105  TableStateManager getTableStateManager();
-106
-107  /**
-108   * @return Master's instance of {@link MasterCoprocessorHost}
-109   */
-110  MasterCoprocessorHost getMasterCoprocessorHost();
-111
-112  /**
-113   * @return Master's instance of {@link MasterQuotaManager}
-114   */
-115  MasterQuotaManager getMasterQuotaManager();
-116
-117  /**
-118   * @return Master's instance of {@link RegionNormalizer}
-119   */
-120  RegionNormalizer getRegionNormalizer();
-121
-122  /**
-123   * @return Master's instance of {@link CatalogJanitor}
-124   */
-125  CatalogJanitor getCatalogJanitor();
-126
-127  /**
-128   * @return Master's instance of {@link ProcedureExecutor}
-129   */
-130  ProcedureExecutor<MasterProcedureEnv> getMasterProcedureExecutor();
-131
-132  /**
-133   * @return Tripped when Master has finished initialization.
-134   */
-135  @VisibleForTesting
-136  public ProcedureEvent getInitializedEvent();
-137
-138  /**
-139   * @return Master's instance of {@link MetricsMaster}
-140   */
-141  MetricsMaster getMasterMetrics();
-142
-143  /**
-144   * Check table is modifiable; i.e. exists and is offline.
-145   * @param tableName Name of table to check.
-146   * @throws TableNotDisabledException
-147   * @throws TableNotFoundException
-148   * @throws IOException
-149   */
-150  // We actually throw the exceptions mentioned in the
-151  void checkTableModifiable(final TableName tableName)
-152      throws IOException, TableNotFoundException, TableNotDisabledException;
-153
-154  /**
-155   * Create a table using the given table definition.
-156   * @param desc The table definition
-157   * @param splitKeys Starting row keys for the initial table regions.  If null
-158   * @param nonceGroup
-159   * @param nonce
-160   *     a single region is created.
-161   */
-162  long createTable(
-163      final TableDescriptor desc,
-164      final byte[][] splitKeys,
-165      final long nonceGroup,
-166      final long nonce) throws IOException;
-167
-168  /**
-169   * Create a system table using the given table definition.
-170   * @param tableDescriptor The system table definition
-171   *     a single region is created.
-172   */
-173  long createSystemTable(final TableDescriptor tableDescriptor) throws IOException;
-174
-175  /**
-176   * Delete a table
-177   * @param tableName The table name
-178   * @param nonceGroup
-179   * @param nonce
-180   * @throws IOException
-181   */
-182  long deleteTable(
-183      final TableName tableName,
-184      final long nonceGroup,
-185      final long nonce) throws IOException;
-186
-187  /**
-188   * Truncate a table
-189   * @param tableName The table name
-190   * @param preserveSplits True if the splits should be preserved
-191   * @param nonceGroup
-192   * @param nonce
-193   * @throws IOException
-194   */
-195  public long truncateTable(
-196      final TableName tableName,
-197      final boolean preserveSplits,
-198      final long nonceGroup,
-199      final long nonce) throws IOException;
-200
-201  /**
-202   * Modify the descriptor of an existing table
-203   * @param tableName The table name
-204   * @param descriptor The updated table descriptor
-205   * @param nonceGroup
-206   * @param nonce
-207   * @throws IOException
-208   */
-209  long modifyTable(
-210      final TableName tableName,
-211      final TableDescriptor descriptor,
-212      final long nonceGroup,
-213      final long nonce)
-214      throws IOException;
-215
-216  /**
-217   * Enable an existing table
-218   * @param tableName The table name
-219   * @param nonceGroup
-220   * @param nonce
-221   * @throws IOException
-222   */
-223  long enableTable(
-224      final TableName tableName,
-225      final long nonceGroup,
-226      final long nonce) throws IOException;
-227
-228  /**
-229   * Disable an existing table
-230   * @param tableName The table name
-231   * @param nonceGroup
-232   * @param nonce
-233   * @throws IOException
-234   */
-235  long disableTable(
-236      final TableName tableName,
-237      final long nonceGroup,
-238      final long nonce) throws IOException;
-239
-240
-241  /**
-242   * Add a new column to an existing table
-243   * @param tableName The table name
-244   * @param column The column definition
-245   * @param nonceGroup
-246   * @param nonce
-247   * @throws IOException
-248   */
-249  long addColumn(
-250      final TableName tableName,
-251      final ColumnFamilyDescriptor column,
-252      final long nonceGroup,
-253      final long nonce)
-254      throws IOException;
-255
-256  /**
-257   * Modify the column descriptor of an existing column in an existing table
-258   * @param tableName The table name
-259   * @param descriptor The updated column definition
-260   * @param nonceGroup
-261   * @param nonce
-262   * @throws IOException
-263   */
-264  long modifyColumn(
-265      final TableName tableName,
-266      final ColumnFamilyDescriptor descriptor,
-267      final long nonceGroup,
-268      final long nonce)
-269      throws IOException;
-270
-271  /**
-272   * Delete a column from an existing table
-273   * @param tableName The table name
-274   * @param columnName The column name
-275   * @param nonceGroup
-276   * @param nonce
-277   * @throws IOException
-278   */
-279  long deleteColumn(
-280      final TableName tableName,
-281      final byte[] columnName,
-282      final long nonceGroup,
-283      final long nonce)
-284      throws IOException;
-285
-286  /**
-287   * Merge regions in a table.
-288   * @param regionsToMerge daughter regions to merge
-289   * @param forcible whether to force to merge even two regions are not adjacent
-290   * @param nonceGroup used to detect duplicate
-291   * @param nonce used to detect duplicate
-292   * @return  procedure Id
-293   * @throws IOException
-294   */
-295  long mergeRegions(
-296      final RegionInfo[] regionsToMerge,
-297      final boolean forcible,
-298      final long nonceGroup,
-299      final long nonce) throws IOException;
-300
-301  /**
-302   * Split a region.
-303   * @param regionInfo region to split
-304   * @param splitRow split point
-305   * @param nonceGroup used to detect duplicate
-306   * @param nonce used to detect duplicate
-307   * @return  procedure Id
-308   * @throws IOException
-309   */
-310  long splitRegion(
-311      final RegionInfo regionInfo,
-312      final byte [] splitRow,
-313      final long nonceGroup,
-314      final long nonce) throws IOException;
-315
-316  /**
-317   * @return Return table descriptors implementation.
-318   */
-319  TableDescriptors getTableDescriptors();
-320
-321  /**
-322   * @return true if master enables ServerShutdownHandler;
-323   */
-324  boolean isServerCrashProcessingEnabled();
-325
-326  /**
-327   * Registers a new protocol buffer {@link Service} subclass as a master coprocessor endpoint.
-328   *
-329   * <p>
-330   * Only a single instance may be registered for a given {@link Service} subclass (the
-331   * instances are keyed on {@link com.google.protobuf.Descriptors.ServiceDescriptor#getFullName()}.
-332   * After the first registration, subsequent calls with the same service name will fail with
-333   * a return value of {@code false}.
-334   * </p>
-335   * @param instance the {@code Service} subclass instance to expose as a coprocessor endpoint
-336   * @return {@code true} if the registration was successful, {@code false}
-337   * otherwise
-338   */
-339  boolean registerService(Service instance);
-340
-341  /**
-342   * @return true if master is the active one
-343   */
-344  boolean isActiveMaster();
-345
-346  /**
-347   * @return true if master is initialized
-348   */
-349  boolean isInitialized();
-350
-351  /**
-352   * @return true if master is in maintanceMode
-353   */
-354  boolean isInMaintenanceMode();
-355
-356  /**
-357   * Abort a procedure.
-358   * @param procId ID of the procedure
-359   * @param mayInterruptIfRunning if the proc completed at least one step, should it be aborted?
-360   * @return true if aborted, false if procedure already completed or does not exist
-361   * @throws IOException
-362   */
-363  public boolean abortProcedure(final long procId, final boolean mayInterruptIfRunning)
-364      throws IOException;
-365
-366  /**
-367   * Get procedures
-368   * @return procedure list
-369   * @throws IOException
-370   */
-371  public List<Procedure<?>> getProcedures() throws IOException;
-372
-373  /**
-374   * Get locks
-375   * @return lock list
-376   * @throws IOException
-377   */
-378  public List<LockedResource> getLocks() throws IOException;
-379
-380  /**
-381   * Get list of table descriptors by namespace
-382   * @param name namespace name
-383   * @return descriptors
-384   * @throws IOException
-385   */
-386  public List<TableDescriptor> listTableDescriptorsByNamespace(String name) throws IOException;
-387
-388  /**
-389   * Get list of table names by namespace
-390   * @param name namespace name
-391   * @return table names
-392   * @throws IOException
-393   */
-394  public List<TableName> listTableNamesByNamespace(String name) throws IOException;
-395
-396  /**
-397   * @param table the table for which last successful major compaction time is queried
-398   * @return the timestamp of the last successful major compaction for the passed table,
-399   * or 0 if no HFile resulting from a major compaction exists
-400   * @throws IOException
-401   */
-402  public long getLastMajorCompactionTimestamp(TableName table) throws IOException;
-403
-404  /**
-405   * @param regionName
-406   * @return the timestamp of the last successful major compaction for the passed region
-407   * or 0 if no HFile resulting from a major compaction exists
-408   * @throws IOException
-409   */
-410  public long getLastMajorCompactionTimestampForRegion(byte[] regionName) throws IOException;
-411
-412  /**
-413   * @return load balancer
-414   */
-415  public LoadBalancer getLoadBalancer();
-416
-417  /**
-418   * @return True if this master is stopping.
-419   */
-420  boolean isStopping();
+058 * A curated subset of services provided by {@link HMaster}.
+059 * For use internally only. Passed to Managers, Services and Chores so can pass less-than-a
+060 * full-on HMaster at test-time. Be judicious adding API. Changes cause ripples through
+061 * the code base.
+062 */
+063@InterfaceAudience.Private
+064public interface MasterServices extends Server {
+065  /**
+066   * @return the underlying snapshot manager
+067   */
+068  SnapshotManager getSnapshotManager();
+069
+070  /**
+071   * @return the underlying MasterProcedureManagerHost
+072   */
+073  MasterProcedureManagerHost getMasterProcedureManagerHost();
+074
+075  /**
+076   * @return Master's instance of {@link ClusterSchema}
+077   */
+078  ClusterSchema getClusterSchema();
+079
+080  /**
+081   * @return Master's instance of the {@link AssignmentManager}
+082   */
+083  AssignmentManager getAssignmentManager();
+084
+085  /**
+086   * @return Master's filesystem {@link MasterFileSystem} utility class.
+087   */
+088  MasterFileSystem getMasterFileSystem();
+089
+090  /**
+091   * @return Master's WALs {@link MasterWalManager} utility class.
+092   */
+093  MasterWalManager getMasterWalManager();
+094
+095  /**
+096   * @return Master's {@link ServerManager} instance.
+097   */
+098  ServerManager getServerManager();
+099
+100  /**
+101   * @return Master's instance of {@link ExecutorService}
+102   */
+103  ExecutorService getExecutorService();
+104
+105  /**
+106   * @return Master's instance of {@link TableStateManager}
+107   */
+108  TableStateManager getTableStateManager();
+109
+110  /**
+111   * @return Master's instance of {@link MasterCoprocessorHost}
+112   */
+113  MasterCoprocessorHost getMasterCoprocessorHost();
+114
+115  /**
+116   * @return Master's instance of {@link MasterQuotaManager}
+117   */
+118  MasterQuotaManager getMasterQuotaManager();
+119
+120  /**
+121   * @return Master's instance of {@link RegionNormalizer}
+122   */
+123  RegionNormalizer getRegionNormalizer();
+124
+125  /**
+126   * @return Master's instance of {@link CatalogJanitor}
+127   */
+128  CatalogJanitor getCatalogJanitor();
+129
+130  /**
+131   * @return Master's instance of {@link ProcedureExecutor}
+132   */
+133  ProcedureExecutor<MasterProcedureEnv> getMasterProcedureExecutor();
+134
+135  /**
+136   * @return Tripped when Master has finished initialization.
+137   */
+138  @VisibleForTesting
+139  public ProcedureEvent getInitializedEvent();
+140
+141  /**
+142   * @return Master's instance of {@link MetricsMaster}
+143   */
+144  MetricsMaster getMasterMetrics();
+145
+146  /**
+147   * Check table is modifiable; i.e. exists and is offline.
+148   * @param tableName Name of table to check.
+149   * @throws TableNotDisabledException
+150   * @throws TableNotFoundException
+151   * @throws IOException
+152   */
+153  // We actually throw the exceptions mentioned in the
+154  void checkTableModifiable(final TableName tableName)
+155      throws IOException, TableNotFoundException, TableNotDisabledException;
+156
+157  /**
+158   * Create a table using the given table definition.
+159   * @param desc The table definition
+160   * @param splitKeys Starting row keys for the initial table regions.  If null
+161   * @param nonceGroup
+162   * @param nonce
+163   *     a single region is created.
+164   */
+165  long createTable(
+166      final TableDescriptor desc,
+167      final byte[][] splitKeys,
+168      final long nonceGroup,
+169      final long nonce) throws IOException;
+170
+171  /**
+172   * Create a system table using the given table definition.
+173   * @param tableDescriptor The system table definition
+174   *     a single region is created.
+175   */
+176  long createSystemTable(final TableDescriptor tableDescriptor) throws IOException;
+177
+178  /**
+179   * Delete a table
+180   * @param tableName The table name
+181   * @param nonceGroup
+182   * @param nonce
+183   * @throws IOException
+184   */
+185  long deleteTable(
+186      final TableName tableName,
+187      final long nonceGroup,
+188      final long nonce) throws IOException;
+189
+190  /**
+191   * Truncate a table
+192   * @param tableName The table name
+193   * @param preserveSplits True if the splits should be preserved
+194   * @param nonceGroup
+195   * @param nonce
+196   * @throws IOException
+197   */
+198  public long truncateTable(
+199      final TableName tableName,
+200      final boolean preserveSplits,
+201      final long nonceGroup,
+202      final long nonce) throws IOException;
+203
+204  /**
+205   * Modify the descriptor of an existing table
+206   * @param tableName The table name
+207   * @param descriptor The updated table descriptor
+208   * @param nonceGroup
+209   * @param nonce
+210   * @throws IOException
+211   */
+212  long modifyTable(
+213      final TableName tableName,
+214      final TableDescriptor descriptor,
+215      final long nonceGroup,
+216      final long nonce)
+217      throws IOException;
+218
+219  /**
+220   * Enable an existing table
+221   * @param tableName The table name
+222   * @param nonceGroup
+223   * @param nonce
+224   * @throws IOException
+225   */
+226  long enableTable(
+227      final TableName tableName,
+228      final long nonceGroup,
+229      final long nonce) throws IOException;
+230
+231  /**
+232   * Disable an existing table
+233   * @param tableName The table name
+234   * @param nonceGroup
+235   * @param nonce
+236   * @throws IOException
+237   */
+238  long disableTable(
+239      final TableName tableName,
+240      final long nonceGroup,
+241      final long nonce) throws IOException;
+242
+243
+244  /**
+245   * Add a new column to an existing table
+246   * @param tableName The table name
+247   * @param column The column definition
+248   * @param nonceGroup
+249   * @param nonce
+250   * @throws IOException
+251   */
+252  long addColumn(
+253      final TableName tableName,
+254      final ColumnFamilyDescriptor column,
+255      final long nonceGroup,
+256      final long nonce)
+257      throws IOException;
+258
+259  /**
+260   * Modify the column descriptor of an existing column in an existing table
+261   * @param tableName The table name
+262   * @param descriptor The updated column definition
+263   * @param nonceGroup
+264   * @param nonce
+265   * @throws IOException
+266   */
+267  long modifyColumn(
+268      final TableName tableName,
+269      final ColumnFamilyDescriptor descriptor,
+270      final long nonceGroup,
+271      final long nonce)
+272      throws IOException;
+273
+274  /**
+275   * Delete a column from an existing table
+276   * @param tableName The table name
+277   * @param columnName The column name
+278   * @param nonceGroup
+279   * @param nonce
+280   * @throws IOException
+281   */
+282  long deleteColumn(
+283      final TableName tableName,
+284      final byte[] columnName,
+285      final long nonceGroup,
+286      final long nonce)
+287      throws IOException;
+288
+289  /**
+290   * Merge regions in a table.
+291   * @param regionsToMerge daughter regions to merge
+292   * @param forcible whether to force to merge even two regions are not adjacent
+293   * @param nonceGroup used to detect duplicate
+294   * @param nonce used to detect duplicate
+295   * @return  procedure Id
+296   * @throws IOException
+297   */
+298  long mergeRegions(
+299      final RegionInfo[] regionsToMerge,
+300      final boolean forcible,
+301      final long nonceGroup,
+302      final long nonce) throws IOException;
+303
+304  /**
+305   * Split a region.
+306   * @param regionInfo region to split
+307   * @param splitRow split point
+308   * @param nonceGroup used to detect duplicate
+309   * @param nonce used to detect duplicate
+310   * @return  procedure Id
+311   * @throws IOException
+312   */
+313  long splitRegion(
+314      final RegionInfo regionInfo,
+315      final byte [] splitRow,
+316      final long nonceGroup,
+317      final long nonce) throws IOException;
+318
+319  /**
+320   * @return Return table descriptors implementation.
+321   */
+322  TableDescriptors getTableDescriptors();
+323
+324  /**
+325   * @return true if master enables ServerShutdownHandler;
+326   */
+327  boolean isServerCrashProcessingEnabled();
+328
+329  /**
+330   * Registers a new protocol buffer {@link Service} subclass as a master coprocessor endpoint.
+331   *
+332   * <p>
+333   * Only a single instance may be registered for a given {@link Service} subclass (the
+334   * instances are keyed on {@link com.google.protobuf.Descriptors.ServiceDescriptor#getFullName()}.
+335   * After the first registration, subsequent calls with the same service name will fail with
+336   * a return value of {@code false}.
+337   * </p>
+338   * @param instance the {@code Service} subclass instance to expose as a coprocessor endpoint
+339   * @return {@code true} if the registration was successful, {@code false}
+340   * otherwise
+341   */
+342  boolean registerService(Service instance);
+343
+344  /**
+345   * @return true if master is the active one
+346   */
+347  boolean isActiveMaster();
+348
+349  /**
+350   * @return true if master is initialized
+351   */
+352  boolean isInitialized();
+353
+354  /**
+355   * @return true if master is in maintanceMode
+356   */
+357  boolean isInMaintenanceMode();
+358
+359  /**
+360   * Abort a procedure.
+361   * @param procId ID of the procedure
+362   * @param mayInterruptIfRunning if the proc completed at least one step, should it be aborted?
+363   * @return true if aborted, false if procedure already completed or does not exist
+364   * @throws IOException
+365   */
+366  public boolean abortProcedure(final long procId, final boolean mayInterruptIfRunning)
+367      throws IOException;
+368
+369  /**
+370   * Get procedures
+371   * @return procedure list
+372   * @throws IOException
+373   */
+374  public List<Procedure<?>> getProcedures() throws IOException;
+375
+376  /**
+377   * Get locks
+378   * @return lock list
+379   * @throws IOException
+380   */
+381  public List<LockedResource> getLocks() throws IOException;
+382
+383  /**
+384   * Get list of table descriptors by namespace
+385   * @param name namespace name
+386   * @return descriptors
+387   * @throws IOException
+388   */
+389  public List<TableDescriptor> listTableDescriptorsByNamespace(String name) throws IOException;
+390
+391  /**
+392   * Get list of table names by namespace
+393   * @param name namespace name
+394   * @return table names
+395   * @throws IOException
+396   */
+397  public List<TableName> listTableNamesByNamespace(String name) throws IOException;
+398
+399  /**
+400   * @param table the table for which last successful major compaction time is queried
+401   * @return the timestamp of the last successful major compaction for the passed table,
+402   * or 0 if no HFile resulting from a major compaction exists
+403   * @throws IOException
+404   */
+405  public long getLastMajorCompactionTimestamp(TableName table) throws IOException;
+406
+407  /**
+408   * @param regionName
+409   * @return the timestamp of the last successful major compaction for the passed region
+410   * or 0 if no HFile resulting from a major compaction exists
+411   * @throws IOException
+412   */
+413  public long getLastMajorCompactionTimestampForRegion(byte[] regionName) throws IOException;
+414
+415  /**
+416   * @return load balancer
+417   */
+418  public LoadBalancer getLoadBalancer();
+419
+420  boolean isSplitOrMergeEnabled(MasterSwitchType switchType);
 421
-422  boolean isSplitOrMergeEnabled(MasterSwitchType switchType);
-423
-424  /**
-425   * @return Favored Nodes Manager
-426   */
-427  public FavoredNodesManager getFavoredNodesManager();
-428
-429  /**
-430   * Add a new replication peer for replicating data to slave cluster
-431   * @param peerId a short name that identifies the peer
-432   * @param peerConfig configuration for the replication slave cluster
-433   */
-434  void addReplicationPeer(String peerId, ReplicationPeerConfig peerConfig)
-435      throws ReplicationException, IOException;
-436
-437  /**
-438   * Removes a peer and stops the replication
-439   * @param peerId a short name that identifies the peer
-440   */
-441  void removeReplicationPeer(String peerId) throws ReplicationException, IOException;
-442
-443  /**
-444   * Restart the replication stream to the specified peer
-445   * @param peerId a short name that identifies the peer
-446   */
-447  void enableReplicationPeer(String peerId) throws ReplicationException, IOException;
-448
-449  /**
-450   * Stop the replication stream to the specified peer
-451   * @param peerId a short name that identifies the peer
-452   */
-453  void disableReplicationPeer(String peerId) throws ReplicationException, IOException;
-454
-455  /**
-456   * Returns the configured ReplicationPeerConfig for the specified peer
-457   * @param peerId a short name that identifies the peer
-458   * @return ReplicationPeerConfig for the peer
-459   */
-460  ReplicationPeerConfig getReplicationPeerConfig(String peerId) throws ReplicationException,
-461      IOException;
-462
-463  /**
-464   * Update the peerConfig for the specified peer
-465   * @param peerId a short name that identifies the peer
-466   * @param peerConfig new config for the peer
-467   */
-468  void updateReplicationPeerConfig(String peerId, ReplicationPeerConfig peerConfig)
-469      throws ReplicationException, IOException;
-470
-471  /**
-472   * Return a list of replication peers.
-473   * @param regex The regular expression to match peer id
-474   * @return a list of replication peers description
-475   */
-476  List<ReplicationPeerDescription> listReplicationPeers(String regex) throws ReplicationException,
-477      IOException;
-478
-479  /**
-480   * @return {@link LockManager} to lock namespaces/tables/regions.
-481   */
-482  LockManager getLockManager();
+422  /**
+423   * @return Favored Nodes Manager
+424   */
+425  public FavoredNodesManager getFavoredNodesManager();
+426
+427  /**
+428   * Add a new replication peer for replicating data to slave cluster
+429   * @param peerId a short name that identifies the peer
+430   * @param peerConfig configuration for the replication slave cluster
+431   */
+432  void addReplicationPeer(String peerId, ReplicationPeerConfig peerConfig)
+433      throws ReplicationException, IOException;
+434
+435  /**
+436   * Removes a peer and stops the replication
+437   * @param peerId a short name that identifies the peer
+438   */
+439  void removeReplicationPeer(String peerId) throws ReplicationException, IOException;
+440
+441  /**
+442   * Restart the replication stream to the specified peer
+443   * @param peerId a short name that identifies the peer
+444   */
+445  void enableReplicationPeer(String peerId) throws ReplicationException, IOException;
+446
+447  /**
+448   * Stop the replication stream to the specified peer
+449   * @param peerId a short name that identifies the peer
+450   */
+451  void disableReplicationPeer(String peerId) throws ReplicationException, IOException;
+452
+453  /**
+454   * Returns the configured ReplicationPeerConfig for the specified peer
+455   * @param peerId a short name that identifies the peer
+456   * @return ReplicationPeerConfig for the peer
+457   */
+458  ReplicationPeerConfig getReplicationPeerConfig(String peerId) throws ReplicationException,
+459      IOException;
+460
+461  /**
+462   * Update the peerConfig for the specified peer
+463   * @param peerId a short name that identifies the peer
+464   * @param peerConfig new config for the peer
+465   */
+466  void updateReplicationPeerConfig(String peerId, ReplicationPeerConfig peerConfig)
+467      throws ReplicationException, IOException;
+468
+469  /**
+470   * Return a list of replication peers.
+471   * @param regex The regular expression to match peer id
+472   * @return a list of replication peers description
+473   */
+474  List<ReplicationPeerDescription> listReplicationPeers(String regex) throws ReplicationException,
+475      IOException;
+476
+477  /**
+478   * @return {@link LockManager} to lock namespaces/tables/regions.
+479   */
+480  LockManager getLockManager();
+481
+482  public String getRegionServerVersion(final ServerName sn);
 483
-484  public String getRegionServerVersion(final ServerName sn);
+484  public void checkIfShouldMoveSystemRegionAsync();
 485
-486  public void checkIfShouldMoveSystemRegionAsync();
-487
-488  /**
-489   * Recover meta table. Will result in no-op is meta is already initialized. Any code that has
-490   * access to master and requires to access meta during process initialization can call this
-491   * method to make sure meta is initialized.
-492   */
-493  boolean recoverMeta() throws IOException;
-494
-495  String getClientIdAuditPrefix();
-496}
+486  /**
+487   * Recover meta table. Will result in no-op is meta is already initialized. Any code that has
+488   * access to master and requires to access meta during process initialization can call this
+489   * method to make sure meta is initialized.
+490   */
+491  boolean recoverMeta() throws IOException;
+492
+493  String getClientIdAuditPrefix();
+494}