You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by gi...@apache.org on 2017/12/04 15:22:29 UTC

[01/14] hbase-site git commit: Published site at .

Repository: hbase-site
Updated Branches:
  refs/heads/asf-site 9d4462e96 -> 29385b7e5


http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.IgnoreYouAreDeadRS.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.IgnoreYouAreDeadRS.html b/testdevapidocs/src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.IgnoreYouAreDeadRS.html
index ba697d8..c1aa504 100644
--- a/testdevapidocs/src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.IgnoreYouAreDeadRS.html
+++ b/testdevapidocs/src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.IgnoreYouAreDeadRS.html
@@ -32,139 +32,157 @@
 <span class="sourceLineNo">024</span>import java.util.Arrays;<a name="line.24"></a>
 <span class="sourceLineNo">025</span>import java.util.List;<a name="line.25"></a>
 <span class="sourceLineNo">026</span><a name="line.26"></a>
-<span class="sourceLineNo">027</span>import org.apache.hadoop.conf.Configuration;<a name="line.27"></a>
-<span class="sourceLineNo">028</span>import org.apache.hadoop.hbase.HBaseTestingUtility;<a name="line.28"></a>
-<span class="sourceLineNo">029</span>import org.apache.hadoop.hbase.HConstants;<a name="line.29"></a>
-<span class="sourceLineNo">030</span>import org.apache.hadoop.hbase.TableName;<a name="line.30"></a>
-<span class="sourceLineNo">031</span>import org.apache.hadoop.hbase.Waiter.ExplainingPredicate;<a name="line.31"></a>
-<span class="sourceLineNo">032</span>import org.apache.hadoop.hbase.YouAreDeadException;<a name="line.32"></a>
-<span class="sourceLineNo">033</span>import org.apache.hadoop.hbase.client.Get;<a name="line.33"></a>
-<span class="sourceLineNo">034</span>import org.apache.hadoop.hbase.client.Put;<a name="line.34"></a>
-<span class="sourceLineNo">035</span>import org.apache.hadoop.hbase.client.Table;<a name="line.35"></a>
-<span class="sourceLineNo">036</span>import org.apache.hadoop.hbase.testclassification.LargeTests;<a name="line.36"></a>
-<span class="sourceLineNo">037</span>import org.apache.hadoop.hbase.testclassification.RegionServerTests;<a name="line.37"></a>
-<span class="sourceLineNo">038</span>import org.apache.hadoop.hbase.util.Bytes;<a name="line.38"></a>
-<span class="sourceLineNo">039</span>import org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread;<a name="line.39"></a>
-<span class="sourceLineNo">040</span>import org.apache.hadoop.hbase.wal.AsyncFSWALProvider;<a name="line.40"></a>
-<span class="sourceLineNo">041</span>import org.apache.hadoop.hbase.wal.FSHLogProvider;<a name="line.41"></a>
-<span class="sourceLineNo">042</span>import org.apache.hadoop.hbase.wal.WALFactory;<a name="line.42"></a>
-<span class="sourceLineNo">043</span>import org.apache.hadoop.hbase.wal.WALProvider;<a name="line.43"></a>
-<span class="sourceLineNo">044</span>import org.apache.hadoop.hbase.zookeeper.ZKWatcher;<a name="line.44"></a>
-<span class="sourceLineNo">045</span>import org.apache.hadoop.hbase.zookeeper.ZNodePaths;<a name="line.45"></a>
-<span class="sourceLineNo">046</span>import org.junit.After;<a name="line.46"></a>
-<span class="sourceLineNo">047</span>import org.junit.Before;<a name="line.47"></a>
-<span class="sourceLineNo">048</span>import org.junit.Test;<a name="line.48"></a>
-<span class="sourceLineNo">049</span>import org.junit.experimental.categories.Category;<a name="line.49"></a>
-<span class="sourceLineNo">050</span>import org.junit.runner.RunWith;<a name="line.50"></a>
-<span class="sourceLineNo">051</span>import org.junit.runners.Parameterized;<a name="line.51"></a>
-<span class="sourceLineNo">052</span>import org.junit.runners.Parameterized.Parameter;<a name="line.52"></a>
-<span class="sourceLineNo">053</span>import org.junit.runners.Parameterized.Parameters;<a name="line.53"></a>
-<span class="sourceLineNo">054</span><a name="line.54"></a>
-<span class="sourceLineNo">055</span>/**<a name="line.55"></a>
-<span class="sourceLineNo">056</span> * This testcase is used to ensure that the compaction marker will fail a compaction if the RS is<a name="line.56"></a>
-<span class="sourceLineNo">057</span> * already dead. It can not eliminate FNFE when scanning but it does reduce the possibility a lot.<a name="line.57"></a>
-<span class="sourceLineNo">058</span> */<a name="line.58"></a>
-<span class="sourceLineNo">059</span>@RunWith(Parameterized.class)<a name="line.59"></a>
-<span class="sourceLineNo">060</span>@Category({ RegionServerTests.class, LargeTests.class })<a name="line.60"></a>
-<span class="sourceLineNo">061</span>public class TestCompactionInDeadRegionServer {<a name="line.61"></a>
-<span class="sourceLineNo">062</span><a name="line.62"></a>
-<span class="sourceLineNo">063</span>  private static final HBaseTestingUtility UTIL = new HBaseTestingUtility();<a name="line.63"></a>
-<span class="sourceLineNo">064</span><a name="line.64"></a>
-<span class="sourceLineNo">065</span>  private static final TableName TABLE_NAME = TableName.valueOf("test");<a name="line.65"></a>
-<span class="sourceLineNo">066</span><a name="line.66"></a>
-<span class="sourceLineNo">067</span>  private static final byte[] CF = Bytes.toBytes("cf");<a name="line.67"></a>
-<span class="sourceLineNo">068</span><a name="line.68"></a>
-<span class="sourceLineNo">069</span>  private static final byte[] CQ = Bytes.toBytes("cq");<a name="line.69"></a>
-<span class="sourceLineNo">070</span><a name="line.70"></a>
-<span class="sourceLineNo">071</span>  public static final class IgnoreYouAreDeadRS extends HRegionServer {<a name="line.71"></a>
-<span class="sourceLineNo">072</span><a name="line.72"></a>
-<span class="sourceLineNo">073</span>    public IgnoreYouAreDeadRS(Configuration conf) throws IOException, InterruptedException {<a name="line.73"></a>
-<span class="sourceLineNo">074</span>      super(conf);<a name="line.74"></a>
-<span class="sourceLineNo">075</span>    }<a name="line.75"></a>
-<span class="sourceLineNo">076</span><a name="line.76"></a>
-<span class="sourceLineNo">077</span>    @Override<a name="line.77"></a>
-<span class="sourceLineNo">078</span>    protected void tryRegionServerReport(long reportStartTime, long reportEndTime)<a name="line.78"></a>
-<span class="sourceLineNo">079</span>        throws IOException {<a name="line.79"></a>
-<span class="sourceLineNo">080</span>      try {<a name="line.80"></a>
-<span class="sourceLineNo">081</span>        super.tryRegionServerReport(reportStartTime, reportEndTime);<a name="line.81"></a>
-<span class="sourceLineNo">082</span>      } catch (YouAreDeadException e) {<a name="line.82"></a>
-<span class="sourceLineNo">083</span>        // ignore, do not abort<a name="line.83"></a>
-<span class="sourceLineNo">084</span>      }<a name="line.84"></a>
-<span class="sourceLineNo">085</span>    }<a name="line.85"></a>
-<span class="sourceLineNo">086</span>  }<a name="line.86"></a>
-<span class="sourceLineNo">087</span><a name="line.87"></a>
-<span class="sourceLineNo">088</span>  @Parameter<a name="line.88"></a>
-<span class="sourceLineNo">089</span>  public Class&lt;? extends WALProvider&gt; walProvider;<a name="line.89"></a>
+<span class="sourceLineNo">027</span>import org.apache.commons.logging.Log;<a name="line.27"></a>
+<span class="sourceLineNo">028</span>import org.apache.commons.logging.LogFactory;<a name="line.28"></a>
+<span class="sourceLineNo">029</span>import org.apache.hadoop.conf.Configuration;<a name="line.29"></a>
+<span class="sourceLineNo">030</span>import org.apache.hadoop.hbase.HBaseTestingUtility;<a name="line.30"></a>
+<span class="sourceLineNo">031</span>import org.apache.hadoop.hbase.HConstants;<a name="line.31"></a>
+<span class="sourceLineNo">032</span>import org.apache.hadoop.hbase.TableName;<a name="line.32"></a>
+<span class="sourceLineNo">033</span>import org.apache.hadoop.hbase.Waiter.ExplainingPredicate;<a name="line.33"></a>
+<span class="sourceLineNo">034</span>import org.apache.hadoop.hbase.YouAreDeadException;<a name="line.34"></a>
+<span class="sourceLineNo">035</span>import org.apache.hadoop.hbase.client.Get;<a name="line.35"></a>
+<span class="sourceLineNo">036</span>import org.apache.hadoop.hbase.client.Put;<a name="line.36"></a>
+<span class="sourceLineNo">037</span>import org.apache.hadoop.hbase.client.Table;<a name="line.37"></a>
+<span class="sourceLineNo">038</span>import org.apache.hadoop.hbase.testclassification.LargeTests;<a name="line.38"></a>
+<span class="sourceLineNo">039</span>import org.apache.hadoop.hbase.testclassification.RegionServerTests;<a name="line.39"></a>
+<span class="sourceLineNo">040</span>import org.apache.hadoop.hbase.util.Bytes;<a name="line.40"></a>
+<span class="sourceLineNo">041</span>import org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread;<a name="line.41"></a>
+<span class="sourceLineNo">042</span>import org.apache.hadoop.hbase.wal.AsyncFSWALProvider;<a name="line.42"></a>
+<span class="sourceLineNo">043</span>import org.apache.hadoop.hbase.wal.FSHLogProvider;<a name="line.43"></a>
+<span class="sourceLineNo">044</span>import org.apache.hadoop.hbase.wal.WALFactory;<a name="line.44"></a>
+<span class="sourceLineNo">045</span>import org.apache.hadoop.hbase.wal.WALProvider;<a name="line.45"></a>
+<span class="sourceLineNo">046</span>import org.apache.hadoop.hbase.zookeeper.ZKWatcher;<a name="line.46"></a>
+<span class="sourceLineNo">047</span>import org.apache.hadoop.hbase.zookeeper.ZNodePaths;<a name="line.47"></a>
+<span class="sourceLineNo">048</span>import org.junit.After;<a name="line.48"></a>
+<span class="sourceLineNo">049</span>import org.junit.Before;<a name="line.49"></a>
+<span class="sourceLineNo">050</span>import org.junit.Test;<a name="line.50"></a>
+<span class="sourceLineNo">051</span>import org.junit.experimental.categories.Category;<a name="line.51"></a>
+<span class="sourceLineNo">052</span>import org.junit.runner.RunWith;<a name="line.52"></a>
+<span class="sourceLineNo">053</span>import org.junit.runners.Parameterized;<a name="line.53"></a>
+<span class="sourceLineNo">054</span>import org.junit.runners.Parameterized.Parameter;<a name="line.54"></a>
+<span class="sourceLineNo">055</span>import org.junit.runners.Parameterized.Parameters;<a name="line.55"></a>
+<span class="sourceLineNo">056</span><a name="line.56"></a>
+<span class="sourceLineNo">057</span>/**<a name="line.57"></a>
+<span class="sourceLineNo">058</span> * This testcase is used to ensure that the compaction marker will fail a compaction if the RS is<a name="line.58"></a>
+<span class="sourceLineNo">059</span> * already dead. It can not eliminate FNFE when scanning but it does reduce the possibility a lot.<a name="line.59"></a>
+<span class="sourceLineNo">060</span> */<a name="line.60"></a>
+<span class="sourceLineNo">061</span>@RunWith(Parameterized.class)<a name="line.61"></a>
+<span class="sourceLineNo">062</span>@Category({ RegionServerTests.class, LargeTests.class })<a name="line.62"></a>
+<span class="sourceLineNo">063</span>public class TestCompactionInDeadRegionServer {<a name="line.63"></a>
+<span class="sourceLineNo">064</span>  private static final Log LOG = LogFactory.getLog(TestCompactionInDeadRegionServer.class);<a name="line.64"></a>
+<span class="sourceLineNo">065</span><a name="line.65"></a>
+<span class="sourceLineNo">066</span>  private static final HBaseTestingUtility UTIL = new HBaseTestingUtility();<a name="line.66"></a>
+<span class="sourceLineNo">067</span><a name="line.67"></a>
+<span class="sourceLineNo">068</span>  private static final TableName TABLE_NAME = TableName.valueOf("test");<a name="line.68"></a>
+<span class="sourceLineNo">069</span><a name="line.69"></a>
+<span class="sourceLineNo">070</span>  private static final byte[] CF = Bytes.toBytes("cf");<a name="line.70"></a>
+<span class="sourceLineNo">071</span><a name="line.71"></a>
+<span class="sourceLineNo">072</span>  private static final byte[] CQ = Bytes.toBytes("cq");<a name="line.72"></a>
+<span class="sourceLineNo">073</span><a name="line.73"></a>
+<span class="sourceLineNo">074</span>  public static final class IgnoreYouAreDeadRS extends HRegionServer {<a name="line.74"></a>
+<span class="sourceLineNo">075</span><a name="line.75"></a>
+<span class="sourceLineNo">076</span>    public IgnoreYouAreDeadRS(Configuration conf) throws IOException, InterruptedException {<a name="line.76"></a>
+<span class="sourceLineNo">077</span>      super(conf);<a name="line.77"></a>
+<span class="sourceLineNo">078</span>    }<a name="line.78"></a>
+<span class="sourceLineNo">079</span><a name="line.79"></a>
+<span class="sourceLineNo">080</span>    @Override<a name="line.80"></a>
+<span class="sourceLineNo">081</span>    protected void tryRegionServerReport(long reportStartTime, long reportEndTime)<a name="line.81"></a>
+<span class="sourceLineNo">082</span>        throws IOException {<a name="line.82"></a>
+<span class="sourceLineNo">083</span>      try {<a name="line.83"></a>
+<span class="sourceLineNo">084</span>        super.tryRegionServerReport(reportStartTime, reportEndTime);<a name="line.84"></a>
+<span class="sourceLineNo">085</span>      } catch (YouAreDeadException e) {<a name="line.85"></a>
+<span class="sourceLineNo">086</span>        // ignore, do not abort<a name="line.86"></a>
+<span class="sourceLineNo">087</span>      }<a name="line.87"></a>
+<span class="sourceLineNo">088</span>    }<a name="line.88"></a>
+<span class="sourceLineNo">089</span>  }<a name="line.89"></a>
 <span class="sourceLineNo">090</span><a name="line.90"></a>
-<span class="sourceLineNo">091</span>  @Parameters(name = "{index}: wal={0}")<a name="line.91"></a>
-<span class="sourceLineNo">092</span>  public static List&lt;Object[]&gt; params() {<a name="line.92"></a>
-<span class="sourceLineNo">093</span>    return Arrays.asList(new Object[] { FSHLogProvider.class },<a name="line.93"></a>
-<span class="sourceLineNo">094</span>      new Object[] { AsyncFSWALProvider.class });<a name="line.94"></a>
-<span class="sourceLineNo">095</span>  }<a name="line.95"></a>
-<span class="sourceLineNo">096</span><a name="line.96"></a>
-<span class="sourceLineNo">097</span>  @Before<a name="line.97"></a>
-<span class="sourceLineNo">098</span>  public void setUp() throws Exception {<a name="line.98"></a>
-<span class="sourceLineNo">099</span>    UTIL.getConfiguration().setClass(WALFactory.WAL_PROVIDER, walProvider, WALProvider.class);<a name="line.99"></a>
-<span class="sourceLineNo">100</span>    UTIL.getConfiguration().setInt(HConstants.ZK_SESSION_TIMEOUT, 2000);<a name="line.100"></a>
-<span class="sourceLineNo">101</span>    UTIL.getConfiguration().setClass(HConstants.REGION_SERVER_IMPL, IgnoreYouAreDeadRS.class,<a name="line.101"></a>
-<span class="sourceLineNo">102</span>      HRegionServer.class);<a name="line.102"></a>
-<span class="sourceLineNo">103</span>    UTIL.startMiniCluster(2);<a name="line.103"></a>
-<span class="sourceLineNo">104</span>    Table table = UTIL.createTable(TABLE_NAME, CF);<a name="line.104"></a>
-<span class="sourceLineNo">105</span>    for (int i = 0; i &lt; 10; i++) {<a name="line.105"></a>
-<span class="sourceLineNo">106</span>      table.put(new Put(Bytes.toBytes(i)).addColumn(CF, CQ, Bytes.toBytes(i)));<a name="line.106"></a>
-<span class="sourceLineNo">107</span>    }<a name="line.107"></a>
-<span class="sourceLineNo">108</span>    UTIL.getAdmin().flush(TABLE_NAME);<a name="line.108"></a>
-<span class="sourceLineNo">109</span>    for (int i = 10; i &lt; 20; i++) {<a name="line.109"></a>
-<span class="sourceLineNo">110</span>      table.put(new Put(Bytes.toBytes(i)).addColumn(CF, CQ, Bytes.toBytes(i)));<a name="line.110"></a>
-<span class="sourceLineNo">111</span>    }<a name="line.111"></a>
-<span class="sourceLineNo">112</span>    UTIL.getAdmin().flush(TABLE_NAME);<a name="line.112"></a>
-<span class="sourceLineNo">113</span>  }<a name="line.113"></a>
-<span class="sourceLineNo">114</span><a name="line.114"></a>
-<span class="sourceLineNo">115</span>  @After<a name="line.115"></a>
-<span class="sourceLineNo">116</span>  public void tearDown() throws Exception {<a name="line.116"></a>
-<span class="sourceLineNo">117</span>    UTIL.shutdownMiniCluster();<a name="line.117"></a>
-<span class="sourceLineNo">118</span>  }<a name="line.118"></a>
-<span class="sourceLineNo">119</span><a name="line.119"></a>
-<span class="sourceLineNo">120</span>  @Test<a name="line.120"></a>
-<span class="sourceLineNo">121</span>  public void test() throws Exception {<a name="line.121"></a>
-<span class="sourceLineNo">122</span>    HRegionServer rsToSuspend = UTIL.getRSForFirstRegionInTable(TABLE_NAME);<a name="line.122"></a>
-<span class="sourceLineNo">123</span>    HRegion region = (HRegion) rsToSuspend.getRegions(TABLE_NAME).get(0);<a name="line.123"></a>
-<span class="sourceLineNo">124</span>    ZKWatcher watcher = UTIL.getZooKeeperWatcher();<a name="line.124"></a>
-<span class="sourceLineNo">125</span>    watcher.getRecoverableZooKeeper().delete(<a name="line.125"></a>
-<span class="sourceLineNo">126</span>      ZNodePaths.joinZNode(watcher.getZNodePaths().rsZNode, rsToSuspend.getServerName().toString()),<a name="line.126"></a>
-<span class="sourceLineNo">127</span>      -1);<a name="line.127"></a>
-<span class="sourceLineNo">128</span>    UTIL.waitFor(60000, 1000, new ExplainingPredicate&lt;Exception&gt;() {<a name="line.128"></a>
-<span class="sourceLineNo">129</span><a name="line.129"></a>
-<span class="sourceLineNo">130</span>      @Override<a name="line.130"></a>
-<span class="sourceLineNo">131</span>      public boolean evaluate() throws Exception {<a name="line.131"></a>
-<span class="sourceLineNo">132</span>        for (RegionServerThread thread : UTIL.getHBaseCluster().getRegionServerThreads()) {<a name="line.132"></a>
-<span class="sourceLineNo">133</span>          HRegionServer rs = thread.getRegionServer();<a name="line.133"></a>
-<span class="sourceLineNo">134</span>          if (rs != rsToSuspend) {<a name="line.134"></a>
-<span class="sourceLineNo">135</span>            return !rs.getRegions(TABLE_NAME).isEmpty();<a name="line.135"></a>
-<span class="sourceLineNo">136</span>          }<a name="line.136"></a>
-<span class="sourceLineNo">137</span>        }<a name="line.137"></a>
-<span class="sourceLineNo">138</span>        return false;<a name="line.138"></a>
-<span class="sourceLineNo">139</span>      }<a name="line.139"></a>
+<span class="sourceLineNo">091</span>  @Parameter<a name="line.91"></a>
+<span class="sourceLineNo">092</span>  public Class&lt;? extends WALProvider&gt; walProvider;<a name="line.92"></a>
+<span class="sourceLineNo">093</span><a name="line.93"></a>
+<span class="sourceLineNo">094</span>  @Parameters(name = "{index}: wal={0}")<a name="line.94"></a>
+<span class="sourceLineNo">095</span>  public static List&lt;Object[]&gt; params() {<a name="line.95"></a>
+<span class="sourceLineNo">096</span>    return Arrays.asList(new Object[] { FSHLogProvider.class },<a name="line.96"></a>
+<span class="sourceLineNo">097</span>        new Object[] { AsyncFSWALProvider.class });<a name="line.97"></a>
+<span class="sourceLineNo">098</span>  }<a name="line.98"></a>
+<span class="sourceLineNo">099</span><a name="line.99"></a>
+<span class="sourceLineNo">100</span>  @Before<a name="line.100"></a>
+<span class="sourceLineNo">101</span>  public void setUp() throws Exception {<a name="line.101"></a>
+<span class="sourceLineNo">102</span>    UTIL.getConfiguration().setClass(WALFactory.WAL_PROVIDER, walProvider, WALProvider.class);<a name="line.102"></a>
+<span class="sourceLineNo">103</span>    UTIL.getConfiguration().setInt(HConstants.ZK_SESSION_TIMEOUT, 2000);<a name="line.103"></a>
+<span class="sourceLineNo">104</span>    UTIL.getConfiguration().setClass(HConstants.REGION_SERVER_IMPL, IgnoreYouAreDeadRS.class,<a name="line.104"></a>
+<span class="sourceLineNo">105</span>      HRegionServer.class);<a name="line.105"></a>
+<span class="sourceLineNo">106</span>    UTIL.startMiniCluster(2);<a name="line.106"></a>
+<span class="sourceLineNo">107</span>    Table table = UTIL.createTable(TABLE_NAME, CF);<a name="line.107"></a>
+<span class="sourceLineNo">108</span>    for (int i = 0; i &lt; 10; i++) {<a name="line.108"></a>
+<span class="sourceLineNo">109</span>      table.put(new Put(Bytes.toBytes(i)).addColumn(CF, CQ, Bytes.toBytes(i)));<a name="line.109"></a>
+<span class="sourceLineNo">110</span>    }<a name="line.110"></a>
+<span class="sourceLineNo">111</span>    UTIL.getAdmin().flush(TABLE_NAME);<a name="line.111"></a>
+<span class="sourceLineNo">112</span>    for (int i = 10; i &lt; 20; i++) {<a name="line.112"></a>
+<span class="sourceLineNo">113</span>      table.put(new Put(Bytes.toBytes(i)).addColumn(CF, CQ, Bytes.toBytes(i)));<a name="line.113"></a>
+<span class="sourceLineNo">114</span>    }<a name="line.114"></a>
+<span class="sourceLineNo">115</span>    UTIL.getAdmin().flush(TABLE_NAME);<a name="line.115"></a>
+<span class="sourceLineNo">116</span>  }<a name="line.116"></a>
+<span class="sourceLineNo">117</span><a name="line.117"></a>
+<span class="sourceLineNo">118</span>  @After<a name="line.118"></a>
+<span class="sourceLineNo">119</span>  public void tearDown() throws Exception {<a name="line.119"></a>
+<span class="sourceLineNo">120</span>    UTIL.shutdownMiniCluster();<a name="line.120"></a>
+<span class="sourceLineNo">121</span>  }<a name="line.121"></a>
+<span class="sourceLineNo">122</span><a name="line.122"></a>
+<span class="sourceLineNo">123</span>  @Test<a name="line.123"></a>
+<span class="sourceLineNo">124</span>  public void test() throws Exception {<a name="line.124"></a>
+<span class="sourceLineNo">125</span>    HRegionServer regionSvr = UTIL.getRSForFirstRegionInTable(TABLE_NAME);<a name="line.125"></a>
+<span class="sourceLineNo">126</span>    HRegion region = regionSvr.getRegions(TABLE_NAME).get(0);<a name="line.126"></a>
+<span class="sourceLineNo">127</span>    String regName = region.getRegionInfo().getEncodedName();<a name="line.127"></a>
+<span class="sourceLineNo">128</span>    List&lt;HRegion&gt; metaRegs = regionSvr.getRegions(TableName.META_TABLE_NAME);<a name="line.128"></a>
+<span class="sourceLineNo">129</span>    if (metaRegs != null &amp;&amp; !metaRegs.isEmpty()) {<a name="line.129"></a>
+<span class="sourceLineNo">130</span>      LOG.info("meta is on the same server: " + regionSvr);<a name="line.130"></a>
+<span class="sourceLineNo">131</span>      // when region is on same server as hbase:meta, reassigning meta would abort the server<a name="line.131"></a>
+<span class="sourceLineNo">132</span>      // since WAL is broken.<a name="line.132"></a>
+<span class="sourceLineNo">133</span>      // so the region is moved to a different server<a name="line.133"></a>
+<span class="sourceLineNo">134</span>      HRegionServer otherRs = UTIL.getOtherRegionServer(regionSvr);<a name="line.134"></a>
+<span class="sourceLineNo">135</span>      UTIL.moveRegionAndWait(region.getRegionInfo(), otherRs.getServerName());<a name="line.135"></a>
+<span class="sourceLineNo">136</span>      LOG.info("Moved region: " + regName + " to " + otherRs.getServerName());<a name="line.136"></a>
+<span class="sourceLineNo">137</span>    }<a name="line.137"></a>
+<span class="sourceLineNo">138</span>    HRegionServer rsToSuspend = UTIL.getRSForFirstRegionInTable(TABLE_NAME);<a name="line.138"></a>
+<span class="sourceLineNo">139</span>    region = rsToSuspend.getRegions(TABLE_NAME).get(0);<a name="line.139"></a>
 <span class="sourceLineNo">140</span><a name="line.140"></a>
-<span class="sourceLineNo">141</span>      @Override<a name="line.141"></a>
-<span class="sourceLineNo">142</span>      public String explainFailure() throws Exception {<a name="line.142"></a>
-<span class="sourceLineNo">143</span>        return "The region for " + TABLE_NAME + " is still on " + rsToSuspend.getServerName();<a name="line.143"></a>
-<span class="sourceLineNo">144</span>      }<a name="line.144"></a>
-<span class="sourceLineNo">145</span>    });<a name="line.145"></a>
-<span class="sourceLineNo">146</span>    try {<a name="line.146"></a>
-<span class="sourceLineNo">147</span>      region.compact(true);<a name="line.147"></a>
-<span class="sourceLineNo">148</span>      fail("Should fail as our wal file has already been closed, " +<a name="line.148"></a>
-<span class="sourceLineNo">149</span>          "and walDir has also been renamed");<a name="line.149"></a>
-<span class="sourceLineNo">150</span>    } catch (Exception e) {<a name="line.150"></a>
-<span class="sourceLineNo">151</span>      // expected<a name="line.151"></a>
-<span class="sourceLineNo">152</span>    }<a name="line.152"></a>
-<span class="sourceLineNo">153</span>    Table table = UTIL.getConnection().getTable(TABLE_NAME);<a name="line.153"></a>
-<span class="sourceLineNo">154</span>    // should not hit FNFE<a name="line.154"></a>
-<span class="sourceLineNo">155</span>    for (int i = 0; i &lt; 20; i++) {<a name="line.155"></a>
-<span class="sourceLineNo">156</span>      assertEquals(i, Bytes.toInt(table.get(new Get(Bytes.toBytes(i))).getValue(CF, CQ)));<a name="line.156"></a>
-<span class="sourceLineNo">157</span>    }<a name="line.157"></a>
-<span class="sourceLineNo">158</span>  }<a name="line.158"></a>
-<span class="sourceLineNo">159</span>}<a name="line.159"></a>
+<span class="sourceLineNo">141</span>    ZKWatcher watcher = UTIL.getZooKeeperWatcher();<a name="line.141"></a>
+<span class="sourceLineNo">142</span>    watcher.getRecoverableZooKeeper().delete(<a name="line.142"></a>
+<span class="sourceLineNo">143</span>      ZNodePaths.joinZNode(watcher.getZNodePaths().rsZNode, rsToSuspend.getServerName().toString()),<a name="line.143"></a>
+<span class="sourceLineNo">144</span>      -1);<a name="line.144"></a>
+<span class="sourceLineNo">145</span>    LOG.info("suspending " + rsToSuspend);<a name="line.145"></a>
+<span class="sourceLineNo">146</span>    UTIL.waitFor(60000, 1000, new ExplainingPredicate&lt;Exception&gt;() {<a name="line.146"></a>
+<span class="sourceLineNo">147</span><a name="line.147"></a>
+<span class="sourceLineNo">148</span>      @Override<a name="line.148"></a>
+<span class="sourceLineNo">149</span>      public boolean evaluate() throws Exception {<a name="line.149"></a>
+<span class="sourceLineNo">150</span>        for (RegionServerThread thread : UTIL.getHBaseCluster().getRegionServerThreads()) {<a name="line.150"></a>
+<span class="sourceLineNo">151</span>          HRegionServer rs = thread.getRegionServer();<a name="line.151"></a>
+<span class="sourceLineNo">152</span>          if (rs != rsToSuspend) {<a name="line.152"></a>
+<span class="sourceLineNo">153</span>            return !rs.getRegions(TABLE_NAME).isEmpty();<a name="line.153"></a>
+<span class="sourceLineNo">154</span>          }<a name="line.154"></a>
+<span class="sourceLineNo">155</span>        }<a name="line.155"></a>
+<span class="sourceLineNo">156</span>        return false;<a name="line.156"></a>
+<span class="sourceLineNo">157</span>      }<a name="line.157"></a>
+<span class="sourceLineNo">158</span><a name="line.158"></a>
+<span class="sourceLineNo">159</span>      @Override<a name="line.159"></a>
+<span class="sourceLineNo">160</span>      public String explainFailure() throws Exception {<a name="line.160"></a>
+<span class="sourceLineNo">161</span>        return "The region for " + TABLE_NAME + " is still on " + rsToSuspend.getServerName();<a name="line.161"></a>
+<span class="sourceLineNo">162</span>      }<a name="line.162"></a>
+<span class="sourceLineNo">163</span>    });<a name="line.163"></a>
+<span class="sourceLineNo">164</span>    try {<a name="line.164"></a>
+<span class="sourceLineNo">165</span>      region.compact(true);<a name="line.165"></a>
+<span class="sourceLineNo">166</span>      fail("Should fail as our wal file has already been closed, " +<a name="line.166"></a>
+<span class="sourceLineNo">167</span>          "and walDir has also been renamed");<a name="line.167"></a>
+<span class="sourceLineNo">168</span>    } catch (Exception e) {<a name="line.168"></a>
+<span class="sourceLineNo">169</span>      LOG.debug("expected exception: ", e);<a name="line.169"></a>
+<span class="sourceLineNo">170</span>    }<a name="line.170"></a>
+<span class="sourceLineNo">171</span>    Table table = UTIL.getConnection().getTable(TABLE_NAME);<a name="line.171"></a>
+<span class="sourceLineNo">172</span>    // should not hit FNFE<a name="line.172"></a>
+<span class="sourceLineNo">173</span>    for (int i = 0; i &lt; 20; i++) {<a name="line.173"></a>
+<span class="sourceLineNo">174</span>      assertEquals(i, Bytes.toInt(table.get(new Get(Bytes.toBytes(i))).getValue(CF, CQ)));<a name="line.174"></a>
+<span class="sourceLineNo">175</span>    }<a name="line.175"></a>
+<span class="sourceLineNo">176</span>  }<a name="line.176"></a>
+<span class="sourceLineNo">177</span>}<a name="line.177"></a>
 
 
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html b/testdevapidocs/src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html
index ba697d8..c1aa504 100644
--- a/testdevapidocs/src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html
+++ b/testdevapidocs/src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html
@@ -32,139 +32,157 @@
 <span class="sourceLineNo">024</span>import java.util.Arrays;<a name="line.24"></a>
 <span class="sourceLineNo">025</span>import java.util.List;<a name="line.25"></a>
 <span class="sourceLineNo">026</span><a name="line.26"></a>
-<span class="sourceLineNo">027</span>import org.apache.hadoop.conf.Configuration;<a name="line.27"></a>
-<span class="sourceLineNo">028</span>import org.apache.hadoop.hbase.HBaseTestingUtility;<a name="line.28"></a>
-<span class="sourceLineNo">029</span>import org.apache.hadoop.hbase.HConstants;<a name="line.29"></a>
-<span class="sourceLineNo">030</span>import org.apache.hadoop.hbase.TableName;<a name="line.30"></a>
-<span class="sourceLineNo">031</span>import org.apache.hadoop.hbase.Waiter.ExplainingPredicate;<a name="line.31"></a>
-<span class="sourceLineNo">032</span>import org.apache.hadoop.hbase.YouAreDeadException;<a name="line.32"></a>
-<span class="sourceLineNo">033</span>import org.apache.hadoop.hbase.client.Get;<a name="line.33"></a>
-<span class="sourceLineNo">034</span>import org.apache.hadoop.hbase.client.Put;<a name="line.34"></a>
-<span class="sourceLineNo">035</span>import org.apache.hadoop.hbase.client.Table;<a name="line.35"></a>
-<span class="sourceLineNo">036</span>import org.apache.hadoop.hbase.testclassification.LargeTests;<a name="line.36"></a>
-<span class="sourceLineNo">037</span>import org.apache.hadoop.hbase.testclassification.RegionServerTests;<a name="line.37"></a>
-<span class="sourceLineNo">038</span>import org.apache.hadoop.hbase.util.Bytes;<a name="line.38"></a>
-<span class="sourceLineNo">039</span>import org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread;<a name="line.39"></a>
-<span class="sourceLineNo">040</span>import org.apache.hadoop.hbase.wal.AsyncFSWALProvider;<a name="line.40"></a>
-<span class="sourceLineNo">041</span>import org.apache.hadoop.hbase.wal.FSHLogProvider;<a name="line.41"></a>
-<span class="sourceLineNo">042</span>import org.apache.hadoop.hbase.wal.WALFactory;<a name="line.42"></a>
-<span class="sourceLineNo">043</span>import org.apache.hadoop.hbase.wal.WALProvider;<a name="line.43"></a>
-<span class="sourceLineNo">044</span>import org.apache.hadoop.hbase.zookeeper.ZKWatcher;<a name="line.44"></a>
-<span class="sourceLineNo">045</span>import org.apache.hadoop.hbase.zookeeper.ZNodePaths;<a name="line.45"></a>
-<span class="sourceLineNo">046</span>import org.junit.After;<a name="line.46"></a>
-<span class="sourceLineNo">047</span>import org.junit.Before;<a name="line.47"></a>
-<span class="sourceLineNo">048</span>import org.junit.Test;<a name="line.48"></a>
-<span class="sourceLineNo">049</span>import org.junit.experimental.categories.Category;<a name="line.49"></a>
-<span class="sourceLineNo">050</span>import org.junit.runner.RunWith;<a name="line.50"></a>
-<span class="sourceLineNo">051</span>import org.junit.runners.Parameterized;<a name="line.51"></a>
-<span class="sourceLineNo">052</span>import org.junit.runners.Parameterized.Parameter;<a name="line.52"></a>
-<span class="sourceLineNo">053</span>import org.junit.runners.Parameterized.Parameters;<a name="line.53"></a>
-<span class="sourceLineNo">054</span><a name="line.54"></a>
-<span class="sourceLineNo">055</span>/**<a name="line.55"></a>
-<span class="sourceLineNo">056</span> * This testcase is used to ensure that the compaction marker will fail a compaction if the RS is<a name="line.56"></a>
-<span class="sourceLineNo">057</span> * already dead. It can not eliminate FNFE when scanning but it does reduce the possibility a lot.<a name="line.57"></a>
-<span class="sourceLineNo">058</span> */<a name="line.58"></a>
-<span class="sourceLineNo">059</span>@RunWith(Parameterized.class)<a name="line.59"></a>
-<span class="sourceLineNo">060</span>@Category({ RegionServerTests.class, LargeTests.class })<a name="line.60"></a>
-<span class="sourceLineNo">061</span>public class TestCompactionInDeadRegionServer {<a name="line.61"></a>
-<span class="sourceLineNo">062</span><a name="line.62"></a>
-<span class="sourceLineNo">063</span>  private static final HBaseTestingUtility UTIL = new HBaseTestingUtility();<a name="line.63"></a>
-<span class="sourceLineNo">064</span><a name="line.64"></a>
-<span class="sourceLineNo">065</span>  private static final TableName TABLE_NAME = TableName.valueOf("test");<a name="line.65"></a>
-<span class="sourceLineNo">066</span><a name="line.66"></a>
-<span class="sourceLineNo">067</span>  private static final byte[] CF = Bytes.toBytes("cf");<a name="line.67"></a>
-<span class="sourceLineNo">068</span><a name="line.68"></a>
-<span class="sourceLineNo">069</span>  private static final byte[] CQ = Bytes.toBytes("cq");<a name="line.69"></a>
-<span class="sourceLineNo">070</span><a name="line.70"></a>
-<span class="sourceLineNo">071</span>  public static final class IgnoreYouAreDeadRS extends HRegionServer {<a name="line.71"></a>
-<span class="sourceLineNo">072</span><a name="line.72"></a>
-<span class="sourceLineNo">073</span>    public IgnoreYouAreDeadRS(Configuration conf) throws IOException, InterruptedException {<a name="line.73"></a>
-<span class="sourceLineNo">074</span>      super(conf);<a name="line.74"></a>
-<span class="sourceLineNo">075</span>    }<a name="line.75"></a>
-<span class="sourceLineNo">076</span><a name="line.76"></a>
-<span class="sourceLineNo">077</span>    @Override<a name="line.77"></a>
-<span class="sourceLineNo">078</span>    protected void tryRegionServerReport(long reportStartTime, long reportEndTime)<a name="line.78"></a>
-<span class="sourceLineNo">079</span>        throws IOException {<a name="line.79"></a>
-<span class="sourceLineNo">080</span>      try {<a name="line.80"></a>
-<span class="sourceLineNo">081</span>        super.tryRegionServerReport(reportStartTime, reportEndTime);<a name="line.81"></a>
-<span class="sourceLineNo">082</span>      } catch (YouAreDeadException e) {<a name="line.82"></a>
-<span class="sourceLineNo">083</span>        // ignore, do not abort<a name="line.83"></a>
-<span class="sourceLineNo">084</span>      }<a name="line.84"></a>
-<span class="sourceLineNo">085</span>    }<a name="line.85"></a>
-<span class="sourceLineNo">086</span>  }<a name="line.86"></a>
-<span class="sourceLineNo">087</span><a name="line.87"></a>
-<span class="sourceLineNo">088</span>  @Parameter<a name="line.88"></a>
-<span class="sourceLineNo">089</span>  public Class&lt;? extends WALProvider&gt; walProvider;<a name="line.89"></a>
+<span class="sourceLineNo">027</span>import org.apache.commons.logging.Log;<a name="line.27"></a>
+<span class="sourceLineNo">028</span>import org.apache.commons.logging.LogFactory;<a name="line.28"></a>
+<span class="sourceLineNo">029</span>import org.apache.hadoop.conf.Configuration;<a name="line.29"></a>
+<span class="sourceLineNo">030</span>import org.apache.hadoop.hbase.HBaseTestingUtility;<a name="line.30"></a>
+<span class="sourceLineNo">031</span>import org.apache.hadoop.hbase.HConstants;<a name="line.31"></a>
+<span class="sourceLineNo">032</span>import org.apache.hadoop.hbase.TableName;<a name="line.32"></a>
+<span class="sourceLineNo">033</span>import org.apache.hadoop.hbase.Waiter.ExplainingPredicate;<a name="line.33"></a>
+<span class="sourceLineNo">034</span>import org.apache.hadoop.hbase.YouAreDeadException;<a name="line.34"></a>
+<span class="sourceLineNo">035</span>import org.apache.hadoop.hbase.client.Get;<a name="line.35"></a>
+<span class="sourceLineNo">036</span>import org.apache.hadoop.hbase.client.Put;<a name="line.36"></a>
+<span class="sourceLineNo">037</span>import org.apache.hadoop.hbase.client.Table;<a name="line.37"></a>
+<span class="sourceLineNo">038</span>import org.apache.hadoop.hbase.testclassification.LargeTests;<a name="line.38"></a>
+<span class="sourceLineNo">039</span>import org.apache.hadoop.hbase.testclassification.RegionServerTests;<a name="line.39"></a>
+<span class="sourceLineNo">040</span>import org.apache.hadoop.hbase.util.Bytes;<a name="line.40"></a>
+<span class="sourceLineNo">041</span>import org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread;<a name="line.41"></a>
+<span class="sourceLineNo">042</span>import org.apache.hadoop.hbase.wal.AsyncFSWALProvider;<a name="line.42"></a>
+<span class="sourceLineNo">043</span>import org.apache.hadoop.hbase.wal.FSHLogProvider;<a name="line.43"></a>
+<span class="sourceLineNo">044</span>import org.apache.hadoop.hbase.wal.WALFactory;<a name="line.44"></a>
+<span class="sourceLineNo">045</span>import org.apache.hadoop.hbase.wal.WALProvider;<a name="line.45"></a>
+<span class="sourceLineNo">046</span>import org.apache.hadoop.hbase.zookeeper.ZKWatcher;<a name="line.46"></a>
+<span class="sourceLineNo">047</span>import org.apache.hadoop.hbase.zookeeper.ZNodePaths;<a name="line.47"></a>
+<span class="sourceLineNo">048</span>import org.junit.After;<a name="line.48"></a>
+<span class="sourceLineNo">049</span>import org.junit.Before;<a name="line.49"></a>
+<span class="sourceLineNo">050</span>import org.junit.Test;<a name="line.50"></a>
+<span class="sourceLineNo">051</span>import org.junit.experimental.categories.Category;<a name="line.51"></a>
+<span class="sourceLineNo">052</span>import org.junit.runner.RunWith;<a name="line.52"></a>
+<span class="sourceLineNo">053</span>import org.junit.runners.Parameterized;<a name="line.53"></a>
+<span class="sourceLineNo">054</span>import org.junit.runners.Parameterized.Parameter;<a name="line.54"></a>
+<span class="sourceLineNo">055</span>import org.junit.runners.Parameterized.Parameters;<a name="line.55"></a>
+<span class="sourceLineNo">056</span><a name="line.56"></a>
+<span class="sourceLineNo">057</span>/**<a name="line.57"></a>
+<span class="sourceLineNo">058</span> * This testcase is used to ensure that the compaction marker will fail a compaction if the RS is<a name="line.58"></a>
+<span class="sourceLineNo">059</span> * already dead. It can not eliminate FNFE when scanning but it does reduce the possibility a lot.<a name="line.59"></a>
+<span class="sourceLineNo">060</span> */<a name="line.60"></a>
+<span class="sourceLineNo">061</span>@RunWith(Parameterized.class)<a name="line.61"></a>
+<span class="sourceLineNo">062</span>@Category({ RegionServerTests.class, LargeTests.class })<a name="line.62"></a>
+<span class="sourceLineNo">063</span>public class TestCompactionInDeadRegionServer {<a name="line.63"></a>
+<span class="sourceLineNo">064</span>  private static final Log LOG = LogFactory.getLog(TestCompactionInDeadRegionServer.class);<a name="line.64"></a>
+<span class="sourceLineNo">065</span><a name="line.65"></a>
+<span class="sourceLineNo">066</span>  private static final HBaseTestingUtility UTIL = new HBaseTestingUtility();<a name="line.66"></a>
+<span class="sourceLineNo">067</span><a name="line.67"></a>
+<span class="sourceLineNo">068</span>  private static final TableName TABLE_NAME = TableName.valueOf("test");<a name="line.68"></a>
+<span class="sourceLineNo">069</span><a name="line.69"></a>
+<span class="sourceLineNo">070</span>  private static final byte[] CF = Bytes.toBytes("cf");<a name="line.70"></a>
+<span class="sourceLineNo">071</span><a name="line.71"></a>
+<span class="sourceLineNo">072</span>  private static final byte[] CQ = Bytes.toBytes("cq");<a name="line.72"></a>
+<span class="sourceLineNo">073</span><a name="line.73"></a>
+<span class="sourceLineNo">074</span>  public static final class IgnoreYouAreDeadRS extends HRegionServer {<a name="line.74"></a>
+<span class="sourceLineNo">075</span><a name="line.75"></a>
+<span class="sourceLineNo">076</span>    public IgnoreYouAreDeadRS(Configuration conf) throws IOException, InterruptedException {<a name="line.76"></a>
+<span class="sourceLineNo">077</span>      super(conf);<a name="line.77"></a>
+<span class="sourceLineNo">078</span>    }<a name="line.78"></a>
+<span class="sourceLineNo">079</span><a name="line.79"></a>
+<span class="sourceLineNo">080</span>    @Override<a name="line.80"></a>
+<span class="sourceLineNo">081</span>    protected void tryRegionServerReport(long reportStartTime, long reportEndTime)<a name="line.81"></a>
+<span class="sourceLineNo">082</span>        throws IOException {<a name="line.82"></a>
+<span class="sourceLineNo">083</span>      try {<a name="line.83"></a>
+<span class="sourceLineNo">084</span>        super.tryRegionServerReport(reportStartTime, reportEndTime);<a name="line.84"></a>
+<span class="sourceLineNo">085</span>      } catch (YouAreDeadException e) {<a name="line.85"></a>
+<span class="sourceLineNo">086</span>        // ignore, do not abort<a name="line.86"></a>
+<span class="sourceLineNo">087</span>      }<a name="line.87"></a>
+<span class="sourceLineNo">088</span>    }<a name="line.88"></a>
+<span class="sourceLineNo">089</span>  }<a name="line.89"></a>
 <span class="sourceLineNo">090</span><a name="line.90"></a>
-<span class="sourceLineNo">091</span>  @Parameters(name = "{index}: wal={0}")<a name="line.91"></a>
-<span class="sourceLineNo">092</span>  public static List&lt;Object[]&gt; params() {<a name="line.92"></a>
-<span class="sourceLineNo">093</span>    return Arrays.asList(new Object[] { FSHLogProvider.class },<a name="line.93"></a>
-<span class="sourceLineNo">094</span>      new Object[] { AsyncFSWALProvider.class });<a name="line.94"></a>
-<span class="sourceLineNo">095</span>  }<a name="line.95"></a>
-<span class="sourceLineNo">096</span><a name="line.96"></a>
-<span class="sourceLineNo">097</span>  @Before<a name="line.97"></a>
-<span class="sourceLineNo">098</span>  public void setUp() throws Exception {<a name="line.98"></a>
-<span class="sourceLineNo">099</span>    UTIL.getConfiguration().setClass(WALFactory.WAL_PROVIDER, walProvider, WALProvider.class);<a name="line.99"></a>
-<span class="sourceLineNo">100</span>    UTIL.getConfiguration().setInt(HConstants.ZK_SESSION_TIMEOUT, 2000);<a name="line.100"></a>
-<span class="sourceLineNo">101</span>    UTIL.getConfiguration().setClass(HConstants.REGION_SERVER_IMPL, IgnoreYouAreDeadRS.class,<a name="line.101"></a>
-<span class="sourceLineNo">102</span>      HRegionServer.class);<a name="line.102"></a>
-<span class="sourceLineNo">103</span>    UTIL.startMiniCluster(2);<a name="line.103"></a>
-<span class="sourceLineNo">104</span>    Table table = UTIL.createTable(TABLE_NAME, CF);<a name="line.104"></a>
-<span class="sourceLineNo">105</span>    for (int i = 0; i &lt; 10; i++) {<a name="line.105"></a>
-<span class="sourceLineNo">106</span>      table.put(new Put(Bytes.toBytes(i)).addColumn(CF, CQ, Bytes.toBytes(i)));<a name="line.106"></a>
-<span class="sourceLineNo">107</span>    }<a name="line.107"></a>
-<span class="sourceLineNo">108</span>    UTIL.getAdmin().flush(TABLE_NAME);<a name="line.108"></a>
-<span class="sourceLineNo">109</span>    for (int i = 10; i &lt; 20; i++) {<a name="line.109"></a>
-<span class="sourceLineNo">110</span>      table.put(new Put(Bytes.toBytes(i)).addColumn(CF, CQ, Bytes.toBytes(i)));<a name="line.110"></a>
-<span class="sourceLineNo">111</span>    }<a name="line.111"></a>
-<span class="sourceLineNo">112</span>    UTIL.getAdmin().flush(TABLE_NAME);<a name="line.112"></a>
-<span class="sourceLineNo">113</span>  }<a name="line.113"></a>
-<span class="sourceLineNo">114</span><a name="line.114"></a>
-<span class="sourceLineNo">115</span>  @After<a name="line.115"></a>
-<span class="sourceLineNo">116</span>  public void tearDown() throws Exception {<a name="line.116"></a>
-<span class="sourceLineNo">117</span>    UTIL.shutdownMiniCluster();<a name="line.117"></a>
-<span class="sourceLineNo">118</span>  }<a name="line.118"></a>
-<span class="sourceLineNo">119</span><a name="line.119"></a>
-<span class="sourceLineNo">120</span>  @Test<a name="line.120"></a>
-<span class="sourceLineNo">121</span>  public void test() throws Exception {<a name="line.121"></a>
-<span class="sourceLineNo">122</span>    HRegionServer rsToSuspend = UTIL.getRSForFirstRegionInTable(TABLE_NAME);<a name="line.122"></a>
-<span class="sourceLineNo">123</span>    HRegion region = (HRegion) rsToSuspend.getRegions(TABLE_NAME).get(0);<a name="line.123"></a>
-<span class="sourceLineNo">124</span>    ZKWatcher watcher = UTIL.getZooKeeperWatcher();<a name="line.124"></a>
-<span class="sourceLineNo">125</span>    watcher.getRecoverableZooKeeper().delete(<a name="line.125"></a>
-<span class="sourceLineNo">126</span>      ZNodePaths.joinZNode(watcher.getZNodePaths().rsZNode, rsToSuspend.getServerName().toString()),<a name="line.126"></a>
-<span class="sourceLineNo">127</span>      -1);<a name="line.127"></a>
-<span class="sourceLineNo">128</span>    UTIL.waitFor(60000, 1000, new ExplainingPredicate&lt;Exception&gt;() {<a name="line.128"></a>
-<span class="sourceLineNo">129</span><a name="line.129"></a>
-<span class="sourceLineNo">130</span>      @Override<a name="line.130"></a>
-<span class="sourceLineNo">131</span>      public boolean evaluate() throws Exception {<a name="line.131"></a>
-<span class="sourceLineNo">132</span>        for (RegionServerThread thread : UTIL.getHBaseCluster().getRegionServerThreads()) {<a name="line.132"></a>
-<span class="sourceLineNo">133</span>          HRegionServer rs = thread.getRegionServer();<a name="line.133"></a>
-<span class="sourceLineNo">134</span>          if (rs != rsToSuspend) {<a name="line.134"></a>
-<span class="sourceLineNo">135</span>            return !rs.getRegions(TABLE_NAME).isEmpty();<a name="line.135"></a>
-<span class="sourceLineNo">136</span>          }<a name="line.136"></a>
-<span class="sourceLineNo">137</span>        }<a name="line.137"></a>
-<span class="sourceLineNo">138</span>        return false;<a name="line.138"></a>
-<span class="sourceLineNo">139</span>      }<a name="line.139"></a>
+<span class="sourceLineNo">091</span>  @Parameter<a name="line.91"></a>
+<span class="sourceLineNo">092</span>  public Class&lt;? extends WALProvider&gt; walProvider;<a name="line.92"></a>
+<span class="sourceLineNo">093</span><a name="line.93"></a>
+<span class="sourceLineNo">094</span>  @Parameters(name = "{index}: wal={0}")<a name="line.94"></a>
+<span class="sourceLineNo">095</span>  public static List&lt;Object[]&gt; params() {<a name="line.95"></a>
+<span class="sourceLineNo">096</span>    return Arrays.asList(new Object[] { FSHLogProvider.class },<a name="line.96"></a>
+<span class="sourceLineNo">097</span>        new Object[] { AsyncFSWALProvider.class });<a name="line.97"></a>
+<span class="sourceLineNo">098</span>  }<a name="line.98"></a>
+<span class="sourceLineNo">099</span><a name="line.99"></a>
+<span class="sourceLineNo">100</span>  @Before<a name="line.100"></a>
+<span class="sourceLineNo">101</span>  public void setUp() throws Exception {<a name="line.101"></a>
+<span class="sourceLineNo">102</span>    UTIL.getConfiguration().setClass(WALFactory.WAL_PROVIDER, walProvider, WALProvider.class);<a name="line.102"></a>
+<span class="sourceLineNo">103</span>    UTIL.getConfiguration().setInt(HConstants.ZK_SESSION_TIMEOUT, 2000);<a name="line.103"></a>
+<span class="sourceLineNo">104</span>    UTIL.getConfiguration().setClass(HConstants.REGION_SERVER_IMPL, IgnoreYouAreDeadRS.class,<a name="line.104"></a>
+<span class="sourceLineNo">105</span>      HRegionServer.class);<a name="line.105"></a>
+<span class="sourceLineNo">106</span>    UTIL.startMiniCluster(2);<a name="line.106"></a>
+<span class="sourceLineNo">107</span>    Table table = UTIL.createTable(TABLE_NAME, CF);<a name="line.107"></a>
+<span class="sourceLineNo">108</span>    for (int i = 0; i &lt; 10; i++) {<a name="line.108"></a>
+<span class="sourceLineNo">109</span>      table.put(new Put(Bytes.toBytes(i)).addColumn(CF, CQ, Bytes.toBytes(i)));<a name="line.109"></a>
+<span class="sourceLineNo">110</span>    }<a name="line.110"></a>
+<span class="sourceLineNo">111</span>    UTIL.getAdmin().flush(TABLE_NAME);<a name="line.111"></a>
+<span class="sourceLineNo">112</span>    for (int i = 10; i &lt; 20; i++) {<a name="line.112"></a>
+<span class="sourceLineNo">113</span>      table.put(new Put(Bytes.toBytes(i)).addColumn(CF, CQ, Bytes.toBytes(i)));<a name="line.113"></a>
+<span class="sourceLineNo">114</span>    }<a name="line.114"></a>
+<span class="sourceLineNo">115</span>    UTIL.getAdmin().flush(TABLE_NAME);<a name="line.115"></a>
+<span class="sourceLineNo">116</span>  }<a name="line.116"></a>
+<span class="sourceLineNo">117</span><a name="line.117"></a>
+<span class="sourceLineNo">118</span>  @After<a name="line.118"></a>
+<span class="sourceLineNo">119</span>  public void tearDown() throws Exception {<a name="line.119"></a>
+<span class="sourceLineNo">120</span>    UTIL.shutdownMiniCluster();<a name="line.120"></a>
+<span class="sourceLineNo">121</span>  }<a name="line.121"></a>
+<span class="sourceLineNo">122</span><a name="line.122"></a>
+<span class="sourceLineNo">123</span>  @Test<a name="line.123"></a>
+<span class="sourceLineNo">124</span>  public void test() throws Exception {<a name="line.124"></a>
+<span class="sourceLineNo">125</span>    HRegionServer regionSvr = UTIL.getRSForFirstRegionInTable(TABLE_NAME);<a name="line.125"></a>
+<span class="sourceLineNo">126</span>    HRegion region = regionSvr.getRegions(TABLE_NAME).get(0);<a name="line.126"></a>
+<span class="sourceLineNo">127</span>    String regName = region.getRegionInfo().getEncodedName();<a name="line.127"></a>
+<span class="sourceLineNo">128</span>    List&lt;HRegion&gt; metaRegs = regionSvr.getRegions(TableName.META_TABLE_NAME);<a name="line.128"></a>
+<span class="sourceLineNo">129</span>    if (metaRegs != null &amp;&amp; !metaRegs.isEmpty()) {<a name="line.129"></a>
+<span class="sourceLineNo">130</span>      LOG.info("meta is on the same server: " + regionSvr);<a name="line.130"></a>
+<span class="sourceLineNo">131</span>      // when region is on same server as hbase:meta, reassigning meta would abort the server<a name="line.131"></a>
+<span class="sourceLineNo">132</span>      // since WAL is broken.<a name="line.132"></a>
+<span class="sourceLineNo">133</span>      // so the region is moved to a different server<a name="line.133"></a>
+<span class="sourceLineNo">134</span>      HRegionServer otherRs = UTIL.getOtherRegionServer(regionSvr);<a name="line.134"></a>
+<span class="sourceLineNo">135</span>      UTIL.moveRegionAndWait(region.getRegionInfo(), otherRs.getServerName());<a name="line.135"></a>
+<span class="sourceLineNo">136</span>      LOG.info("Moved region: " + regName + " to " + otherRs.getServerName());<a name="line.136"></a>
+<span class="sourceLineNo">137</span>    }<a name="line.137"></a>
+<span class="sourceLineNo">138</span>    HRegionServer rsToSuspend = UTIL.getRSForFirstRegionInTable(TABLE_NAME);<a name="line.138"></a>
+<span class="sourceLineNo">139</span>    region = rsToSuspend.getRegions(TABLE_NAME).get(0);<a name="line.139"></a>
 <span class="sourceLineNo">140</span><a name="line.140"></a>
-<span class="sourceLineNo">141</span>      @Override<a name="line.141"></a>
-<span class="sourceLineNo">142</span>      public String explainFailure() throws Exception {<a name="line.142"></a>
-<span class="sourceLineNo">143</span>        return "The region for " + TABLE_NAME + " is still on " + rsToSuspend.getServerName();<a name="line.143"></a>
-<span class="sourceLineNo">144</span>      }<a name="line.144"></a>
-<span class="sourceLineNo">145</span>    });<a name="line.145"></a>
-<span class="sourceLineNo">146</span>    try {<a name="line.146"></a>
-<span class="sourceLineNo">147</span>      region.compact(true);<a name="line.147"></a>
-<span class="sourceLineNo">148</span>      fail("Should fail as our wal file has already been closed, " +<a name="line.148"></a>
-<span class="sourceLineNo">149</span>          "and walDir has also been renamed");<a name="line.149"></a>
-<span class="sourceLineNo">150</span>    } catch (Exception e) {<a name="line.150"></a>
-<span class="sourceLineNo">151</span>      // expected<a name="line.151"></a>
-<span class="sourceLineNo">152</span>    }<a name="line.152"></a>
-<span class="sourceLineNo">153</span>    Table table = UTIL.getConnection().getTable(TABLE_NAME);<a name="line.153"></a>
-<span class="sourceLineNo">154</span>    // should not hit FNFE<a name="line.154"></a>
-<span class="sourceLineNo">155</span>    for (int i = 0; i &lt; 20; i++) {<a name="line.155"></a>
-<span class="sourceLineNo">156</span>      assertEquals(i, Bytes.toInt(table.get(new Get(Bytes.toBytes(i))).getValue(CF, CQ)));<a name="line.156"></a>
-<span class="sourceLineNo">157</span>    }<a name="line.157"></a>
-<span class="sourceLineNo">158</span>  }<a name="line.158"></a>
-<span class="sourceLineNo">159</span>}<a name="line.159"></a>
+<span class="sourceLineNo">141</span>    ZKWatcher watcher = UTIL.getZooKeeperWatcher();<a name="line.141"></a>
+<span class="sourceLineNo">142</span>    watcher.getRecoverableZooKeeper().delete(<a name="line.142"></a>
+<span class="sourceLineNo">143</span>      ZNodePaths.joinZNode(watcher.getZNodePaths().rsZNode, rsToSuspend.getServerName().toString()),<a name="line.143"></a>
+<span class="sourceLineNo">144</span>      -1);<a name="line.144"></a>
+<span class="sourceLineNo">145</span>    LOG.info("suspending " + rsToSuspend);<a name="line.145"></a>
+<span class="sourceLineNo">146</span>    UTIL.waitFor(60000, 1000, new ExplainingPredicate&lt;Exception&gt;() {<a name="line.146"></a>
+<span class="sourceLineNo">147</span><a name="line.147"></a>
+<span class="sourceLineNo">148</span>      @Override<a name="line.148"></a>
+<span class="sourceLineNo">149</span>      public boolean evaluate() throws Exception {<a name="line.149"></a>
+<span class="sourceLineNo">150</span>        for (RegionServerThread thread : UTIL.getHBaseCluster().getRegionServerThreads()) {<a name="line.150"></a>
+<span class="sourceLineNo">151</span>          HRegionServer rs = thread.getRegionServer();<a name="line.151"></a>
+<span class="sourceLineNo">152</span>          if (rs != rsToSuspend) {<a name="line.152"></a>
+<span class="sourceLineNo">153</span>            return !rs.getRegions(TABLE_NAME).isEmpty();<a name="line.153"></a>
+<span class="sourceLineNo">154</span>          }<a name="line.154"></a>
+<span class="sourceLineNo">155</span>        }<a name="line.155"></a>
+<span class="sourceLineNo">156</span>        return false;<a name="line.156"></a>
+<span class="sourceLineNo">157</span>      }<a name="line.157"></a>
+<span class="sourceLineNo">158</span><a name="line.158"></a>
+<span class="sourceLineNo">159</span>      @Override<a name="line.159"></a>
+<span class="sourceLineNo">160</span>      public String explainFailure() throws Exception {<a name="line.160"></a>
+<span class="sourceLineNo">161</span>        return "The region for " + TABLE_NAME + " is still on " + rsToSuspend.getServerName();<a name="line.161"></a>
+<span class="sourceLineNo">162</span>      }<a name="line.162"></a>
+<span class="sourceLineNo">163</span>    });<a name="line.163"></a>
+<span class="sourceLineNo">164</span>    try {<a name="line.164"></a>
+<span class="sourceLineNo">165</span>      region.compact(true);<a name="line.165"></a>
+<span class="sourceLineNo">166</span>      fail("Should fail as our wal file has already been closed, " +<a name="line.166"></a>
+<span class="sourceLineNo">167</span>          "and walDir has also been renamed");<a name="line.167"></a>
+<span class="sourceLineNo">168</span>    } catch (Exception e) {<a name="line.168"></a>
+<span class="sourceLineNo">169</span>      LOG.debug("expected exception: ", e);<a name="line.169"></a>
+<span class="sourceLineNo">170</span>    }<a name="line.170"></a>
+<span class="sourceLineNo">171</span>    Table table = UTIL.getConnection().getTable(TABLE_NAME);<a name="line.171"></a>
+<span class="sourceLineNo">172</span>    // should not hit FNFE<a name="line.172"></a>
+<span class="sourceLineNo">173</span>    for (int i = 0; i &lt; 20; i++) {<a name="line.173"></a>
+<span class="sourceLineNo">174</span>      assertEquals(i, Bytes.toInt(table.get(new Get(Bytes.toBytes(i))).getValue(CF, CQ)));<a name="line.174"></a>
+<span class="sourceLineNo">175</span>    }<a name="line.175"></a>
+<span class="sourceLineNo">176</span>  }<a name="line.176"></a>
+<span class="sourceLineNo">177</span>}<a name="line.177"></a>
 
 
 


[09/14] hbase-site git commit: Published site at .

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/index-all.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/index-all.html b/testdevapidocs/index-all.html
index e1028db..e701665 100644
--- a/testdevapidocs/index-all.html
+++ b/testdevapidocs/index-all.html
@@ -14238,6 +14238,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/filter/TestFilterList.html#getOrderingFilter--">getOrderingFilter()</a></span> - Method in class org.apache.hadoop.hbase.filter.<a href="org/apache/hadoop/hbase/filter/TestFilterList.html" title="class in org.apache.hadoop.hbase.filter">TestFilterList</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/HBaseTestingUtility.html#getOtherRegionServer-org.apache.hadoop.hbase.regionserver.HRegionServer-">getOtherRegionServer(HRegionServer)</a></span> - Method in class org.apache.hadoop.hbase.<a href="org/apache/hadoop/hbase/HBaseTestingUtility.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/regionserver/TestSplitTransactionOnCluster.html#getOtherRegionServer-org.apache.hadoop.hbase.MiniHBaseCluster-org.apache.hadoop.hbase.regionserver.HRegionServer-">getOtherRegionServer(MiniHBaseCluster, HRegionServer)</a></span> - Method in class org.apache.hadoop.hbase.regionserver.<a href="org/apache/hadoop/hbase/regionserver/TestSplitTransactionOnCluster.html" title="class in org.apache.hadoop.hbase.regionserver">TestSplitTransactionOnCluster</a></dt>
 <dd>
 <div class="block">Find regionserver other than the one passed.</div>
@@ -20225,6 +20227,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/regionserver/TestCompactionFileNotFound.html#LOG">LOG</a></span> - Static variable in class org.apache.hadoop.hbase.regionserver.<a href="org/apache/hadoop/hbase/regionserver/TestCompactionFileNotFound.html" title="class in org.apache.hadoop.hbase.regionserver">TestCompactionFileNotFound</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#LOG">LOG</a></span> - Static variable in class org.apache.hadoop.hbase.regionserver.<a href="org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html" title="class in org.apache.hadoop.hbase.regionserver">TestCompactionInDeadRegionServer</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/regionserver/TestCompactionPolicy.html#LOG">LOG</a></span> - Static variable in class org.apache.hadoop.hbase.regionserver.<a href="org/apache/hadoop/hbase/regionserver/TestCompactionPolicy.html" title="class in org.apache.hadoop.hbase.regionserver">TestCompactionPolicy</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/regionserver/TestCompactionState.html#LOG">LOG</a></span> - Static variable in class org.apache.hadoop.hbase.regionserver.<a href="org/apache/hadoop/hbase/regionserver/TestCompactionState.html" title="class in org.apache.hadoop.hbase.regionserver">TestCompactionState</a></dt>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.AvailablePortChecker.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.AvailablePortChecker.html b/testdevapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.AvailablePortChecker.html
index a36e149..b5a3c98 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.AvailablePortChecker.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.AvailablePortChecker.html
@@ -105,7 +105,7 @@ var activeTableTab = "activeTableTab";
 </dl>
 <hr>
 <br>
-<pre>static interface <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3756">HBaseTestingUtility.PortAllocator.AvailablePortChecker</a></pre>
+<pre>static interface <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3771">HBaseTestingUtility.PortAllocator.AvailablePortChecker</a></pre>
 </li>
 </ul>
 </div>
@@ -149,7 +149,7 @@ var activeTableTab = "activeTableTab";
 <ul class="blockListLast">
 <li class="blockList">
 <h4>available</h4>
-<pre>boolean&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.AvailablePortChecker.html#line.3757">available</a>(int&nbsp;port)</pre>
+<pre>boolean&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.AvailablePortChecker.html#line.3772">available</a>(int&nbsp;port)</pre>
 </li>
 </ul>
 </li>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html b/testdevapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html
index 26eefa0..e7d0389 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html
@@ -113,7 +113,7 @@ var activeTableTab = "activeTableTab";
 </dl>
 <hr>
 <br>
-<pre>static class <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.3695">HBaseTestingUtility.PortAllocator</a>
+<pre>static class <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.3710">HBaseTestingUtility.PortAllocator</a>
 extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true" title="class or interface in java.lang">Object</a></pre>
 </li>
 </ul>
@@ -250,7 +250,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>MIN_RANDOM_PORT</h4>
-<pre>private static final&nbsp;int <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3696">MIN_RANDOM_PORT</a></pre>
+<pre>private static final&nbsp;int <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3711">MIN_RANDOM_PORT</a></pre>
 <dl>
 <dt><span class="seeLabel">See Also:</span></dt>
 <dd><a href="../../../../constant-values.html#org.apache.hadoop.hbase.HBaseTestingUtility.PortAllocator.MIN_RANDOM_PORT">Constant Field Values</a></dd>
@@ -263,7 +263,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>MAX_RANDOM_PORT</h4>
-<pre>private static final&nbsp;int <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3697">MAX_RANDOM_PORT</a></pre>
+<pre>private static final&nbsp;int <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3712">MAX_RANDOM_PORT</a></pre>
 <dl>
 <dt><span class="seeLabel">See Also:</span></dt>
 <dd><a href="../../../../constant-values.html#org.apache.hadoop.hbase.HBaseTestingUtility.PortAllocator.MAX_RANDOM_PORT">Constant Field Values</a></dd>
@@ -276,7 +276,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>takenRandomPorts</h4>
-<pre>private final&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/Set.html?is-external=true" title="class or interface in java.util">Set</a>&lt;<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Integer.html?is-external=true" title="class or interface in java.lang">Integer</a>&gt; <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3700">takenRandomPorts</a></pre>
+<pre>private final&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/Set.html?is-external=true" title="class or interface in java.util">Set</a>&lt;<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Integer.html?is-external=true" title="class or interface in java.lang">Integer</a>&gt; <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3715">takenRandomPorts</a></pre>
 <div class="block">A set of ports that have been claimed using <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#randomFreePort--"><code>randomFreePort()</code></a>.</div>
 </li>
 </ul>
@@ -286,7 +286,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>random</h4>
-<pre>private final&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/Random.html?is-external=true" title="class or interface in java.util">Random</a> <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3702">random</a></pre>
+<pre>private final&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/Random.html?is-external=true" title="class or interface in java.util">Random</a> <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3717">random</a></pre>
 </li>
 </ul>
 <a name="portChecker">
@@ -295,7 +295,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>portChecker</h4>
-<pre>private final&nbsp;<a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.AvailablePortChecker.html" title="interface in org.apache.hadoop.hbase">HBaseTestingUtility.PortAllocator.AvailablePortChecker</a> <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3703">portChecker</a></pre>
+<pre>private final&nbsp;<a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.AvailablePortChecker.html" title="interface in org.apache.hadoop.hbase">HBaseTestingUtility.PortAllocator.AvailablePortChecker</a> <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3718">portChecker</a></pre>
 </li>
 </ul>
 </li>
@@ -312,7 +312,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>PortAllocator</h4>
-<pre>public&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3705">PortAllocator</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/util/Random.html?is-external=true" title="class or interface in java.util">Random</a>&nbsp;random)</pre>
+<pre>public&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3720">PortAllocator</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/util/Random.html?is-external=true" title="class or interface in java.util">Random</a>&nbsp;random)</pre>
 </li>
 </ul>
 <a name="PortAllocator-java.util.Random-org.apache.hadoop.hbase.HBaseTestingUtility.PortAllocator.AvailablePortChecker-">
@@ -321,7 +321,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>PortAllocator</h4>
-<pre>public&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3721">PortAllocator</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/util/Random.html?is-external=true" title="class or interface in java.util">Random</a>&nbsp;random,
+<pre>public&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3736">PortAllocator</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/util/Random.html?is-external=true" title="class or interface in java.util">Random</a>&nbsp;random,
                      <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.AvailablePortChecker.html" title="interface in org.apache.hadoop.hbase">HBaseTestingUtility.PortAllocator.AvailablePortChecker</a>&nbsp;portChecker)</pre>
 </li>
 </ul>
@@ -339,7 +339,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>randomFreePort</h4>
-<pre>public&nbsp;int&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3730">randomFreePort</a>()</pre>
+<pre>public&nbsp;int&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3745">randomFreePort</a>()</pre>
 <div class="block">Returns a random free port and marks that port as taken. Not thread-safe. Expected to be
  called from single-threaded test setup code/</div>
 </li>
@@ -350,7 +350,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>randomPort</h4>
-<pre>private&nbsp;int&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3751">randomPort</a>()</pre>
+<pre>private&nbsp;int&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html#line.3766">randomPort</a>()</pre>
 <div class="block">Returns a random port. These ports cannot be registered with IANA and are
  intended for dynamic allocation (see http://bit.ly/dynports).</div>
 </li>


[03/14] hbase-site git commit: Published site at .

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.SeenRowTracker.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.SeenRowTracker.html b/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.SeenRowTracker.html
index 0cec549..06b92ba 100644
--- a/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.SeenRowTracker.html
+++ b/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.SeenRowTracker.html
@@ -2518,1796 +2518,1811 @@
 <span class="sourceLineNo">2510</span>    return rows;<a name="line.2510"></a>
 <span class="sourceLineNo">2511</span>  }<a name="line.2511"></a>
 <span class="sourceLineNo">2512</span><a name="line.2512"></a>
-<span class="sourceLineNo">2513</span>  /**<a name="line.2513"></a>
-<span class="sourceLineNo">2514</span>   * Tool to get the reference to the region server object that holds the<a name="line.2514"></a>
-<span class="sourceLineNo">2515</span>   * region of the specified user table.<a name="line.2515"></a>
-<span class="sourceLineNo">2516</span>   * It first searches for the meta rows that contain the region of the<a name="line.2516"></a>
-<span class="sourceLineNo">2517</span>   * specified table, then gets the index of that RS, and finally retrieves<a name="line.2517"></a>
-<span class="sourceLineNo">2518</span>   * the RS's reference.<a name="line.2518"></a>
-<span class="sourceLineNo">2519</span>   * @param tableName user table to lookup in hbase:meta<a name="line.2519"></a>
-<span class="sourceLineNo">2520</span>   * @return region server that holds it, null if the row doesn't exist<a name="line.2520"></a>
-<span class="sourceLineNo">2521</span>   * @throws IOException<a name="line.2521"></a>
-<span class="sourceLineNo">2522</span>   * @throws InterruptedException<a name="line.2522"></a>
-<span class="sourceLineNo">2523</span>   */<a name="line.2523"></a>
-<span class="sourceLineNo">2524</span>  public HRegionServer getRSForFirstRegionInTable(TableName tableName)<a name="line.2524"></a>
-<span class="sourceLineNo">2525</span>      throws IOException, InterruptedException {<a name="line.2525"></a>
-<span class="sourceLineNo">2526</span>    List&lt;byte[]&gt; metaRows = getMetaTableRows(tableName);<a name="line.2526"></a>
-<span class="sourceLineNo">2527</span>    if (metaRows == null || metaRows.isEmpty()) {<a name="line.2527"></a>
-<span class="sourceLineNo">2528</span>      return null;<a name="line.2528"></a>
-<span class="sourceLineNo">2529</span>    }<a name="line.2529"></a>
-<span class="sourceLineNo">2530</span>    LOG.debug("Found " + metaRows.size() + " rows for table " +<a name="line.2530"></a>
-<span class="sourceLineNo">2531</span>      tableName);<a name="line.2531"></a>
-<span class="sourceLineNo">2532</span>    byte [] firstrow = metaRows.get(0);<a name="line.2532"></a>
-<span class="sourceLineNo">2533</span>    LOG.debug("FirstRow=" + Bytes.toString(firstrow));<a name="line.2533"></a>
-<span class="sourceLineNo">2534</span>    long pause = getConfiguration().getLong(HConstants.HBASE_CLIENT_PAUSE,<a name="line.2534"></a>
-<span class="sourceLineNo">2535</span>      HConstants.DEFAULT_HBASE_CLIENT_PAUSE);<a name="line.2535"></a>
-<span class="sourceLineNo">2536</span>    int numRetries = getConfiguration().getInt(HConstants.HBASE_CLIENT_RETRIES_NUMBER,<a name="line.2536"></a>
-<span class="sourceLineNo">2537</span>      HConstants.DEFAULT_HBASE_CLIENT_RETRIES_NUMBER);<a name="line.2537"></a>
-<span class="sourceLineNo">2538</span>    RetryCounter retrier = new RetryCounter(numRetries+1, (int)pause, TimeUnit.MICROSECONDS);<a name="line.2538"></a>
-<span class="sourceLineNo">2539</span>    while(retrier.shouldRetry()) {<a name="line.2539"></a>
-<span class="sourceLineNo">2540</span>      int index = getMiniHBaseCluster().getServerWith(firstrow);<a name="line.2540"></a>
-<span class="sourceLineNo">2541</span>      if (index != -1) {<a name="line.2541"></a>
-<span class="sourceLineNo">2542</span>        return getMiniHBaseCluster().getRegionServerThreads().get(index).getRegionServer();<a name="line.2542"></a>
-<span class="sourceLineNo">2543</span>      }<a name="line.2543"></a>
-<span class="sourceLineNo">2544</span>      // Came back -1.  Region may not be online yet.  Sleep a while.<a name="line.2544"></a>
-<span class="sourceLineNo">2545</span>      retrier.sleepUntilNextRetry();<a name="line.2545"></a>
-<span class="sourceLineNo">2546</span>    }<a name="line.2546"></a>
-<span class="sourceLineNo">2547</span>    return null;<a name="line.2547"></a>
-<span class="sourceLineNo">2548</span>  }<a name="line.2548"></a>
-<span class="sourceLineNo">2549</span><a name="line.2549"></a>
-<span class="sourceLineNo">2550</span>  /**<a name="line.2550"></a>
-<span class="sourceLineNo">2551</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt; with a default number of<a name="line.2551"></a>
-<span class="sourceLineNo">2552</span>   * &lt;code&gt;TaskTracker&lt;/code&gt;'s.<a name="line.2552"></a>
-<span class="sourceLineNo">2553</span>   *<a name="line.2553"></a>
-<span class="sourceLineNo">2554</span>   * @throws IOException When starting the cluster fails.<a name="line.2554"></a>
-<span class="sourceLineNo">2555</span>   */<a name="line.2555"></a>
-<span class="sourceLineNo">2556</span>  public MiniMRCluster startMiniMapReduceCluster() throws IOException {<a name="line.2556"></a>
-<span class="sourceLineNo">2557</span>    // Set a very high max-disk-utilization percentage to avoid the NodeManagers from failing.<a name="line.2557"></a>
-<span class="sourceLineNo">2558</span>    conf.setIfUnset(<a name="line.2558"></a>
-<span class="sourceLineNo">2559</span>        "yarn.nodemanager.disk-health-checker.max-disk-utilization-per-disk-percentage",<a name="line.2559"></a>
-<span class="sourceLineNo">2560</span>        "99.0");<a name="line.2560"></a>
-<span class="sourceLineNo">2561</span>    startMiniMapReduceCluster(2);<a name="line.2561"></a>
-<span class="sourceLineNo">2562</span>    return mrCluster;<a name="line.2562"></a>
+<span class="sourceLineNo">2513</span>  /*<a name="line.2513"></a>
+<span class="sourceLineNo">2514</span>   * Find any other region server which is different from the one identified by parameter<a name="line.2514"></a>
+<span class="sourceLineNo">2515</span>   * @param rs<a name="line.2515"></a>
+<span class="sourceLineNo">2516</span>   * @return another region server<a name="line.2516"></a>
+<span class="sourceLineNo">2517</span>   */<a name="line.2517"></a>
+<span class="sourceLineNo">2518</span>  public HRegionServer getOtherRegionServer(HRegionServer rs) {<a name="line.2518"></a>
+<span class="sourceLineNo">2519</span>    for (JVMClusterUtil.RegionServerThread rst :<a name="line.2519"></a>
+<span class="sourceLineNo">2520</span>      getMiniHBaseCluster().getRegionServerThreads()) {<a name="line.2520"></a>
+<span class="sourceLineNo">2521</span>      if (!(rst.getRegionServer() == rs)) {<a name="line.2521"></a>
+<span class="sourceLineNo">2522</span>        return rst.getRegionServer();<a name="line.2522"></a>
+<span class="sourceLineNo">2523</span>      }<a name="line.2523"></a>
+<span class="sourceLineNo">2524</span>    }<a name="line.2524"></a>
+<span class="sourceLineNo">2525</span>    return null;<a name="line.2525"></a>
+<span class="sourceLineNo">2526</span>  }<a name="line.2526"></a>
+<span class="sourceLineNo">2527</span><a name="line.2527"></a>
+<span class="sourceLineNo">2528</span>  /**<a name="line.2528"></a>
+<span class="sourceLineNo">2529</span>   * Tool to get the reference to the region server object that holds the<a name="line.2529"></a>
+<span class="sourceLineNo">2530</span>   * region of the specified user table.<a name="line.2530"></a>
+<span class="sourceLineNo">2531</span>   * It first searches for the meta rows that contain the region of the<a name="line.2531"></a>
+<span class="sourceLineNo">2532</span>   * specified table, then gets the index of that RS, and finally retrieves<a name="line.2532"></a>
+<span class="sourceLineNo">2533</span>   * the RS's reference.<a name="line.2533"></a>
+<span class="sourceLineNo">2534</span>   * @param tableName user table to lookup in hbase:meta<a name="line.2534"></a>
+<span class="sourceLineNo">2535</span>   * @return region server that holds it, null if the row doesn't exist<a name="line.2535"></a>
+<span class="sourceLineNo">2536</span>   * @throws IOException<a name="line.2536"></a>
+<span class="sourceLineNo">2537</span>   * @throws InterruptedException<a name="line.2537"></a>
+<span class="sourceLineNo">2538</span>   */<a name="line.2538"></a>
+<span class="sourceLineNo">2539</span>  public HRegionServer getRSForFirstRegionInTable(TableName tableName)<a name="line.2539"></a>
+<span class="sourceLineNo">2540</span>      throws IOException, InterruptedException {<a name="line.2540"></a>
+<span class="sourceLineNo">2541</span>    List&lt;byte[]&gt; metaRows = getMetaTableRows(tableName);<a name="line.2541"></a>
+<span class="sourceLineNo">2542</span>    if (metaRows == null || metaRows.isEmpty()) {<a name="line.2542"></a>
+<span class="sourceLineNo">2543</span>      return null;<a name="line.2543"></a>
+<span class="sourceLineNo">2544</span>    }<a name="line.2544"></a>
+<span class="sourceLineNo">2545</span>    LOG.debug("Found " + metaRows.size() + " rows for table " +<a name="line.2545"></a>
+<span class="sourceLineNo">2546</span>      tableName);<a name="line.2546"></a>
+<span class="sourceLineNo">2547</span>    byte [] firstrow = metaRows.get(0);<a name="line.2547"></a>
+<span class="sourceLineNo">2548</span>    LOG.debug("FirstRow=" + Bytes.toString(firstrow));<a name="line.2548"></a>
+<span class="sourceLineNo">2549</span>    long pause = getConfiguration().getLong(HConstants.HBASE_CLIENT_PAUSE,<a name="line.2549"></a>
+<span class="sourceLineNo">2550</span>      HConstants.DEFAULT_HBASE_CLIENT_PAUSE);<a name="line.2550"></a>
+<span class="sourceLineNo">2551</span>    int numRetries = getConfiguration().getInt(HConstants.HBASE_CLIENT_RETRIES_NUMBER,<a name="line.2551"></a>
+<span class="sourceLineNo">2552</span>      HConstants.DEFAULT_HBASE_CLIENT_RETRIES_NUMBER);<a name="line.2552"></a>
+<span class="sourceLineNo">2553</span>    RetryCounter retrier = new RetryCounter(numRetries+1, (int)pause, TimeUnit.MICROSECONDS);<a name="line.2553"></a>
+<span class="sourceLineNo">2554</span>    while(retrier.shouldRetry()) {<a name="line.2554"></a>
+<span class="sourceLineNo">2555</span>      int index = getMiniHBaseCluster().getServerWith(firstrow);<a name="line.2555"></a>
+<span class="sourceLineNo">2556</span>      if (index != -1) {<a name="line.2556"></a>
+<span class="sourceLineNo">2557</span>        return getMiniHBaseCluster().getRegionServerThreads().get(index).getRegionServer();<a name="line.2557"></a>
+<span class="sourceLineNo">2558</span>      }<a name="line.2558"></a>
+<span class="sourceLineNo">2559</span>      // Came back -1.  Region may not be online yet.  Sleep a while.<a name="line.2559"></a>
+<span class="sourceLineNo">2560</span>      retrier.sleepUntilNextRetry();<a name="line.2560"></a>
+<span class="sourceLineNo">2561</span>    }<a name="line.2561"></a>
+<span class="sourceLineNo">2562</span>    return null;<a name="line.2562"></a>
 <span class="sourceLineNo">2563</span>  }<a name="line.2563"></a>
 <span class="sourceLineNo">2564</span><a name="line.2564"></a>
 <span class="sourceLineNo">2565</span>  /**<a name="line.2565"></a>
-<span class="sourceLineNo">2566</span>   * Tasktracker has a bug where changing the hadoop.log.dir system property<a name="line.2566"></a>
-<span class="sourceLineNo">2567</span>   * will not change its internal static LOG_DIR variable.<a name="line.2567"></a>
-<span class="sourceLineNo">2568</span>   */<a name="line.2568"></a>
-<span class="sourceLineNo">2569</span>  private void forceChangeTaskLogDir() {<a name="line.2569"></a>
-<span class="sourceLineNo">2570</span>    Field logDirField;<a name="line.2570"></a>
-<span class="sourceLineNo">2571</span>    try {<a name="line.2571"></a>
-<span class="sourceLineNo">2572</span>      logDirField = TaskLog.class.getDeclaredField("LOG_DIR");<a name="line.2572"></a>
-<span class="sourceLineNo">2573</span>      logDirField.setAccessible(true);<a name="line.2573"></a>
-<span class="sourceLineNo">2574</span><a name="line.2574"></a>
-<span class="sourceLineNo">2575</span>      Field modifiersField = Field.class.getDeclaredField("modifiers");<a name="line.2575"></a>
-<span class="sourceLineNo">2576</span>      modifiersField.setAccessible(true);<a name="line.2576"></a>
-<span class="sourceLineNo">2577</span>      modifiersField.setInt(logDirField, logDirField.getModifiers() &amp; ~Modifier.FINAL);<a name="line.2577"></a>
-<span class="sourceLineNo">2578</span><a name="line.2578"></a>
-<span class="sourceLineNo">2579</span>      logDirField.set(null, new File(hadoopLogDir, "userlogs"));<a name="line.2579"></a>
-<span class="sourceLineNo">2580</span>    } catch (SecurityException e) {<a name="line.2580"></a>
-<span class="sourceLineNo">2581</span>      throw new RuntimeException(e);<a name="line.2581"></a>
-<span class="sourceLineNo">2582</span>    } catch (NoSuchFieldException e) {<a name="line.2582"></a>
-<span class="sourceLineNo">2583</span>      // TODO Auto-generated catch block<a name="line.2583"></a>
-<span class="sourceLineNo">2584</span>      throw new RuntimeException(e);<a name="line.2584"></a>
-<span class="sourceLineNo">2585</span>    } catch (IllegalArgumentException e) {<a name="line.2585"></a>
-<span class="sourceLineNo">2586</span>      throw new RuntimeException(e);<a name="line.2586"></a>
-<span class="sourceLineNo">2587</span>    } catch (IllegalAccessException e) {<a name="line.2587"></a>
-<span class="sourceLineNo">2588</span>      throw new RuntimeException(e);<a name="line.2588"></a>
-<span class="sourceLineNo">2589</span>    }<a name="line.2589"></a>
-<span class="sourceLineNo">2590</span>  }<a name="line.2590"></a>
-<span class="sourceLineNo">2591</span><a name="line.2591"></a>
-<span class="sourceLineNo">2592</span>  /**<a name="line.2592"></a>
-<span class="sourceLineNo">2593</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt;. Call {@link #setFileSystemURI(String)} to use a different<a name="line.2593"></a>
-<span class="sourceLineNo">2594</span>   * filesystem.<a name="line.2594"></a>
-<span class="sourceLineNo">2595</span>   * @param servers  The number of &lt;code&gt;TaskTracker&lt;/code&gt;'s to start.<a name="line.2595"></a>
-<span class="sourceLineNo">2596</span>   * @throws IOException When starting the cluster fails.<a name="line.2596"></a>
-<span class="sourceLineNo">2597</span>   */<a name="line.2597"></a>
-<span class="sourceLineNo">2598</span>  private void startMiniMapReduceCluster(final int servers) throws IOException {<a name="line.2598"></a>
-<span class="sourceLineNo">2599</span>    if (mrCluster != null) {<a name="line.2599"></a>
-<span class="sourceLineNo">2600</span>      throw new IllegalStateException("MiniMRCluster is already running");<a name="line.2600"></a>
-<span class="sourceLineNo">2601</span>    }<a name="line.2601"></a>
-<span class="sourceLineNo">2602</span>    LOG.info("Starting mini mapreduce cluster...");<a name="line.2602"></a>
-<span class="sourceLineNo">2603</span>    setupClusterTestDir();<a name="line.2603"></a>
-<span class="sourceLineNo">2604</span>    createDirsAndSetProperties();<a name="line.2604"></a>
-<span class="sourceLineNo">2605</span><a name="line.2605"></a>
-<span class="sourceLineNo">2606</span>    forceChangeTaskLogDir();<a name="line.2606"></a>
-<span class="sourceLineNo">2607</span><a name="line.2607"></a>
-<span class="sourceLineNo">2608</span>    //// hadoop2 specific settings<a name="line.2608"></a>
-<span class="sourceLineNo">2609</span>    // Tests were failing because this process used 6GB of virtual memory and was getting killed.<a name="line.2609"></a>
-<span class="sourceLineNo">2610</span>    // we up the VM usable so that processes don't get killed.<a name="line.2610"></a>
-<span class="sourceLineNo">2611</span>    conf.setFloat("yarn.nodemanager.vmem-pmem-ratio", 8.0f);<a name="line.2611"></a>
-<span class="sourceLineNo">2612</span><a name="line.2612"></a>
-<span class="sourceLineNo">2613</span>    // Tests were failing due to MAPREDUCE-4880 / MAPREDUCE-4607 against hadoop 2.0.2-alpha and<a name="line.2613"></a>
-<span class="sourceLineNo">2614</span>    // this avoids the problem by disabling speculative task execution in tests.<a name="line.2614"></a>
-<span class="sourceLineNo">2615</span>    conf.setBoolean("mapreduce.map.speculative", false);<a name="line.2615"></a>
-<span class="sourceLineNo">2616</span>    conf.setBoolean("mapreduce.reduce.speculative", false);<a name="line.2616"></a>
-<span class="sourceLineNo">2617</span>    ////<a name="line.2617"></a>
-<span class="sourceLineNo">2618</span><a name="line.2618"></a>
-<span class="sourceLineNo">2619</span>    // Allow the user to override FS URI for this map-reduce cluster to use.<a name="line.2619"></a>
-<span class="sourceLineNo">2620</span>    mrCluster = new MiniMRCluster(servers,<a name="line.2620"></a>
-<span class="sourceLineNo">2621</span>      FS_URI != null ? FS_URI : FileSystem.get(conf).getUri().toString(), 1,<a name="line.2621"></a>
-<span class="sourceLineNo">2622</span>      null, null, new JobConf(this.conf));<a name="line.2622"></a>
-<span class="sourceLineNo">2623</span>    JobConf jobConf = MapreduceTestingShim.getJobConf(mrCluster);<a name="line.2623"></a>
-<span class="sourceLineNo">2624</span>    if (jobConf == null) {<a name="line.2624"></a>
-<span class="sourceLineNo">2625</span>      jobConf = mrCluster.createJobConf();<a name="line.2625"></a>
-<span class="sourceLineNo">2626</span>    }<a name="line.2626"></a>
+<span class="sourceLineNo">2566</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt; with a default number of<a name="line.2566"></a>
+<span class="sourceLineNo">2567</span>   * &lt;code&gt;TaskTracker&lt;/code&gt;'s.<a name="line.2567"></a>
+<span class="sourceLineNo">2568</span>   *<a name="line.2568"></a>
+<span class="sourceLineNo">2569</span>   * @throws IOException When starting the cluster fails.<a name="line.2569"></a>
+<span class="sourceLineNo">2570</span>   */<a name="line.2570"></a>
+<span class="sourceLineNo">2571</span>  public MiniMRCluster startMiniMapReduceCluster() throws IOException {<a name="line.2571"></a>
+<span class="sourceLineNo">2572</span>    // Set a very high max-disk-utilization percentage to avoid the NodeManagers from failing.<a name="line.2572"></a>
+<span class="sourceLineNo">2573</span>    conf.setIfUnset(<a name="line.2573"></a>
+<span class="sourceLineNo">2574</span>        "yarn.nodemanager.disk-health-checker.max-disk-utilization-per-disk-percentage",<a name="line.2574"></a>
+<span class="sourceLineNo">2575</span>        "99.0");<a name="line.2575"></a>
+<span class="sourceLineNo">2576</span>    startMiniMapReduceCluster(2);<a name="line.2576"></a>
+<span class="sourceLineNo">2577</span>    return mrCluster;<a name="line.2577"></a>
+<span class="sourceLineNo">2578</span>  }<a name="line.2578"></a>
+<span class="sourceLineNo">2579</span><a name="line.2579"></a>
+<span class="sourceLineNo">2580</span>  /**<a name="line.2580"></a>
+<span class="sourceLineNo">2581</span>   * Tasktracker has a bug where changing the hadoop.log.dir system property<a name="line.2581"></a>
+<span class="sourceLineNo">2582</span>   * will not change its internal static LOG_DIR variable.<a name="line.2582"></a>
+<span class="sourceLineNo">2583</span>   */<a name="line.2583"></a>
+<span class="sourceLineNo">2584</span>  private void forceChangeTaskLogDir() {<a name="line.2584"></a>
+<span class="sourceLineNo">2585</span>    Field logDirField;<a name="line.2585"></a>
+<span class="sourceLineNo">2586</span>    try {<a name="line.2586"></a>
+<span class="sourceLineNo">2587</span>      logDirField = TaskLog.class.getDeclaredField("LOG_DIR");<a name="line.2587"></a>
+<span class="sourceLineNo">2588</span>      logDirField.setAccessible(true);<a name="line.2588"></a>
+<span class="sourceLineNo">2589</span><a name="line.2589"></a>
+<span class="sourceLineNo">2590</span>      Field modifiersField = Field.class.getDeclaredField("modifiers");<a name="line.2590"></a>
+<span class="sourceLineNo">2591</span>      modifiersField.setAccessible(true);<a name="line.2591"></a>
+<span class="sourceLineNo">2592</span>      modifiersField.setInt(logDirField, logDirField.getModifiers() &amp; ~Modifier.FINAL);<a name="line.2592"></a>
+<span class="sourceLineNo">2593</span><a name="line.2593"></a>
+<span class="sourceLineNo">2594</span>      logDirField.set(null, new File(hadoopLogDir, "userlogs"));<a name="line.2594"></a>
+<span class="sourceLineNo">2595</span>    } catch (SecurityException e) {<a name="line.2595"></a>
+<span class="sourceLineNo">2596</span>      throw new RuntimeException(e);<a name="line.2596"></a>
+<span class="sourceLineNo">2597</span>    } catch (NoSuchFieldException e) {<a name="line.2597"></a>
+<span class="sourceLineNo">2598</span>      // TODO Auto-generated catch block<a name="line.2598"></a>
+<span class="sourceLineNo">2599</span>      throw new RuntimeException(e);<a name="line.2599"></a>
+<span class="sourceLineNo">2600</span>    } catch (IllegalArgumentException e) {<a name="line.2600"></a>
+<span class="sourceLineNo">2601</span>      throw new RuntimeException(e);<a name="line.2601"></a>
+<span class="sourceLineNo">2602</span>    } catch (IllegalAccessException e) {<a name="line.2602"></a>
+<span class="sourceLineNo">2603</span>      throw new RuntimeException(e);<a name="line.2603"></a>
+<span class="sourceLineNo">2604</span>    }<a name="line.2604"></a>
+<span class="sourceLineNo">2605</span>  }<a name="line.2605"></a>
+<span class="sourceLineNo">2606</span><a name="line.2606"></a>
+<span class="sourceLineNo">2607</span>  /**<a name="line.2607"></a>
+<span class="sourceLineNo">2608</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt;. Call {@link #setFileSystemURI(String)} to use a different<a name="line.2608"></a>
+<span class="sourceLineNo">2609</span>   * filesystem.<a name="line.2609"></a>
+<span class="sourceLineNo">2610</span>   * @param servers  The number of &lt;code&gt;TaskTracker&lt;/code&gt;'s to start.<a name="line.2610"></a>
+<span class="sourceLineNo">2611</span>   * @throws IOException When starting the cluster fails.<a name="line.2611"></a>
+<span class="sourceLineNo">2612</span>   */<a name="line.2612"></a>
+<span class="sourceLineNo">2613</span>  private void startMiniMapReduceCluster(final int servers) throws IOException {<a name="line.2613"></a>
+<span class="sourceLineNo">2614</span>    if (mrCluster != null) {<a name="line.2614"></a>
+<span class="sourceLineNo">2615</span>      throw new IllegalStateException("MiniMRCluster is already running");<a name="line.2615"></a>
+<span class="sourceLineNo">2616</span>    }<a name="line.2616"></a>
+<span class="sourceLineNo">2617</span>    LOG.info("Starting mini mapreduce cluster...");<a name="line.2617"></a>
+<span class="sourceLineNo">2618</span>    setupClusterTestDir();<a name="line.2618"></a>
+<span class="sourceLineNo">2619</span>    createDirsAndSetProperties();<a name="line.2619"></a>
+<span class="sourceLineNo">2620</span><a name="line.2620"></a>
+<span class="sourceLineNo">2621</span>    forceChangeTaskLogDir();<a name="line.2621"></a>
+<span class="sourceLineNo">2622</span><a name="line.2622"></a>
+<span class="sourceLineNo">2623</span>    //// hadoop2 specific settings<a name="line.2623"></a>
+<span class="sourceLineNo">2624</span>    // Tests were failing because this process used 6GB of virtual memory and was getting killed.<a name="line.2624"></a>
+<span class="sourceLineNo">2625</span>    // we up the VM usable so that processes don't get killed.<a name="line.2625"></a>
+<span class="sourceLineNo">2626</span>    conf.setFloat("yarn.nodemanager.vmem-pmem-ratio", 8.0f);<a name="line.2626"></a>
 <span class="sourceLineNo">2627</span><a name="line.2627"></a>
-<span class="sourceLineNo">2628</span>    jobConf.set("mapreduce.cluster.local.dir",<a name="line.2628"></a>
-<span class="sourceLineNo">2629</span>      conf.get("mapreduce.cluster.local.dir")); //Hadoop MiniMR overwrites this while it should not<a name="line.2629"></a>
-<span class="sourceLineNo">2630</span>    LOG.info("Mini mapreduce cluster started");<a name="line.2630"></a>
-<span class="sourceLineNo">2631</span><a name="line.2631"></a>
-<span class="sourceLineNo">2632</span>    // In hadoop2, YARN/MR2 starts a mini cluster with its own conf instance and updates settings.<a name="line.2632"></a>
-<span class="sourceLineNo">2633</span>    // Our HBase MR jobs need several of these settings in order to properly run.  So we copy the<a name="line.2633"></a>
-<span class="sourceLineNo">2634</span>    // necessary config properties here.  YARN-129 required adding a few properties.<a name="line.2634"></a>
-<span class="sourceLineNo">2635</span>    conf.set("mapreduce.jobtracker.address", jobConf.get("mapreduce.jobtracker.address"));<a name="line.2635"></a>
-<span class="sourceLineNo">2636</span>    // this for mrv2 support; mr1 ignores this<a name="line.2636"></a>
-<span class="sourceLineNo">2637</span>    conf.set("mapreduce.framework.name", "yarn");<a name="line.2637"></a>
-<span class="sourceLineNo">2638</span>    conf.setBoolean("yarn.is.minicluster", true);<a name="line.2638"></a>
-<span class="sourceLineNo">2639</span>    String rmAddress = jobConf.get("yarn.resourcemanager.address");<a name="line.2639"></a>
-<span class="sourceLineNo">2640</span>    if (rmAddress != null) {<a name="line.2640"></a>
-<span class="sourceLineNo">2641</span>      conf.set("yarn.resourcemanager.address", rmAddress);<a name="line.2641"></a>
-<span class="sourceLineNo">2642</span>    }<a name="line.2642"></a>
-<span class="sourceLineNo">2643</span>    String historyAddress = jobConf.get("mapreduce.jobhistory.address");<a name="line.2643"></a>
-<span class="sourceLineNo">2644</span>    if (historyAddress != null) {<a name="line.2644"></a>
-<span class="sourceLineNo">2645</span>      conf.set("mapreduce.jobhistory.address", historyAddress);<a name="line.2645"></a>
-<span class="sourceLineNo">2646</span>    }<a name="line.2646"></a>
-<span class="sourceLineNo">2647</span>    String schedulerAddress =<a name="line.2647"></a>
-<span class="sourceLineNo">2648</span>      jobConf.get("yarn.resourcemanager.scheduler.address");<a name="line.2648"></a>
-<span class="sourceLineNo">2649</span>    if (schedulerAddress != null) {<a name="line.2649"></a>
-<span class="sourceLineNo">2650</span>      conf.set("yarn.resourcemanager.scheduler.address", schedulerAddress);<a name="line.2650"></a>
-<span class="sourceLineNo">2651</span>    }<a name="line.2651"></a>
-<span class="sourceLineNo">2652</span>    String mrJobHistoryWebappAddress =<a name="line.2652"></a>
-<span class="sourceLineNo">2653</span>      jobConf.get("mapreduce.jobhistory.webapp.address");<a name="line.2653"></a>
-<span class="sourceLineNo">2654</span>    if (mrJobHistoryWebappAddress != null) {<a name="line.2654"></a>
-<span class="sourceLineNo">2655</span>      conf.set("mapreduce.jobhistory.webapp.address", mrJobHistoryWebappAddress);<a name="line.2655"></a>
-<span class="sourceLineNo">2656</span>    }<a name="line.2656"></a>
-<span class="sourceLineNo">2657</span>    String yarnRMWebappAddress =<a name="line.2657"></a>
-<span class="sourceLineNo">2658</span>      jobConf.get("yarn.resourcemanager.webapp.address");<a name="line.2658"></a>
-<span class="sourceLineNo">2659</span>    if (yarnRMWebappAddress != null) {<a name="line.2659"></a>
-<span class="sourceLineNo">2660</span>      conf.set("yarn.resourcemanager.webapp.address", yarnRMWebappAddress);<a name="line.2660"></a>
+<span class="sourceLineNo">2628</span>    // Tests were failing due to MAPREDUCE-4880 / MAPREDUCE-4607 against hadoop 2.0.2-alpha and<a name="line.2628"></a>
+<span class="sourceLineNo">2629</span>    // this avoids the problem by disabling speculative task execution in tests.<a name="line.2629"></a>
+<span class="sourceLineNo">2630</span>    conf.setBoolean("mapreduce.map.speculative", false);<a name="line.2630"></a>
+<span class="sourceLineNo">2631</span>    conf.setBoolean("mapreduce.reduce.speculative", false);<a name="line.2631"></a>
+<span class="sourceLineNo">2632</span>    ////<a name="line.2632"></a>
+<span class="sourceLineNo">2633</span><a name="line.2633"></a>
+<span class="sourceLineNo">2634</span>    // Allow the user to override FS URI for this map-reduce cluster to use.<a name="line.2634"></a>
+<span class="sourceLineNo">2635</span>    mrCluster = new MiniMRCluster(servers,<a name="line.2635"></a>
+<span class="sourceLineNo">2636</span>      FS_URI != null ? FS_URI : FileSystem.get(conf).getUri().toString(), 1,<a name="line.2636"></a>
+<span class="sourceLineNo">2637</span>      null, null, new JobConf(this.conf));<a name="line.2637"></a>
+<span class="sourceLineNo">2638</span>    JobConf jobConf = MapreduceTestingShim.getJobConf(mrCluster);<a name="line.2638"></a>
+<span class="sourceLineNo">2639</span>    if (jobConf == null) {<a name="line.2639"></a>
+<span class="sourceLineNo">2640</span>      jobConf = mrCluster.createJobConf();<a name="line.2640"></a>
+<span class="sourceLineNo">2641</span>    }<a name="line.2641"></a>
+<span class="sourceLineNo">2642</span><a name="line.2642"></a>
+<span class="sourceLineNo">2643</span>    jobConf.set("mapreduce.cluster.local.dir",<a name="line.2643"></a>
+<span class="sourceLineNo">2644</span>      conf.get("mapreduce.cluster.local.dir")); //Hadoop MiniMR overwrites this while it should not<a name="line.2644"></a>
+<span class="sourceLineNo">2645</span>    LOG.info("Mini mapreduce cluster started");<a name="line.2645"></a>
+<span class="sourceLineNo">2646</span><a name="line.2646"></a>
+<span class="sourceLineNo">2647</span>    // In hadoop2, YARN/MR2 starts a mini cluster with its own conf instance and updates settings.<a name="line.2647"></a>
+<span class="sourceLineNo">2648</span>    // Our HBase MR jobs need several of these settings in order to properly run.  So we copy the<a name="line.2648"></a>
+<span class="sourceLineNo">2649</span>    // necessary config properties here.  YARN-129 required adding a few properties.<a name="line.2649"></a>
+<span class="sourceLineNo">2650</span>    conf.set("mapreduce.jobtracker.address", jobConf.get("mapreduce.jobtracker.address"));<a name="line.2650"></a>
+<span class="sourceLineNo">2651</span>    // this for mrv2 support; mr1 ignores this<a name="line.2651"></a>
+<span class="sourceLineNo">2652</span>    conf.set("mapreduce.framework.name", "yarn");<a name="line.2652"></a>
+<span class="sourceLineNo">2653</span>    conf.setBoolean("yarn.is.minicluster", true);<a name="line.2653"></a>
+<span class="sourceLineNo">2654</span>    String rmAddress = jobConf.get("yarn.resourcemanager.address");<a name="line.2654"></a>
+<span class="sourceLineNo">2655</span>    if (rmAddress != null) {<a name="line.2655"></a>
+<span class="sourceLineNo">2656</span>      conf.set("yarn.resourcemanager.address", rmAddress);<a name="line.2656"></a>
+<span class="sourceLineNo">2657</span>    }<a name="line.2657"></a>
+<span class="sourceLineNo">2658</span>    String historyAddress = jobConf.get("mapreduce.jobhistory.address");<a name="line.2658"></a>
+<span class="sourceLineNo">2659</span>    if (historyAddress != null) {<a name="line.2659"></a>
+<span class="sourceLineNo">2660</span>      conf.set("mapreduce.jobhistory.address", historyAddress);<a name="line.2660"></a>
 <span class="sourceLineNo">2661</span>    }<a name="line.2661"></a>
-<span class="sourceLineNo">2662</span>  }<a name="line.2662"></a>
-<span class="sourceLineNo">2663</span><a name="line.2663"></a>
-<span class="sourceLineNo">2664</span>  /**<a name="line.2664"></a>
-<span class="sourceLineNo">2665</span>   * Stops the previously started &lt;code&gt;MiniMRCluster&lt;/code&gt;.<a name="line.2665"></a>
-<span class="sourceLineNo">2666</span>   */<a name="line.2666"></a>
-<span class="sourceLineNo">2667</span>  public void shutdownMiniMapReduceCluster() {<a name="line.2667"></a>
-<span class="sourceLineNo">2668</span>    if (mrCluster != null) {<a name="line.2668"></a>
-<span class="sourceLineNo">2669</span>      LOG.info("Stopping mini mapreduce cluster...");<a name="line.2669"></a>
-<span class="sourceLineNo">2670</span>      mrCluster.shutdown();<a name="line.2670"></a>
-<span class="sourceLineNo">2671</span>      mrCluster = null;<a name="line.2671"></a>
-<span class="sourceLineNo">2672</span>      LOG.info("Mini mapreduce cluster stopped");<a name="line.2672"></a>
-<span class="sourceLineNo">2673</span>    }<a name="line.2673"></a>
-<span class="sourceLineNo">2674</span>    // Restore configuration to point to local jobtracker<a name="line.2674"></a>
-<span class="sourceLineNo">2675</span>    conf.set("mapreduce.jobtracker.address", "local");<a name="line.2675"></a>
-<span class="sourceLineNo">2676</span>  }<a name="line.2676"></a>
-<span class="sourceLineNo">2677</span><a name="line.2677"></a>
-<span class="sourceLineNo">2678</span>  /**<a name="line.2678"></a>
-<span class="sourceLineNo">2679</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2679"></a>
-<span class="sourceLineNo">2680</span>   */<a name="line.2680"></a>
-<span class="sourceLineNo">2681</span>  public RegionServerServices createMockRegionServerService() throws IOException {<a name="line.2681"></a>
-<span class="sourceLineNo">2682</span>    return createMockRegionServerService((ServerName)null);<a name="line.2682"></a>
-<span class="sourceLineNo">2683</span>  }<a name="line.2683"></a>
-<span class="sourceLineNo">2684</span><a name="line.2684"></a>
-<span class="sourceLineNo">2685</span>  /**<a name="line.2685"></a>
-<span class="sourceLineNo">2686</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2686"></a>
-<span class="sourceLineNo">2687</span>   * This version is used by TestTokenAuthentication<a name="line.2687"></a>
-<span class="sourceLineNo">2688</span>   */<a name="line.2688"></a>
-<span class="sourceLineNo">2689</span>  public RegionServerServices createMockRegionServerService(RpcServerInterface rpc) throws<a name="line.2689"></a>
-<span class="sourceLineNo">2690</span>      IOException {<a name="line.2690"></a>
-<span class="sourceLineNo">2691</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher());<a name="line.2691"></a>
-<span class="sourceLineNo">2692</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2692"></a>
-<span class="sourceLineNo">2693</span>    rss.setRpcServer(rpc);<a name="line.2693"></a>
-<span class="sourceLineNo">2694</span>    return rss;<a name="line.2694"></a>
-<span class="sourceLineNo">2695</span>  }<a name="line.2695"></a>
-<span class="sourceLineNo">2696</span><a name="line.2696"></a>
-<span class="sourceLineNo">2697</span>  /**<a name="line.2697"></a>
-<span class="sourceLineNo">2698</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2698"></a>
-<span class="sourceLineNo">2699</span>   * This version is used by TestOpenRegionHandler<a name="line.2699"></a>
-<span class="sourceLineNo">2700</span>   */<a name="line.2700"></a>
-<span class="sourceLineNo">2701</span>  public RegionServerServices createMockRegionServerService(ServerName name) throws IOException {<a name="line.2701"></a>
-<span class="sourceLineNo">2702</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher(), name);<a name="line.2702"></a>
-<span class="sourceLineNo">2703</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2703"></a>
-<span class="sourceLineNo">2704</span>    return rss;<a name="line.2704"></a>
-<span class="sourceLineNo">2705</span>  }<a name="line.2705"></a>
-<span class="sourceLineNo">2706</span><a name="line.2706"></a>
-<span class="sourceLineNo">2707</span>  /**<a name="line.2707"></a>
-<span class="sourceLineNo">2708</span>   * Switches the logger for the given class to DEBUG level.<a name="line.2708"></a>
-<span class="sourceLineNo">2709</span>   *<a name="line.2709"></a>
-<span class="sourceLineNo">2710</span>   * @param clazz  The class for which to switch to debug logging.<a name="line.2710"></a>
-<span class="sourceLineNo">2711</span>   */<a name="line.2711"></a>
-<span class="sourceLineNo">2712</span>  public void enableDebug(Class&lt;?&gt; clazz) {<a name="line.2712"></a>
-<span class="sourceLineNo">2713</span>    Log l = LogFactory.getLog(clazz);<a name="line.2713"></a>
-<span class="sourceLineNo">2714</span>    if (l instanceof Log4JLogger) {<a name="line.2714"></a>
-<span class="sourceLineNo">2715</span>      ((Log4JLogger) l).getLogger().setLevel(org.apache.log4j.Level.DEBUG);<a name="line.2715"></a>
-<span class="sourceLineNo">2716</span>    } else if (l instanceof Jdk14Logger) {<a name="line.2716"></a>
-<span class="sourceLineNo">2717</span>      ((Jdk14Logger) l).getLogger().setLevel(java.util.logging.Level.ALL);<a name="line.2717"></a>
-<span class="sourceLineNo">2718</span>    }<a name="line.2718"></a>
-<span class="sourceLineNo">2719</span>  }<a name="line.2719"></a>
-<span class="sourceLineNo">2720</span><a name="line.2720"></a>
-<span class="sourceLineNo">2721</span>  /**<a name="line.2721"></a>
-<span class="sourceLineNo">2722</span>   * Expire the Master's session<a name="line.2722"></a>
-<span class="sourceLineNo">2723</span>   * @throws Exception<a name="line.2723"></a>
-<span class="sourceLineNo">2724</span>   */<a name="line.2724"></a>
-<span class="sourceLineNo">2725</span>  public void expireMasterSession() throws Exception {<a name="line.2725"></a>
-<span class="sourceLineNo">2726</span>    HMaster master = getMiniHBaseCluster().getMaster();<a name="line.2726"></a>
-<span class="sourceLineNo">2727</span>    expireSession(master.getZooKeeper(), false);<a name="line.2727"></a>
-<span class="sourceLineNo">2728</span>  }<a name="line.2728"></a>
-<span class="sourceLineNo">2729</span><a name="line.2729"></a>
-<span class="sourceLineNo">2730</span>  /**<a name="line.2730"></a>
-<span class="sourceLineNo">2731</span>   * Expire a region server's session<a name="line.2731"></a>
-<span class="sourceLineNo">2732</span>   * @param index which RS<a name="line.2732"></a>
-<span class="sourceLineNo">2733</span>   * @throws Exception<a name="line.2733"></a>
-<span class="sourceLineNo">2734</span>   */<a name="line.2734"></a>
-<span class="sourceLineNo">2735</span>  public void expireRegionServerSession(int index) throws Exception {<a name="line.2735"></a>
-<span class="sourceLineNo">2736</span>    HRegionServer rs = getMiniHBaseCluster().getRegionServer(index);<a name="line.2736"></a>
-<span class="sourceLineNo">2737</span>    expireSession(rs.getZooKeeper(), false);<a name="line.2737"></a>
-<span class="sourceLineNo">2738</span>    decrementMinRegionServerCount();<a name="line.2738"></a>
-<span class="sourceLineNo">2739</span>  }<a name="line.2739"></a>
-<span class="sourceLineNo">2740</span><a name="line.2740"></a>
-<span class="sourceLineNo">2741</span>  private void decrementMinRegionServerCount() {<a name="line.2741"></a>
-<span class="sourceLineNo">2742</span>    // decrement the count for this.conf, for newly spwaned master<a name="line.2742"></a>
-<span class="sourceLineNo">2743</span>    // this.hbaseCluster shares this configuration too<a name="line.2743"></a>
-<span class="sourceLineNo">2744</span>    decrementMinRegionServerCount(getConfiguration());<a name="line.2744"></a>
-<span class="sourceLineNo">2745</span><a name="line.2745"></a>
-<span class="sourceLineNo">2746</span>    // each master thread keeps a copy of configuration<a name="line.2746"></a>
-<span class="sourceLineNo">2747</span>    for (MasterThread master : getHBaseCluster().getMasterThreads()) {<a name="line.2747"></a>
-<span class="sourceLineNo">2748</span>      decrementMinRegionServerCount(master.getMaster().getConfiguration());<a name="line.2748"></a>
-<span class="sourceLineNo">2749</span>    }<a name="line.2749"></a>
-<span class="sourceLineNo">2750</span>  }<a name="line.2750"></a>
-<span class="sourceLineNo">2751</span><a name="line.2751"></a>
-<span class="sourceLineNo">2752</span>  private void decrementMinRegionServerCount(Configuration conf) {<a name="line.2752"></a>
-<span class="sourceLineNo">2753</span>    int currentCount = conf.getInt(<a name="line.2753"></a>
-<span class="sourceLineNo">2754</span>        ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART, -1);<a name="line.2754"></a>
-<span class="sourceLineNo">2755</span>    if (currentCount != -1) {<a name="line.2755"></a>
-<span class="sourceLineNo">2756</span>      conf.setInt(ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART,<a name="line.2756"></a>
-<span class="sourceLineNo">2757</span>          Math.max(currentCount - 1, 1));<a name="line.2757"></a>
-<span class="sourceLineNo">2758</span>    }<a name="line.2758"></a>
-<span class="sourceLineNo">2759</span>  }<a name="line.2759"></a>
+<span class="sourceLineNo">2662</span>    String schedulerAddress =<a name="line.2662"></a>
+<span class="sourceLineNo">2663</span>      jobConf.get("yarn.resourcemanager.scheduler.address");<a name="line.2663"></a>
+<span class="sourceLineNo">2664</span>    if (schedulerAddress != null) {<a name="line.2664"></a>
+<span class="sourceLineNo">2665</span>      conf.set("yarn.resourcemanager.scheduler.address", schedulerAddress);<a name="line.2665"></a>
+<span class="sourceLineNo">2666</span>    }<a name="line.2666"></a>
+<span class="sourceLineNo">2667</span>    String mrJobHistoryWebappAddress =<a name="line.2667"></a>
+<span class="sourceLineNo">2668</span>      jobConf.get("mapreduce.jobhistory.webapp.address");<a name="line.2668"></a>
+<span class="sourceLineNo">2669</span>    if (mrJobHistoryWebappAddress != null) {<a name="line.2669"></a>
+<span class="sourceLineNo">2670</span>      conf.set("mapreduce.jobhistory.webapp.address", mrJobHistoryWebappAddress);<a name="line.2670"></a>
+<span class="sourceLineNo">2671</span>    }<a name="line.2671"></a>
+<span class="sourceLineNo">2672</span>    String yarnRMWebappAddress =<a name="line.2672"></a>
+<span class="sourceLineNo">2673</span>      jobConf.get("yarn.resourcemanager.webapp.address");<a name="line.2673"></a>
+<span class="sourceLineNo">2674</span>    if (yarnRMWebappAddress != null) {<a name="line.2674"></a>
+<span class="sourceLineNo">2675</span>      conf.set("yarn.resourcemanager.webapp.address", yarnRMWebappAddress);<a name="line.2675"></a>
+<span class="sourceLineNo">2676</span>    }<a name="line.2676"></a>
+<span class="sourceLineNo">2677</span>  }<a name="line.2677"></a>
+<span class="sourceLineNo">2678</span><a name="line.2678"></a>
+<span class="sourceLineNo">2679</span>  /**<a name="line.2679"></a>
+<span class="sourceLineNo">2680</span>   * Stops the previously started &lt;code&gt;MiniMRCluster&lt;/code&gt;.<a name="line.2680"></a>
+<span class="sourceLineNo">2681</span>   */<a name="line.2681"></a>
+<span class="sourceLineNo">2682</span>  public void shutdownMiniMapReduceCluster() {<a name="line.2682"></a>
+<span class="sourceLineNo">2683</span>    if (mrCluster != null) {<a name="line.2683"></a>
+<span class="sourceLineNo">2684</span>      LOG.info("Stopping mini mapreduce cluster...");<a name="line.2684"></a>
+<span class="sourceLineNo">2685</span>      mrCluster.shutdown();<a name="line.2685"></a>
+<span class="sourceLineNo">2686</span>      mrCluster = null;<a name="line.2686"></a>
+<span class="sourceLineNo">2687</span>      LOG.info("Mini mapreduce cluster stopped");<a name="line.2687"></a>
+<span class="sourceLineNo">2688</span>    }<a name="line.2688"></a>
+<span class="sourceLineNo">2689</span>    // Restore configuration to point to local jobtracker<a name="line.2689"></a>
+<span class="sourceLineNo">2690</span>    conf.set("mapreduce.jobtracker.address", "local");<a name="line.2690"></a>
+<span class="sourceLineNo">2691</span>  }<a name="line.2691"></a>
+<span class="sourceLineNo">2692</span><a name="line.2692"></a>
+<span class="sourceLineNo">2693</span>  /**<a name="line.2693"></a>
+<span class="sourceLineNo">2694</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2694"></a>
+<span class="sourceLineNo">2695</span>   */<a name="line.2695"></a>
+<span class="sourceLineNo">2696</span>  public RegionServerServices createMockRegionServerService() throws IOException {<a name="line.2696"></a>
+<span class="sourceLineNo">2697</span>    return createMockRegionServerService((ServerName)null);<a name="line.2697"></a>
+<span class="sourceLineNo">2698</span>  }<a name="line.2698"></a>
+<span class="sourceLineNo">2699</span><a name="line.2699"></a>
+<span class="sourceLineNo">2700</span>  /**<a name="line.2700"></a>
+<span class="sourceLineNo">2701</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2701"></a>
+<span class="sourceLineNo">2702</span>   * This version is used by TestTokenAuthentication<a name="line.2702"></a>
+<span class="sourceLineNo">2703</span>   */<a name="line.2703"></a>
+<span class="sourceLineNo">2704</span>  public RegionServerServices createMockRegionServerService(RpcServerInterface rpc) throws<a name="line.2704"></a>
+<span class="sourceLineNo">2705</span>      IOException {<a name="line.2705"></a>
+<span class="sourceLineNo">2706</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher());<a name="line.2706"></a>
+<span class="sourceLineNo">2707</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2707"></a>
+<span class="sourceLineNo">2708</span>    rss.setRpcServer(rpc);<a name="line.2708"></a>
+<span class="sourceLineNo">2709</span>    return rss;<a name="line.2709"></a>
+<span class="sourceLineNo">2710</span>  }<a name="line.2710"></a>
+<span class="sourceLineNo">2711</span><a name="line.2711"></a>
+<span class="sourceLineNo">2712</span>  /**<a name="line.2712"></a>
+<span class="sourceLineNo">2713</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2713"></a>
+<span class="sourceLineNo">2714</span>   * This version is used by TestOpenRegionHandler<a name="line.2714"></a>
+<span class="sourceLineNo">2715</span>   */<a name="line.2715"></a>
+<span class="sourceLineNo">2716</span>  public RegionServerServices createMockRegionServerService(ServerName name) throws IOException {<a name="line.2716"></a>
+<span class="sourceLineNo">2717</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher(), name);<a name="line.2717"></a>
+<span class="sourceLineNo">2718</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2718"></a>
+<span class="sourceLineNo">2719</span>    return rss;<a name="line.2719"></a>
+<span class="sourceLineNo">2720</span>  }<a name="line.2720"></a>
+<span class="sourceLineNo">2721</span><a name="line.2721"></a>
+<span class="sourceLineNo">2722</span>  /**<a name="line.2722"></a>
+<span class="sourceLineNo">2723</span>   * Switches the logger for the given class to DEBUG level.<a name="line.2723"></a>
+<span class="sourceLineNo">2724</span>   *<a name="line.2724"></a>
+<span class="sourceLineNo">2725</span>   * @param clazz  The class for which to switch to debug logging.<a name="line.2725"></a>
+<span class="sourceLineNo">2726</span>   */<a name="line.2726"></a>
+<span class="sourceLineNo">2727</span>  public void enableDebug(Class&lt;?&gt; clazz) {<a name="line.2727"></a>
+<span class="sourceLineNo">2728</span>    Log l = LogFactory.getLog(clazz);<a name="line.2728"></a>
+<span class="sourceLineNo">2729</span>    if (l instanceof Log4JLogger) {<a name="line.2729"></a>
+<span class="sourceLineNo">2730</span>      ((Log4JLogger) l).getLogger().setLevel(org.apache.log4j.Level.DEBUG);<a name="line.2730"></a>
+<span class="sourceLineNo">2731</span>    } else if (l instanceof Jdk14Logger) {<a name="line.2731"></a>
+<span class="sourceLineNo">2732</span>      ((Jdk14Logger) l).getLogger().setLevel(java.util.logging.Level.ALL);<a name="line.2732"></a>
+<span class="sourceLineNo">2733</span>    }<a name="line.2733"></a>
+<span class="sourceLineNo">2734</span>  }<a name="line.2734"></a>
+<span class="sourceLineNo">2735</span><a name="line.2735"></a>
+<span class="sourceLineNo">2736</span>  /**<a name="line.2736"></a>
+<span class="sourceLineNo">2737</span>   * Expire the Master's session<a name="line.2737"></a>
+<span class="sourceLineNo">2738</span>   * @throws Exception<a name="line.2738"></a>
+<span class="sourceLineNo">2739</span>   */<a name="line.2739"></a>
+<span class="sourceLineNo">2740</span>  public void expireMasterSession() throws Exception {<a name="line.2740"></a>
+<span class="sourceLineNo">2741</span>    HMaster master = getMiniHBaseCluster().getMaster();<a name="line.2741"></a>
+<span class="sourceLineNo">2742</span>    expireSession(master.getZooKeeper(), false);<a name="line.2742"></a>
+<span class="sourceLineNo">2743</span>  }<a name="line.2743"></a>
+<span class="sourceLineNo">2744</span><a name="line.2744"></a>
+<span class="sourceLineNo">2745</span>  /**<a name="line.2745"></a>
+<span class="sourceLineNo">2746</span>   * Expire a region server's session<a name="line.2746"></a>
+<span class="sourceLineNo">2747</span>   * @param index which RS<a name="line.2747"></a>
+<span class="sourceLineNo">2748</span>   * @throws Exception<a name="line.2748"></a>
+<span class="sourceLineNo">2749</span>   */<a name="line.2749"></a>
+<span class="sourceLineNo">2750</span>  public void expireRegionServerSession(int index) throws Exception {<a name="line.2750"></a>
+<span class="sourceLineNo">2751</span>    HRegionServer rs = getMiniHBaseCluster().getRegionServer(index);<a name="line.2751"></a>
+<span class="sourceLineNo">2752</span>    expireSession(rs.getZooKeeper(), false);<a name="line.2752"></a>
+<span class="sourceLineNo">2753</span>    decrementMinRegionServerCount();<a name="line.2753"></a>
+<span class="sourceLineNo">2754</span>  }<a name="line.2754"></a>
+<span class="sourceLineNo">2755</span><a name="line.2755"></a>
+<span class="sourceLineNo">2756</span>  private void decrementMinRegionServerCount() {<a name="line.2756"></a>
+<span class="sourceLineNo">2757</span>    // decrement the count for this.conf, for newly spwaned master<a name="line.2757"></a>
+<span class="sourceLineNo">2758</span>    // this.hbaseCluster shares this configuration too<a name="line.2758"></a>
+<span class="sourceLineNo">2759</span>    decrementMinRegionServerCount(getConfiguration());<a name="line.2759"></a>
 <span class="sourceLineNo">2760</span><a name="line.2760"></a>
-<span class="sourceLineNo">2761</span>  public void expireSession(ZKWatcher nodeZK) throws Exception {<a name="line.2761"></a>
-<span class="sourceLineNo">2762</span>   expireSession(nodeZK, false);<a name="line.2762"></a>
-<span class="sourceLineNo">2763</span>  }<a name="line.2763"></a>
-<span class="sourceLineNo">2764</span><a name="line.2764"></a>
-<span class="sourceLineNo">2765</span>  /**<a name="line.2765"></a>
-<span class="sourceLineNo">2766</span>   * Expire a ZooKeeper session as recommended in ZooKeeper documentation<a name="line.2766"></a>
-<span class="sourceLineNo">2767</span>   * http://hbase.apache.org/book.html#trouble.zookeeper<a name="line.2767"></a>
-<span class="sourceLineNo">2768</span>   * There are issues when doing this:<a name="line.2768"></a>
-<span class="sourceLineNo">2769</span>   * [1] http://www.mail-archive.com/dev@zookeeper.apache.org/msg01942.html<a name="line.2769"></a>
-<span class="sourceLineNo">2770</span>   * [2] https://issues.apache.org/jira/browse/ZOOKEEPER-1105<a name="line.2770"></a>
-<span class="sourceLineNo">2771</span>   *<a name="line.2771"></a>
-<span class="sourceLineNo">2772</span>   * @param nodeZK - the ZK watcher to expire<a name="line.2772"></a>
-<span class="sourceLineNo">2773</span>   * @param checkStatus - true to check if we can create a Table with the<a name="line.2773"></a>
-<span class="sourceLineNo">2774</span>   *                    current configuration.<a name="line.2774"></a>
-<span class="sourceLineNo">2775</span>   */<a name="line.2775"></a>
-<span class="sourceLineNo">2776</span>  public void expireSession(ZKWatcher nodeZK, boolean checkStatus)<a name="line.2776"></a>
-<span class="sourceLineNo">2777</span>    throws Exception {<a name="line.2777"></a>
-<span class="sourceLineNo">2778</span>    Configuration c = new Configuration(this.conf);<a name="line.2778"></a>
-<span class="sourceLineNo">2779</span>    String quorumServers = ZKConfig.getZKQuorumServersString(c);<a name="line.2779"></a>
-<span class="sourceLineNo">2780</span>    ZooKeeper zk = nodeZK.getRecoverableZooKeeper().getZooKeeper();<a name="line.2780"></a>
-<span class="sourceLineNo">2781</span>    byte[] password = zk.getSessionPasswd();<a name="line.2781"></a>
-<span class="sourceLineNo">2782</span>    long sessionID = zk.getSessionId();<a name="line.2782"></a>
-<span class="sourceLineNo">2783</span><a name="line.2783"></a>
-<span class="sourceLineNo">2784</span>    // Expiry seems to be asynchronous (see comment from P. Hunt in [1]),<a name="line.2784"></a>
-<span class="sourceLineNo">2785</span>    //  so we create a first watcher to be sure that the<a name="line.2785"></a>
-<span class="sourceLineNo">2786</span>    //  event was sent. We expect that if our watcher receives the event<a name="line.2786"></a>
-<span class="sourceLineNo">2787</span>    //  other watchers on the same machine will get is as well.<a name="line.2787"></a>
-<span class="sourceLineNo">2788</span>    // When we ask to close the connection, ZK does not close it before<a name="line.2788"></a>
-<span class="sourceLineNo">2789</span>    //  we receive all the events, so don't have to capture the event, just<a name="line.2789"></a>
-<span class="sourceLineNo">2790</span>    //  closing the connection should be enough.<a name="line.2790"></a>
-<span class="sourceLineNo">2791</span>    ZooKeeper monitor = new ZooKeeper(quorumServers,<a name="line.2791"></a>
-<span class="sourceLineNo">2792</span>      1000, new org.apache.zookeeper.Watcher(){<a name="line.2792"></a>
-<span class="sourceLineNo">2793</span>      @Override<a name="line.2793"></a>
-<span class="sourceLineNo">2794</span>      public void process(WatchedEvent watchedEvent) {<a name="line.2794"></a>
-<span class="sourceLineNo">2795</span>        LOG.info("Monitor ZKW received event="+watchedEvent);<a name="line.2795"></a>
-<span class="sourceLineNo">2796</span>      }<a name="line.2796"></a>
-<span class="sourceLineNo">2797</span>    } , sessionID, password);<a name="line.2797"></a>
+<span class="sourceLineNo">2761</span>    // each master thread keeps a copy of configuration<a name="line.2761"></a>
+<span class="sourceLineNo">2762</span>    for (MasterThread master : getHBaseCluster().getMasterThreads()) {<a name="line.2762"></a>
+<span class="sourceLineNo">2763</span>      decrementMinRegionServerCount(master.getMaster().getConfiguration());<a name="line.2763"></a>
+<span class="sourceLineNo">2764</span>    }<a name="line.2764"></a>
+<span class="sourceLineNo">2765</span>  }<a name="line.2765"></a>
+<span class="sourceLineNo">2766</span><a name="line.2766"></a>
+<span class="sourceLineNo">2767</span>  private void decrementMinRegionServerCount(Configuration conf) {<a name="line.2767"></a>
+<span class="sourceLineNo">2768</span>    int currentCount = conf.getInt(<a name="line.2768"></a>
+<span class="sourceLineNo">2769</span>        ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART, -1);<a name="line.2769"></a>
+<span class="sourceLineNo">2770</span>    if (currentCount != -1) {<a name="line.2770"></a>
+<span class="sourceLineNo">2771</span>      conf.setInt(ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART,<a name="line.2771"></a>
+<span class="sourceLineNo">2772</span>          Math.max(currentCount - 1, 1));<a name="line.2772"></a>
+<span class="sourceLineNo">2773</span>    }<a name="line.2773"></a>
+<span class="sourceLineNo">2774</span>  }<a name="line.2774"></a>
+<span class="sourceLineNo">2775</span><a name="line.2775"></a>
+<span class="sourceLineNo">2776</span>  public void expireSession(ZKWatcher nodeZK) throws Exception {<a name="line.2776"></a>
+<span class="sourceLineNo">2777</span>   expireSession(nodeZK, false);<a name="line.2777"></a>
+<span class="sourceLineNo">2778</span>  }<a name="line.2778"></a>
+<span class="sourceLineNo">2779</span><a name="line.2779"></a>
+<span class="sourceLineNo">2780</span>  /**<a name="line.2780"></a>
+<span class="sourceLineNo">2781</span>   * Expire a ZooKeeper session as recommended in ZooKeeper documentation<a name="line.2781"></a>
+<span class="sourceLineNo">2782</span>   * http://hbase.apache.org/book.html#trouble.zookeeper<a name="line.2782"></a>
+<span class="sourceLineNo">2783</span>   * There are issues when doing this:<a name="line.2783"></a>
+<span class="sourceLineNo">2784</span>   * [1] http://www.mail-archive.com/dev@zookeeper.apache.org/msg01942.html<a name="line.2784"></a>
+<span class="sourceLineNo">2785</span>   * [2] https://issues.apache.org/jira/browse/ZOOKEEPER-1105<a name="line.2785"></a>
+<span class="sourceLineNo">2786</span>   *<a name="line.2786"></a>
+<span class="sourceLineNo">2787</span>   * @param nodeZK - the ZK watcher to expire<a name="line.2787"></a>
+<span class="sourceLineNo">2788</span>   * @param checkStatus - true to check if we can create a Table with the<a name="line.2788"></a>
+<span class="sourceLineNo">2789</span>   *                    current configuration.<a name="line.2789"></a>
+<span class="sourceLineNo">2790</span>   */<a name="line.2790"></a>
+<span class="sourceLineNo">2791</span>  public void expireSession(ZKWatcher nodeZK, boolean checkStatus)<a name="line.2791"></a>
+<span class="sourceLineNo">2792</span>    throws Exception {<a name="line.2792"></a>
+<span class="sourceLineNo">2793</span>    Configuration c = new Configuration(this.conf);<a name="line.2793"></a>
+<span class="sourceLineNo">2794</span>    String quorumServers = ZKConfig.getZKQuorumServersString(c);<a name="line.2794"></a>
+<span class="sourceLineNo">2795</span>    ZooKeeper zk = nodeZK.getRecoverableZooKeeper().getZooKeeper();<a name="line.2795"></a>
+<span class="sourceLineNo">2796</span>    byte[] password = zk.getSessionPasswd();<a name="line.2796"></a>
+<span class="sourceLineNo">2797</span>    long sessionID = zk.getSessionId();<a name="line.2797"></a>
 <span class="sourceLineNo">2798</span><a name="line.2798"></a>
-<span class="sourceLineNo">2799</span>    // Making it expire<a name="line.2799"></a>
-<span class="sourceLineNo">2800</span>    ZooKeeper newZK = new ZooKeeper(quorumServers,<a name="line.2800"></a>
-<span class="sourceLineNo">2801</span>        1000, EmptyWatcher.instance, sessionID, password);<a name="line.2801"></a>
-<span class="sourceLineNo">2802</span><a name="line.2802"></a>
-<span class="sourceLineNo">2803</span>    //ensure that we have connection to the server before closing down, otherwise<a name="line.2803"></a>
-<span class="sourceLineNo">2804</span>    //the close session event will be eaten out before we start CONNECTING state<a name="line.2804"></a>
-<span class="sourceLineNo">2805</span>    long start = System.currentTimeMillis();<a name="line.2805"></a>
-<span class="sourceLineNo">2806</span>    while (newZK.getState() != States.CONNECTED<a name="line.2806"></a>
-<span class="sourceLineNo">2807</span>         &amp;&amp; System.currentTimeMillis() - start &lt; 1000) {<a name="line.2807"></a>
-<span class="sourceLineNo">2808</span>       Thread.sleep(1);<a name="line.2808"></a>
-<span class="sourceLineNo">2809</span>    }<a name="line.2809"></a>
-<span class="sourceLineNo">2810</span>    newZK.close();<a name="line.2810"></a>
-<span class="sourceLineNo">2811</span>    LOG.info("ZK Closed Session 0x" + Long.toHexString(sessionID));<a name="line.2811"></a>
-<span class="sourceLineNo">2812</span><a name="line.2812"></a>
-<span class="sourceLineNo">2813</span>    // Now closing &amp; waiting to be sure that the clients get it.<a name="line.2813"></a>
-<span class="sourceLineNo">2814</span>    monitor.close();<a name="line.2814"></a>
-<span class="sourceLineNo">2815</span><a name="line.2815"></a>
-<span class="sourceLineNo">2816</span>    if (checkStatus) {<a name="line.2816"></a>
-<span class="sourceLineNo">2817</span>      getConnection().getTable(TableName.META_TABLE_NAME).close();<a name="line.2817"></a>
-<span class="sourceLineNo">2818</span>    }<a name="line.2818"></a>
-<span class="sourceLineNo">2819</span>  }<a name="line.2819"></a>
-<span class="sourceLineNo">2820</span><a name="line.2820"></a>
-<span class="sourceLineNo">2821</span>  /**<a name="line.2821"></a>
-<span class="sourceLineNo">2822</span>   * Get the Mini HBase cluster.<a name="line.2822"></a>
-<span class="sourceLineNo">2823</span>   *<a name="line.2823"></a>
-<span class="sourceLineNo">2824</span>   * @return hbase cluster<a name="line.2824"></a>
-<span class="sourceLineNo">2825</span>   * @see #getHBaseClusterInterface()<a name="line.2825"></a>
-<span class="sourceLineNo">2826</span>   */<a name="line.2826"></a>
-<span class="sourceLineNo">2827</span>  public MiniHBaseCluster getHBaseCluster() {<a name="line.2827"></a>
-<span class="sourceLineNo">2828</span>    return getMiniHBaseCluster();<a name="line.2828"></a>
-<span class="sourceLineNo">2829</span>  }<a name="line.2829"></a>
+<span class="sourceLineNo">2799</span>    // Expiry seems to be asynchronous (see comment from P. Hunt in [1]),<a name="line.2799"></a>
+<span class="sourceLineNo">2800</span>    //  so we create a first watcher to be sure that the<a name="line.2800"></a>
+<span class="sourceLineNo">2801</span>    //  event was sent. We expect that if our watcher receives the event<a name="line.2801"></a>
+<span class="sourceLineNo">2802</span>    //  other watchers on the same machine will get is as well.<a name="line.2802"></a>
+<span class="sourceLineNo">2803</span>    // When we ask to close the connection, ZK does not close it before<a name="line.2803"></a>
+<span class="sourceLineNo">2804</span>    //  we receive all the events, so don't have to capture the event, just<a name="line.2804"></a>
+<span class="sourceLineNo">2805</span>    //  closing the connection should be enough.<a name="line.2805"></a>
+<span class="sourceLineNo">2806</span>    ZooKeeper monitor = new ZooKeeper(quorumServers,<a name="line.2806"></a>
+<span class="sourceLineNo">2807</span>      1000, new org.apache.zookeeper.Watcher(){<a name="line.2807"></a>
+<span class="sourceLineNo">2808</span>      @Override<a name="line.2808"></a>
+<span class="sourceLineNo">2809</span>      public void process(WatchedEvent watchedEvent) {<a name="line.2809"></a>
+<span class="sourceLineNo">2810</span>        LOG.info("Monitor ZKW received event="+watchedEvent);<a name="line.2810"></a>
+<span class="sourceLineNo">2811</span>      }<a name="line.2811"></a>
+<span class="sourceLineNo">2812</span>    } , sessionID, password);<a name="line.2812"></a>
+<span class="sourceLineNo">2813</span><a name="line.2813"></a>
+<span class="sourceLineNo">2814</span>    // Making it expire<a name="line.2814"></a>
+<span class="sourceLineNo">2815</span>    ZooKeeper newZK = new ZooKeeper(quorumServers,<a name="line.2815"></a>
+<span class="sourceLineNo">2816</span>        1000, EmptyWatcher.instance, sessionID, password);<a name="line.2816"></a>
+<span class="sourceLineNo">2817</span><a name="line.2817"></a>
+<span class="sourceLineNo">2818</span>    //ensure that we have connection to the server before closing down, otherwise<a name="line.2818"></a>
+<span class="sourceLineNo">2819</span>    //the close session event will be eaten out before we start CONNECTING state<a name="line.2819"></a>
+<span class="sourceLineNo">2820</span>    long start = System.currentTimeMillis();<a name="line.2820"></a>
+<span class="sourceLineNo">2821</span>    while (newZK.getState() != States.CONNECTED<a name="line.2821"></a>
+<span class="sourceLineNo">2822</span>         &amp;&amp; System.currentTimeMillis() - start &lt; 1000) {<a name="line.2822"></a>
+<span class="sourceLineNo">2823</span>       Thread.sleep(1);<a name="line.2823"></a>
+<span class="sourceLineNo">2824</span>    }<a name="line.2824"></a>
+<span class="sourceLineNo">2825</span>    newZK.close();<a name="line.2825"></a>
+<span class="sourceLineNo">2826</span>    LOG.info("ZK Closed Session 0x" + Long.toHexString(sessionID));<a name="line.2826"></a>
+<span class="sourceLineNo">2827</span><a name="line.2827"></a>
+<span class="sourceLineNo">2828</span>    // Now closing &amp; waiting to be sure that the clients get it.<a name="line.2828"></a>
+<span class="sourceLineNo">2829</span>    monitor.close();<a name="line.2829"></a>
 <span class="sourceLineNo">2830</span><a name="line.2830"></a>
-<span class="sourceLineNo">2831</span>  /**<a name="line.2831"></a>
-<span class="sourceLineNo">2832</span>   * Returns the HBaseCluster instance.<a name="line.2832"></a>
-<span class="sourceLineNo">2833</span>   * &lt;p&gt;Returned object can be any of the subclasses of HBaseCluster, and the<a name="line.2833"></a>
-<span class="sourceLineNo">2834</span>   * tests referring this should not assume that the cluster is a mini cluster or a<a name="line.2834"></a>
-<span class="sourceLineNo">2835</span>   * distributed one. If the test only works on a mini cluster, then specific<a name="line.2835"></a>
-<span class="sourceLineNo">2836</span>   * method {@link #getMiniHBaseCluster()} can be used instead w/o the<a name="line.2836"></a>
-<span class="sourceLineNo">2837</span>   * need to type-cast.<a name="line.2837"></a>
-<span class="sourceLineNo">2838</span>   */<a name="line.2838"></a>
-<span class="sourceLineNo">2839</span>  public HBaseCluster getHBaseClusterInterface() {<a name="line.2839"></a>
-<span class="sourceLineNo">2840</span>    //implementation note: we should rename this method as #getHBaseCluster(),<a name="line.2840"></a>
-<span class="sourceLineNo">2841</span>    //but this would require refactoring 90+ calls.<a name="line.2841"></a>
-<span class="sourceLineNo">2842</span>    return hbaseCluster;<a name="line.2842"></a>
-<span class="sourceLineNo">2843</span>  }<a name="line.2843"></a>
-<span class="sourceLineNo">2844</span><a name="line.2844"></a>
-<span class="sourceLineNo">2845</span>  /**<a name="line.2845"></a>
-<span class="sourceLineNo">2846</span>   * Get a Connection to the cluster.<a name="line.2846"></a>
-<span class="sourceLineNo">2847</span>   * Not thread-safe (This class needs a lot of work to make it thread-safe).<a name="line.2847"></a>
-<span class="sourceLineNo">2848</span>   * @return A Connection that can be shared. Don't close. Will be closed on shutdown of cluster.<a name="line.2848"></a>
-<span class="sourceLineNo">2849</span>   * @throws IOException<a name="line.2849"></a>
-<span class="sourceLineNo">2850</span>   */<a name="line.2850"></a>
-<span class="sourceLineNo">2851</span>  public Connection getConnection() throws IOException {<a name="line.2851"></a>
-<span class="sourceLineNo">2852</span>    if (this.connection == null) {<a name="line.2852"></a>
-<span class="sourceLineNo">2853</span>      this.connection = ConnectionFactory.createConnection(this.conf);<a name="line.2853"></a>
-<span class="sourceLineNo">2854</span>    }<a name="line.2854"></a>
-<span class="sourceLineNo">2855</span>    return this.connection;<a name="line.2855"></a>
-<span class="sourceLineNo">2856</span>  }<a name="line.2856"></a>
-<span class="sourceLineNo">2857</span><a name="line.2857"></a>
-<span class="sourceLineNo">2858</span>  /**<a name="line.2858"></a>
-<span class="sourceLineNo">2859</span>   * Returns a Admin instance.<a name="line.2859"></a>
-<span class="sourceLineNo">2860</span>   * This instance is shared between HBaseTestingUtility instance users. Closing it has no effect,<a name="line.2860"></a>
-<span class="sourceLineNo">2861</span>   * it will be closed automatically when the cluster shutdowns<a name="line.2861"></a>
-<span class="sourceLineNo">2862</span>   *<a name="line.2862"></a>
-<span class="sourceLineNo">2863</span>   * @return HBaseAdmin instance which is guaranteed to support only {@link Admin} interface.<a name="line.2863"></a>
-<span class="sourceLineNo">2864</span>   *   Functions in HBaseAdmin not provided by {@link Admin} interface can be changed/deleted<a name="line.2864"></a>
-<span class="sourceLineNo">2865</span>   *   anytime.<a name="line.2865"></a>
-<span class="sourceLineNo">2866</span>   * @deprecated Since 2.0. Will be removed in 3.0. Use {@link #getAdmin()} instead.<a name="line.2866"></a>
-<span class="sourceLineNo">2867</span>   */<a name="line.2867"></a>
-<span class="sourceLineNo">2868</span>  @Deprecated<a name="line.2868"></a>
-<span class="sourceLineNo">2869</span>  public synchronized HBaseAdmin getHBaseAdmin()<a name="line.2869"></a>
-<span class="sourceLineNo">2870</span>  throws IOException {<a name="line.2870"></a>
-<span class="sourceLineNo">2871</span>    if (hbaseAdmin == null){<a name="line.2871"></a>
-<span class="sourceLineNo">2872</span>      this.hbaseAdmin = (HBaseAdmin) getConnection().getAdmin();<a name="line.2872"></a>
-<span class="sourceLineNo">2873</span>    }<a name="line.2873"></a>
-<span class="sourceLineNo">2874</span>    return hbaseAdmin;<a name="line.2874"></a>
-<span class="sourceLineNo">2875</span>  }<a name="line.2875"></a>
-<span class="sourceLineNo">2876</span><a name="line.2876"></a>
-<span class="sourceLineNo">2877</span>  /**<a name="line.2877"></a>
-<span class="sourceLineNo">2878</span>   * Returns an Admin instance which is shared between HBaseTestingUtility instance users.<a name="line.2878"></a>
-<span class="sourceLineNo">2879</span>   * Closing it has no effect, it will be closed automatically when the cluster shutdowns<a name="line.2879"></a>
-<span class="sourceLineNo">2880</span>   */<a name="line.2880"></a>
-<span class="sourceLineNo">2881</span>  public synchronized Admin getAdmin() throws IOException {<a name="line.2881"></a>
-<span class="sourceLineNo">2882</span>    if (hbaseAdmin == null){<a name="line.2882"></a>
-<span class="sourceLineNo">2883</span>      this.hbaseAdmin = (HBaseAdmin) getConnection().getAdmin();<a name="line.2883"></a>
-<span class="sourceLineNo">2884</span>    }<a name="line.2884"></a>
-<span class="sourceLineNo">2885</span>    return hbaseAdmin;<a name="line.2885"></a>
-<span class="sourceLineNo">2886</span>  }<a name="line.2886"></a>
-<span class="sourceLineNo">2887</span><a name="line.2887"></a>
-<span class="sourceLineNo">2888</span>  private HBaseAdmin hbaseAdmin = null;<a name="line.2888"></a>
-<span class="sourceLineNo">2889</span><a name="line.2889"></a>
-<span class="sourceLineNo">2890</span>  /**<a name="line.2890"></a>
-<span class="sourceLineNo">2891</span>   * Returns a ZKWatcher instance.<a name="line.2891"></a>
-<span class="sourceLineNo">2892</span>   * This instance is shared between HBaseTestingUtility instance users.<a name="line.2892"></a>
-<span class="sourceLineNo">2893</span>   * Don't close it, it will be closed automatically when the<a name="line.2893"></a>
-<span class="sourceLineNo">2894</span>   * cluster shutdowns<a name="line.2894"></a>
-<span class="sourceLineNo">2895</span>   *<a name="line.2895"></a>
-<span class="sourceLineNo">2896</span>   * @return The ZKWatcher instance.<a name="line.2896"></a>
-<span class="sourceLineNo">2897</span>   * @throws IOException<a name="line.2897"></a>
-<span class="sourceLineNo">2898</span>   */<a name="line.2898"></a>
-<span class="sourceLineNo">2899</span>  public synchronized ZKWatcher getZooKeeperWatcher()<a name="line.2899"></a>
-<span class="sourceLineNo">2900</span>    throws IOException {<a name="line.2900"></a>
-<span class="sourceLineNo">2901</span>    if (zooKeeperWatcher == null) {<a name="line.2901"></a>
-<span class="sourceLineNo">2902</span>      zooKeeperWatcher = new ZKWatcher(conf, "testing utility",<a name="line.2902"></a>
-<span class="sourceLineNo">2903</span>        new Abortable() {<a name="line.2903"></a>
-<span class="sourceLineNo">2904</span>        @Override public void abort(String why, Throwable e) {<a name="line.2904"></a>
-<span class="sourceLineNo">2905</span>          throw new RuntimeException("Unexpected abort in HBaseTestingUtility:"+why, e);<a name="line.2905"></a>
-<span class="sourceLineNo">2906</span>        }<a name="line.2906"></a>
-<span class="sourceLineNo">2907</span>        @Override public boolean isAborted() {return false;}<a name="line.2907"></a>
-<span class="sourceLineNo">2908</span>      });<a name="line.2908"></a>
-<span class="sourceLineNo">2909</span>    }<a name="line.2909"></a>
-<span class="sourceLineNo">2910</span>    return zooKeeperWatcher;<a name="line.2910"></a>
-<span class="sourceLineNo">2911</span>  }<a name="line.2911"></a>
-<span class="sourceLineNo">2912</span>  private ZKWatcher zooKeeperWatcher;<a name="line.2912"></a>
-<span class="sourceLineNo">2913</span><a name="line.2913"></a>
-<span class="sourceLineNo">2914</span><a name="line.2914"></a>
-<span class="sourceLineNo">2915</span><a name="line.2915"></a>
-<span class="sourceLineNo">2916</span>  /**<a name="line.2916"></a>
-<span class="sourceLineNo">2917</span>   * Unassign the named region.<a name="line.2917"></a>
-<span class="sourceLineNo">2918</span>   *<a name="line.2918"></a>
-<span class="sourceLineNo">2919</span>   * @param regionName  The region to unassign.<a name="line.2919"></a>
-<span class="sourceLineNo">2920</span>   */<a name="line.2920"></a>
-<span class="sourceLineNo">2921</span>  public void unassignRegion(String regionName) throws IOException {<a name="line.2921"></a>
-<span class="sourceLineNo">2922</span>    unassignRegion(Bytes.toBytes(regionName));<a name="line.2922"></a>
-<span class="sourceLineNo">2923</span>  }<a name="line.2923"></a>
-<span class="sourceLineNo">2924</span><a name="line.2924"></a>
-<span class="sourceLineNo">2925</span>  /**<a name="line.2925"></a>
-<span class="sourceLineNo">2926</span>   * Unassign the named region.<a name="line.2926"></a>
-<span class="sourceLineNo">2927</span>   *<a name="line.2927"></a>
-<span class="sourceLineNo">2928</span>   * @param regionName  The region to unassign.<a name="line.2928"></a>
-<span class="sourceLineNo">2929</span>   */<a name="line.2929"></a>
-<span class="sourceLineNo">2930</span>  public void unassignRegion(byte[] regionName) throws IOException {<a name="line.2930"></a>
-<span class="sourceLineNo">2931</span>    getAdmin().unassign(regionName, true);<a name="line.2931"></a>
-<span class="sourceLineNo">2932</span>  }<a name="line.2932"></a>
-<span class="sourceLineNo">2933</span><a name="line.2933"></a>
-<span class="sourceLineNo">2934</span>  /**<a name="line.2934"></a>
-<span class="sourceLineNo">2935</span>   * Closes the region containing the given row.<a name="line.2935"></a>
-<span class="sourceLineNo">2936</span>   *<a name="line.2936"></a>
-<span class="sourceLineNo">2937</span>   * @param row  The row to find the containing region.<a name="line.2937"></a>
-<span class="sourceLineNo">2938</span>   * @param table  The table to find the region.<a name="line.2938"></a>
-<span class="sourceLineNo">2939</span>   */<a name="line.2939"></a>
-<span class="sourceLineNo">2940</span>  public void unassignRegionByRow(String row, RegionLocator table) throws IOException {<a name="line.2940"></a>
-<span class="sourceLineNo">2941</span>    unassignRegionByRow(Bytes.toBytes(row), table);<a name="line.2941"></a>
-<span class="sourceLineNo">2942</span>  }<a name="line.2942"></a>
-<span class="sourceLineNo">2943</span><a name="line.2943"></a>
-<span class="sourceLineNo">2944</span>  /**<a name="line.2944"></a>
-<span class="sourceLineNo">2945</span>   * Closes the region containing the given row.<a name="line.2945"></a>
-<span class="sourceLineNo">2946</span>   *<a name="line.2946"></a>
-<span class="sourceLineNo">2947</span>   * @param row  The row to find the containing region.<a name="line.2947"></a>
-<span class="sourceLineNo">2948</span>   * @param table  The table to find the region.<a name="line.2948"></a>
-<span class="sourceLineNo">2949</span>   * @throws IOException<a name="line.2949"></a>
-<span class="sourceLineNo">2950</span>   */<a name="line.2950"></a>
-<span class="sourceLineNo">2951</span>  public void unassignRegionByRow(byte[] row, RegionLocator table) throws IOException {<a name="line.2951"></a>
-<span class="sourceLineNo">2952</span>    HRegionLocation hrl = table.getRegionLocation(row);<a name="line.2952"></a>
-<span class="sourceLineNo">2953</span>    unassignRegion(hrl.getRegionInfo().getRegionName());<a name="line.2953"></a>
-<span class="sourceLineNo">2954</span>  }<a name="line.2954"></a>
-<span class="sourceLineNo">2955</span><a name="line.2955"></a>
-<span class="sourceLineNo">2956</span>  /*<a name="line.2956"></a>
-<span class="sourceLineNo">2957</span>   * Retrieves a splittable region randomly from tableName<a name="line.2957"></a>
-<span class="sourceLineNo">2958</span>   *<a name="line.2958"></a>
-<span class="sourceLineNo">2959</span>   * @param tableName name of table<a name="line.2959"></a>
-<span class="sourceLineNo">2960</span>   * @param maxAttempts maximum number of attempts, unlimited for value of -1<a name="line.2960"></a>
-<span class="sourceLineNo">2961</span>   * @return the HRegion chosen, null if none was found within limit of maxAttempts<a name="line.2961"></a>
-<span class="sourceLineNo">2962</span>   */<a name="line.2962"></a>
-<span class="sourceLineNo">2963</span>  public HRegion getSplittableRegion(TableName tableName, int maxAttempts) {<a name="line.2963"></a>
-<span class="sourceLineNo">2964</span>    List&lt;HRegion&gt; regions = getHBaseCluster().getRegions(tableName);<a name="line.2964"></a>
-<span class="sourceLineNo">2965</span>    int regCount = regions.size();<a name="line.2965"></a>
-<span class="sourceLineNo">2966</span>    Set&lt;Integer&gt; attempted = new HashSet&lt;&gt;();<a name="line.2966"></a>
-<span class="sourceLineNo">2967</span>    int idx;<a name="line.2967"></a>
-<span class="sourceLineNo">2968</span>    int attempts = 0;<a name="line.2968"></a>
-<span class="sourceLineNo">2969</span>    do {<a name="line.2969"></a>
-<span class="sourceLineNo">2970</span>      regions = getHBaseCluster().getRegions(tableName);<a name="line.2970"></a>
-<span class="sourceLineNo">2971</span>      if (regCount != regions.size()) {<a name="line.2971"></a>
-<span class="sourceLineNo">2972</span>        // if there was region movement, clear attempted Set<a name="line.2972"></a>
-<span class="sourceLineNo">2973</span>        attempted.clear();<a name="line.2973"></a>
-<span class="sourceLineNo">2974</span>      }<a name="line.2974"></a>
-<span class="sourceLineNo">2975</span>      regCount = regions.size();<a name="line.2975"></a>
-<span class="sourceLineNo">2976</span>      // There are chances that before we get the region for the table from an RS the region may<a name="line.2976"></a>
-<span class="sourceLineNo">2977</span>      // be going for CLOSE.  This may be because online schema change is enabled<a name="line.2977"></a>
-<span class="sourceLineNo">2978</span>      if (regCount &gt; 0) {<a name="line.2978"></a>
-<span class="sourceLineNo">2979</span>        idx = random.nextInt(regCount);<a name="line.2979"></a>
-<span class="sourceLineNo">2980</span>        // if we have just tried this region, there is no need to try again<a name="line.2980"></a>
-<span class="sourceLineNo">2981</span>        if (attempted.contains(idx))<a name="line.2981"></a>
-<span class="sourceLineNo">2982</span>          continue;<a name="line.2982"></a>
-<span class="sourceLineNo">2983</span>        try {<a name="line.2983"></a>
-<span class="sourceLineNo">2984</span>          regions.get(idx).checkSplit();<a name="line.2984"></a>
-<span class="sourceLineNo">2985</span>          return regions.get(idx);<a name="line.2985"></a>
-<span class="sourceLineNo">2986</span>        } catch (Exception ex) {<a name="line.2986"></a>
-<span class="sourceLineNo">2987</span>          LOG.warn("Caught exception", ex);<a name="line.2987"></a>
-<span class="sourceLineNo">2988</span>          attempted.add(idx);<a name="line.2988"></a>
-<span class="sourceLineNo">2989</span>        }<a name="line.2989"></a>
-<span class="sourceLineNo">2990</span>      }<a name="line.2990"></a>
-<span class="sourceLineNo">2991</span>      attempts++;<a name="line.2991"></a>
-<span class="sourceLineNo">2992</span>    } while (maxAttempts == -1 || attempts &lt; maxAttempts);<a name="line.2992"></a>
-<span class="sourceLineNo">2993</span>    return null;<a name="line.2993"></a>
-<span class="sourceLineNo">2994</span>  }<a name="line.2994"></a>
-<span class="sourceLineNo">2995</span><a name="line.2995"></a>
-<span class="sourceLineNo">2996</span>  public MiniZooKeeperCluster getZkCluster() {<a name="line.2996"></a>
-<span class="sourceLineNo">2997</span>    return zkCluster;<a name="line.2997"></a>
-<span class="sourceLineNo">2998</span>  }<a name="line.2998"></a>
-<span class="sourceLineNo">2999</span><a name="line.2999"></a>
-<span class="sourceLineNo">3000</span>  public void setZkCluster(MiniZooKeeperCluster zkCluster) {<a name="line.3000"></a>
-<span class="sourceLineNo">3001</span>    this.passedZkCluster = true;<a name="line.3001"></a>
-<span class="sourceLineNo">3002</span>    this.zkCluster = zkCluster;<a name="line.3002"></a>
-<span class="sourceLineNo">3003</span>    conf.setInt(HConstants.ZOOKEEPER_CLIENT_PORT, zkCluster.getClientPort());<a name="line.3003"></a>
-<span class="sourceLineNo">3004</span>  }<a name="line.3004"></a>
-<span class="sourceLineNo">3005</span><a name="line.3005"></a>
-<span class="sourceLineNo">3006</span>  public MiniDFSCluster getDFSCluster() {<a name="line.3006"></a>
-<span class="sourceLineNo">3007</span>    return dfsCluster;<a name="line.3007"></a>
-<span class="sourceLineNo">3008</span>  }<a name="line.3008"></a>
-<span class="sourceLineNo">3009</span><a name="line.3009"></a>
-<span class="sourceLineNo">3010</span>  public void setDFSCluster(MiniDFSCluster cluster) throws IllegalStateException, IOException {<a name="line.3010"></a>
-<span class="sourceLineNo">3011</span>    setDFSCluster(cluster, true);<a name="line.3011"></a>
-<span class="sourceLineNo">3012</span>  }<a name="line.3012"></a>
-<span class="sourceLineNo">3013</span><a name="line.3013"></a>
-<span class="sourceLineNo">3014</span>  /**<a name="line.3014"></a>
-<span class="sourceLineNo">3015</span>   * Set the MiniDFSCluster<a name="line.3015"></a>
-<span class="sourceLineNo">3016</span>   * @param cluster cluster to use<a name="line.3016"></a>
-<span class="sourceLineNo">3017</span>   * @param requireDown require the that cluster not be "up" (MiniDFSCluster#isClusterUp) before<a name="line.3017"></a>
-<span class="sourceLineNo">3018</span>   * it is set.<a name="line.3018"></a>
-<span class="sourceLineNo">3019</span>   * @throws IllegalStateException if the passed cluster is up when it is required to be down<a name="line.3019"></a>
-<span class="sourceLineNo">3020</span>   * @throws IOException if the FileSystem could not be set from the passed dfs cluster<a name="line.3020"></a>
-<span class="sourceLineNo">3021</span>   */<a name="line.3021"></a>
-<span class="sourceLineNo">3022</span>  public void setDFSCluster(MiniDFSCluster cluster, boolean requireDown)<a name="line.3022"></a>
-<span class="sourceLineNo">3023</span>      throws IllegalStateException, IOException {<a name="line.3023"></a>
-<span class="sourceLineNo">3024</span>    if (dfsCluster != null &amp;&amp; requireDown &amp;&amp; dfsCluster.isClusterUp()) {<a name="line.3024"></a>
-<span class="sourceLineNo">3025</span>      throw new IllegalStateException("DFSCluster is already running! Shut it down first.");<a name="line.3025"></a>
-<span class="sourceLineNo">3026</span>    }<a name="line.3026"></a>
-<span class="sourceLineNo">3027</span>    this.dfsCluster = cluster;<a name="line.3027"></a>
-<span class="sourceLineNo">3028</span>    this.setFs();<a name="line.3028"></a>
-<span class="sourceLineNo">3029</span>  }<a name="line.3029"></a>
-<span class="sourceLineNo">3030</span><a name="line.3030"></a>
-<span class="sourceLineNo">3031</span>  public FileSystem getTestFileSystem() throws IOException {<a name="line.3031"></a>
-<span class="sourceLineNo">3032</span>    return HFileSystem.get(conf);<a name="line.3032"></a>
-<span class="sourceLineNo">3033</span>  }<a name="line.3033"></a>
-<span class="sourceLineNo">3034</span><a name="line.3034"></a>
-<span class="sourceLineNo">3035</span>  /**<a name="line.3035"></a>
-<span class="sourceLineNo">3036</span>   * Wait until all regions in a table have been assigned.  Waits default timeout before giving up<a name="line.3036"></a>
-<span class="sourceLineNo">3037</span>   * (30 seconds).<a name="line.3037"></a>
-<span class="sourceLineNo">3038</span>   * @param table Table to wait on.<a name="line.3038"></a>
-<span class="sourceLineNo">3039</span>   * @throws InterruptedException<a name="line.3039"></a>
-<span class="sourceLineNo">3040</span>   * @throws IOException<a name="line.3040"></a>
-<span class="sourceLineNo">3041</span>   */<a name="line.3041"></a>
-<span class="sourceLineNo">3042</span>  public void waitTableAvailable(TableName table)<a name="line.3042"></a>
-<span class="sourceLineNo">3043</span>      throws InterruptedException, IOException {<a name="line.3043"></a>
-<span class="sourceLineNo">3044</span>    waitTableAvailable(table.getName(), 30000);<a name="line.3044"></a>
-<span class="sourceLineNo">3045</span>  }<a name="line.3045"></a>
-<span class="sourceLineNo">3046</span><a name="line.3046"></a>
-<span class="sourceLineNo">3047</span>  public void waitTableAvailable(TableName table, long timeoutMillis)<a name="line.3047"></a>
-<span class="sourceLineNo">3048</span>      throws InterruptedException, IOException {<a name="line.3048"></a>
-<span class="sourceLineNo">3049</span>    waitFor(timeoutMillis, predicateTableAvailable(table));<a name="line.3049"></a>
-<span class="sourceLineNo">3050</span>  }<a name="line.3050"></a>
-<span class="sourceLineNo">3051</span><a name="line.3051"></a>
-<span class="sourceLineNo">3052</span>  /**<a name="line.3052"></a>
-<span class="sourceLineNo">3053</span>   * Wait until all regions in a table have been assigned<a name="line.3053"></a>
-<span class="sourceLineNo">3054</span>   * @param table Table to wait on.<a name="line.3054"></a>
-<span class="sourceLineNo">3055</span>   * @param timeoutMillis Timeout.<a name="line.3055"></a>
-<span class="sourceLineNo">3056</span>   * @throws InterruptedException<a name="line.3056"></a>
-<span class="sourceLineNo">3057</span>   * @throws IOException<a name="line.3057"></a>
-<span class="sourceLineNo">3058</span>   */<a name="line.3058"></a>
-<span class="sourceLineNo">3059</span>  public void waitTableAvailable(byte[] table, long timeoutMillis)<a name="line.3059"></a>
-<span class="sourceLineNo">3060</span>  throws InterruptedException, IOException {<a name="line.3060"></a>
-<span class="sourceLineNo">3061</span>    waitFor(timeoutMillis, predicateTableAvailable(TableName.valueOf(table)));<a name="line.3061"></a>
-<span class="sourceLineNo">3062</span>  }<a name="line.3062"></a>
-<span class="sourceLineNo">3063</span><a name="line.3063"></a>
-<span class="sourceLineNo">3064</span>  public String explainTableAvailability(TableName tableName) throws IOException {<a name="line.3064"></a>
-<span class="sourceLineNo">3065</span>    String msg = explainTableState(tableName, TableState.State.ENABLED) + ", ";<a name="line.3065"></a>
-<span class="sourceLineNo">3066</span>    if (getHBaseCluster().getMaster().isAlive()) {<a name="line.3066"></a>
-<span class="sourceLineNo">3067</span>      Map&lt;RegionInfo, ServerName&gt; assignments =<a name="line.3067"></a>
-<span class="sourceLineNo">3068</span>          getHBaseCluster().getMaster().getAssignmentManager().getRegionStates()<a name="line.3068"></a>
-<span class="sourceLineNo">3069</span>              .getRegionAssignments();<a name="line.3069"></a>
-<span class="sourceLineNo">3070</span>      final List&lt;Pair&lt;RegionInfo, ServerName&gt;&gt; metaLocations =<a name="line.3070"></a>
-<span class="sourceLineNo">3071</span>          MetaTableAccessor.getTableRegionsAndLocations(connection, tableName);<a name="line.3071"></a>
-<span class="sourceLineNo">3072</span>      for (Pair&lt;RegionInfo, ServerName&gt; metaLocation : metaLocations) {<a name="line.3072"></a>
-<span class="sourceLineNo">3073</span>        RegionInfo hri = metaLocation.getFirst();<a name="line.3073"></a>
-<span class="sourceLineNo">3074</span>        ServerName sn = metaLocation.getSecond();<a name="line.3074"></a>
-<span class="sourceLineNo">3075</span>        if (!assignments.containsKey(hri)) {<a name="line.3075"></a>
-<span class="sourceLineNo">3076</span>          msg += ", region " + hri<a name="line.307

<TRUNCATED>

[02/14] hbase-site git commit: Published site at .

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html b/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html
index 0cec549..06b92ba 100644
--- a/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html
+++ b/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html
@@ -2518,1796 +2518,1811 @@
 <span class="sourceLineNo">2510</span>    return rows;<a name="line.2510"></a>
 <span class="sourceLineNo">2511</span>  }<a name="line.2511"></a>
 <span class="sourceLineNo">2512</span><a name="line.2512"></a>
-<span class="sourceLineNo">2513</span>  /**<a name="line.2513"></a>
-<span class="sourceLineNo">2514</span>   * Tool to get the reference to the region server object that holds the<a name="line.2514"></a>
-<span class="sourceLineNo">2515</span>   * region of the specified user table.<a name="line.2515"></a>
-<span class="sourceLineNo">2516</span>   * It first searches for the meta rows that contain the region of the<a name="line.2516"></a>
-<span class="sourceLineNo">2517</span>   * specified table, then gets the index of that RS, and finally retrieves<a name="line.2517"></a>
-<span class="sourceLineNo">2518</span>   * the RS's reference.<a name="line.2518"></a>
-<span class="sourceLineNo">2519</span>   * @param tableName user table to lookup in hbase:meta<a name="line.2519"></a>
-<span class="sourceLineNo">2520</span>   * @return region server that holds it, null if the row doesn't exist<a name="line.2520"></a>
-<span class="sourceLineNo">2521</span>   * @throws IOException<a name="line.2521"></a>
-<span class="sourceLineNo">2522</span>   * @throws InterruptedException<a name="line.2522"></a>
-<span class="sourceLineNo">2523</span>   */<a name="line.2523"></a>
-<span class="sourceLineNo">2524</span>  public HRegionServer getRSForFirstRegionInTable(TableName tableName)<a name="line.2524"></a>
-<span class="sourceLineNo">2525</span>      throws IOException, InterruptedException {<a name="line.2525"></a>
-<span class="sourceLineNo">2526</span>    List&lt;byte[]&gt; metaRows = getMetaTableRows(tableName);<a name="line.2526"></a>
-<span class="sourceLineNo">2527</span>    if (metaRows == null || metaRows.isEmpty()) {<a name="line.2527"></a>
-<span class="sourceLineNo">2528</span>      return null;<a name="line.2528"></a>
-<span class="sourceLineNo">2529</span>    }<a name="line.2529"></a>
-<span class="sourceLineNo">2530</span>    LOG.debug("Found " + metaRows.size() + " rows for table " +<a name="line.2530"></a>
-<span class="sourceLineNo">2531</span>      tableName);<a name="line.2531"></a>
-<span class="sourceLineNo">2532</span>    byte [] firstrow = metaRows.get(0);<a name="line.2532"></a>
-<span class="sourceLineNo">2533</span>    LOG.debug("FirstRow=" + Bytes.toString(firstrow));<a name="line.2533"></a>
-<span class="sourceLineNo">2534</span>    long pause = getConfiguration().getLong(HConstants.HBASE_CLIENT_PAUSE,<a name="line.2534"></a>
-<span class="sourceLineNo">2535</span>      HConstants.DEFAULT_HBASE_CLIENT_PAUSE);<a name="line.2535"></a>
-<span class="sourceLineNo">2536</span>    int numRetries = getConfiguration().getInt(HConstants.HBASE_CLIENT_RETRIES_NUMBER,<a name="line.2536"></a>
-<span class="sourceLineNo">2537</span>      HConstants.DEFAULT_HBASE_CLIENT_RETRIES_NUMBER);<a name="line.2537"></a>
-<span class="sourceLineNo">2538</span>    RetryCounter retrier = new RetryCounter(numRetries+1, (int)pause, TimeUnit.MICROSECONDS);<a name="line.2538"></a>
-<span class="sourceLineNo">2539</span>    while(retrier.shouldRetry()) {<a name="line.2539"></a>
-<span class="sourceLineNo">2540</span>      int index = getMiniHBaseCluster().getServerWith(firstrow);<a name="line.2540"></a>
-<span class="sourceLineNo">2541</span>      if (index != -1) {<a name="line.2541"></a>
-<span class="sourceLineNo">2542</span>        return getMiniHBaseCluster().getRegionServerThreads().get(index).getRegionServer();<a name="line.2542"></a>
-<span class="sourceLineNo">2543</span>      }<a name="line.2543"></a>
-<span class="sourceLineNo">2544</span>      // Came back -1.  Region may not be online yet.  Sleep a while.<a name="line.2544"></a>
-<span class="sourceLineNo">2545</span>      retrier.sleepUntilNextRetry();<a name="line.2545"></a>
-<span class="sourceLineNo">2546</span>    }<a name="line.2546"></a>
-<span class="sourceLineNo">2547</span>    return null;<a name="line.2547"></a>
-<span class="sourceLineNo">2548</span>  }<a name="line.2548"></a>
-<span class="sourceLineNo">2549</span><a name="line.2549"></a>
-<span class="sourceLineNo">2550</span>  /**<a name="line.2550"></a>
-<span class="sourceLineNo">2551</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt; with a default number of<a name="line.2551"></a>
-<span class="sourceLineNo">2552</span>   * &lt;code&gt;TaskTracker&lt;/code&gt;'s.<a name="line.2552"></a>
-<span class="sourceLineNo">2553</span>   *<a name="line.2553"></a>
-<span class="sourceLineNo">2554</span>   * @throws IOException When starting the cluster fails.<a name="line.2554"></a>
-<span class="sourceLineNo">2555</span>   */<a name="line.2555"></a>
-<span class="sourceLineNo">2556</span>  public MiniMRCluster startMiniMapReduceCluster() throws IOException {<a name="line.2556"></a>
-<span class="sourceLineNo">2557</span>    // Set a very high max-disk-utilization percentage to avoid the NodeManagers from failing.<a name="line.2557"></a>
-<span class="sourceLineNo">2558</span>    conf.setIfUnset(<a name="line.2558"></a>
-<span class="sourceLineNo">2559</span>        "yarn.nodemanager.disk-health-checker.max-disk-utilization-per-disk-percentage",<a name="line.2559"></a>
-<span class="sourceLineNo">2560</span>        "99.0");<a name="line.2560"></a>
-<span class="sourceLineNo">2561</span>    startMiniMapReduceCluster(2);<a name="line.2561"></a>
-<span class="sourceLineNo">2562</span>    return mrCluster;<a name="line.2562"></a>
+<span class="sourceLineNo">2513</span>  /*<a name="line.2513"></a>
+<span class="sourceLineNo">2514</span>   * Find any other region server which is different from the one identified by parameter<a name="line.2514"></a>
+<span class="sourceLineNo">2515</span>   * @param rs<a name="line.2515"></a>
+<span class="sourceLineNo">2516</span>   * @return another region server<a name="line.2516"></a>
+<span class="sourceLineNo">2517</span>   */<a name="line.2517"></a>
+<span class="sourceLineNo">2518</span>  public HRegionServer getOtherRegionServer(HRegionServer rs) {<a name="line.2518"></a>
+<span class="sourceLineNo">2519</span>    for (JVMClusterUtil.RegionServerThread rst :<a name="line.2519"></a>
+<span class="sourceLineNo">2520</span>      getMiniHBaseCluster().getRegionServerThreads()) {<a name="line.2520"></a>
+<span class="sourceLineNo">2521</span>      if (!(rst.getRegionServer() == rs)) {<a name="line.2521"></a>
+<span class="sourceLineNo">2522</span>        return rst.getRegionServer();<a name="line.2522"></a>
+<span class="sourceLineNo">2523</span>      }<a name="line.2523"></a>
+<span class="sourceLineNo">2524</span>    }<a name="line.2524"></a>
+<span class="sourceLineNo">2525</span>    return null;<a name="line.2525"></a>
+<span class="sourceLineNo">2526</span>  }<a name="line.2526"></a>
+<span class="sourceLineNo">2527</span><a name="line.2527"></a>
+<span class="sourceLineNo">2528</span>  /**<a name="line.2528"></a>
+<span class="sourceLineNo">2529</span>   * Tool to get the reference to the region server object that holds the<a name="line.2529"></a>
+<span class="sourceLineNo">2530</span>   * region of the specified user table.<a name="line.2530"></a>
+<span class="sourceLineNo">2531</span>   * It first searches for the meta rows that contain the region of the<a name="line.2531"></a>
+<span class="sourceLineNo">2532</span>   * specified table, then gets the index of that RS, and finally retrieves<a name="line.2532"></a>
+<span class="sourceLineNo">2533</span>   * the RS's reference.<a name="line.2533"></a>
+<span class="sourceLineNo">2534</span>   * @param tableName user table to lookup in hbase:meta<a name="line.2534"></a>
+<span class="sourceLineNo">2535</span>   * @return region server that holds it, null if the row doesn't exist<a name="line.2535"></a>
+<span class="sourceLineNo">2536</span>   * @throws IOException<a name="line.2536"></a>
+<span class="sourceLineNo">2537</span>   * @throws InterruptedException<a name="line.2537"></a>
+<span class="sourceLineNo">2538</span>   */<a name="line.2538"></a>
+<span class="sourceLineNo">2539</span>  public HRegionServer getRSForFirstRegionInTable(TableName tableName)<a name="line.2539"></a>
+<span class="sourceLineNo">2540</span>      throws IOException, InterruptedException {<a name="line.2540"></a>
+<span class="sourceLineNo">2541</span>    List&lt;byte[]&gt; metaRows = getMetaTableRows(tableName);<a name="line.2541"></a>
+<span class="sourceLineNo">2542</span>    if (metaRows == null || metaRows.isEmpty()) {<a name="line.2542"></a>
+<span class="sourceLineNo">2543</span>      return null;<a name="line.2543"></a>
+<span class="sourceLineNo">2544</span>    }<a name="line.2544"></a>
+<span class="sourceLineNo">2545</span>    LOG.debug("Found " + metaRows.size() + " rows for table " +<a name="line.2545"></a>
+<span class="sourceLineNo">2546</span>      tableName);<a name="line.2546"></a>
+<span class="sourceLineNo">2547</span>    byte [] firstrow = metaRows.get(0);<a name="line.2547"></a>
+<span class="sourceLineNo">2548</span>    LOG.debug("FirstRow=" + Bytes.toString(firstrow));<a name="line.2548"></a>
+<span class="sourceLineNo">2549</span>    long pause = getConfiguration().getLong(HConstants.HBASE_CLIENT_PAUSE,<a name="line.2549"></a>
+<span class="sourceLineNo">2550</span>      HConstants.DEFAULT_HBASE_CLIENT_PAUSE);<a name="line.2550"></a>
+<span class="sourceLineNo">2551</span>    int numRetries = getConfiguration().getInt(HConstants.HBASE_CLIENT_RETRIES_NUMBER,<a name="line.2551"></a>
+<span class="sourceLineNo">2552</span>      HConstants.DEFAULT_HBASE_CLIENT_RETRIES_NUMBER);<a name="line.2552"></a>
+<span class="sourceLineNo">2553</span>    RetryCounter retrier = new RetryCounter(numRetries+1, (int)pause, TimeUnit.MICROSECONDS);<a name="line.2553"></a>
+<span class="sourceLineNo">2554</span>    while(retrier.shouldRetry()) {<a name="line.2554"></a>
+<span class="sourceLineNo">2555</span>      int index = getMiniHBaseCluster().getServerWith(firstrow);<a name="line.2555"></a>
+<span class="sourceLineNo">2556</span>      if (index != -1) {<a name="line.2556"></a>
+<span class="sourceLineNo">2557</span>        return getMiniHBaseCluster().getRegionServerThreads().get(index).getRegionServer();<a name="line.2557"></a>
+<span class="sourceLineNo">2558</span>      }<a name="line.2558"></a>
+<span class="sourceLineNo">2559</span>      // Came back -1.  Region may not be online yet.  Sleep a while.<a name="line.2559"></a>
+<span class="sourceLineNo">2560</span>      retrier.sleepUntilNextRetry();<a name="line.2560"></a>
+<span class="sourceLineNo">2561</span>    }<a name="line.2561"></a>
+<span class="sourceLineNo">2562</span>    return null;<a name="line.2562"></a>
 <span class="sourceLineNo">2563</span>  }<a name="line.2563"></a>
 <span class="sourceLineNo">2564</span><a name="line.2564"></a>
 <span class="sourceLineNo">2565</span>  /**<a name="line.2565"></a>
-<span class="sourceLineNo">2566</span>   * Tasktracker has a bug where changing the hadoop.log.dir system property<a name="line.2566"></a>
-<span class="sourceLineNo">2567</span>   * will not change its internal static LOG_DIR variable.<a name="line.2567"></a>
-<span class="sourceLineNo">2568</span>   */<a name="line.2568"></a>
-<span class="sourceLineNo">2569</span>  private void forceChangeTaskLogDir() {<a name="line.2569"></a>
-<span class="sourceLineNo">2570</span>    Field logDirField;<a name="line.2570"></a>
-<span class="sourceLineNo">2571</span>    try {<a name="line.2571"></a>
-<span class="sourceLineNo">2572</span>      logDirField = TaskLog.class.getDeclaredField("LOG_DIR");<a name="line.2572"></a>
-<span class="sourceLineNo">2573</span>      logDirField.setAccessible(true);<a name="line.2573"></a>
-<span class="sourceLineNo">2574</span><a name="line.2574"></a>
-<span class="sourceLineNo">2575</span>      Field modifiersField = Field.class.getDeclaredField("modifiers");<a name="line.2575"></a>
-<span class="sourceLineNo">2576</span>      modifiersField.setAccessible(true);<a name="line.2576"></a>
-<span class="sourceLineNo">2577</span>      modifiersField.setInt(logDirField, logDirField.getModifiers() &amp; ~Modifier.FINAL);<a name="line.2577"></a>
-<span class="sourceLineNo">2578</span><a name="line.2578"></a>
-<span class="sourceLineNo">2579</span>      logDirField.set(null, new File(hadoopLogDir, "userlogs"));<a name="line.2579"></a>
-<span class="sourceLineNo">2580</span>    } catch (SecurityException e) {<a name="line.2580"></a>
-<span class="sourceLineNo">2581</span>      throw new RuntimeException(e);<a name="line.2581"></a>
-<span class="sourceLineNo">2582</span>    } catch (NoSuchFieldException e) {<a name="line.2582"></a>
-<span class="sourceLineNo">2583</span>      // TODO Auto-generated catch block<a name="line.2583"></a>
-<span class="sourceLineNo">2584</span>      throw new RuntimeException(e);<a name="line.2584"></a>
-<span class="sourceLineNo">2585</span>    } catch (IllegalArgumentException e) {<a name="line.2585"></a>
-<span class="sourceLineNo">2586</span>      throw new RuntimeException(e);<a name="line.2586"></a>
-<span class="sourceLineNo">2587</span>    } catch (IllegalAccessException e) {<a name="line.2587"></a>
-<span class="sourceLineNo">2588</span>      throw new RuntimeException(e);<a name="line.2588"></a>
-<span class="sourceLineNo">2589</span>    }<a name="line.2589"></a>
-<span class="sourceLineNo">2590</span>  }<a name="line.2590"></a>
-<span class="sourceLineNo">2591</span><a name="line.2591"></a>
-<span class="sourceLineNo">2592</span>  /**<a name="line.2592"></a>
-<span class="sourceLineNo">2593</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt;. Call {@link #setFileSystemURI(String)} to use a different<a name="line.2593"></a>
-<span class="sourceLineNo">2594</span>   * filesystem.<a name="line.2594"></a>
-<span class="sourceLineNo">2595</span>   * @param servers  The number of &lt;code&gt;TaskTracker&lt;/code&gt;'s to start.<a name="line.2595"></a>
-<span class="sourceLineNo">2596</span>   * @throws IOException When starting the cluster fails.<a name="line.2596"></a>
-<span class="sourceLineNo">2597</span>   */<a name="line.2597"></a>
-<span class="sourceLineNo">2598</span>  private void startMiniMapReduceCluster(final int servers) throws IOException {<a name="line.2598"></a>
-<span class="sourceLineNo">2599</span>    if (mrCluster != null) {<a name="line.2599"></a>
-<span class="sourceLineNo">2600</span>      throw new IllegalStateException("MiniMRCluster is already running");<a name="line.2600"></a>
-<span class="sourceLineNo">2601</span>    }<a name="line.2601"></a>
-<span class="sourceLineNo">2602</span>    LOG.info("Starting mini mapreduce cluster...");<a name="line.2602"></a>
-<span class="sourceLineNo">2603</span>    setupClusterTestDir();<a name="line.2603"></a>
-<span class="sourceLineNo">2604</span>    createDirsAndSetProperties();<a name="line.2604"></a>
-<span class="sourceLineNo">2605</span><a name="line.2605"></a>
-<span class="sourceLineNo">2606</span>    forceChangeTaskLogDir();<a name="line.2606"></a>
-<span class="sourceLineNo">2607</span><a name="line.2607"></a>
-<span class="sourceLineNo">2608</span>    //// hadoop2 specific settings<a name="line.2608"></a>
-<span class="sourceLineNo">2609</span>    // Tests were failing because this process used 6GB of virtual memory and was getting killed.<a name="line.2609"></a>
-<span class="sourceLineNo">2610</span>    // we up the VM usable so that processes don't get killed.<a name="line.2610"></a>
-<span class="sourceLineNo">2611</span>    conf.setFloat("yarn.nodemanager.vmem-pmem-ratio", 8.0f);<a name="line.2611"></a>
-<span class="sourceLineNo">2612</span><a name="line.2612"></a>
-<span class="sourceLineNo">2613</span>    // Tests were failing due to MAPREDUCE-4880 / MAPREDUCE-4607 against hadoop 2.0.2-alpha and<a name="line.2613"></a>
-<span class="sourceLineNo">2614</span>    // this avoids the problem by disabling speculative task execution in tests.<a name="line.2614"></a>
-<span class="sourceLineNo">2615</span>    conf.setBoolean("mapreduce.map.speculative", false);<a name="line.2615"></a>
-<span class="sourceLineNo">2616</span>    conf.setBoolean("mapreduce.reduce.speculative", false);<a name="line.2616"></a>
-<span class="sourceLineNo">2617</span>    ////<a name="line.2617"></a>
-<span class="sourceLineNo">2618</span><a name="line.2618"></a>
-<span class="sourceLineNo">2619</span>    // Allow the user to override FS URI for this map-reduce cluster to use.<a name="line.2619"></a>
-<span class="sourceLineNo">2620</span>    mrCluster = new MiniMRCluster(servers,<a name="line.2620"></a>
-<span class="sourceLineNo">2621</span>      FS_URI != null ? FS_URI : FileSystem.get(conf).getUri().toString(), 1,<a name="line.2621"></a>
-<span class="sourceLineNo">2622</span>      null, null, new JobConf(this.conf));<a name="line.2622"></a>
-<span class="sourceLineNo">2623</span>    JobConf jobConf = MapreduceTestingShim.getJobConf(mrCluster);<a name="line.2623"></a>
-<span class="sourceLineNo">2624</span>    if (jobConf == null) {<a name="line.2624"></a>
-<span class="sourceLineNo">2625</span>      jobConf = mrCluster.createJobConf();<a name="line.2625"></a>
-<span class="sourceLineNo">2626</span>    }<a name="line.2626"></a>
+<span class="sourceLineNo">2566</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt; with a default number of<a name="line.2566"></a>
+<span class="sourceLineNo">2567</span>   * &lt;code&gt;TaskTracker&lt;/code&gt;'s.<a name="line.2567"></a>
+<span class="sourceLineNo">2568</span>   *<a name="line.2568"></a>
+<span class="sourceLineNo">2569</span>   * @throws IOException When starting the cluster fails.<a name="line.2569"></a>
+<span class="sourceLineNo">2570</span>   */<a name="line.2570"></a>
+<span class="sourceLineNo">2571</span>  public MiniMRCluster startMiniMapReduceCluster() throws IOException {<a name="line.2571"></a>
+<span class="sourceLineNo">2572</span>    // Set a very high max-disk-utilization percentage to avoid the NodeManagers from failing.<a name="line.2572"></a>
+<span class="sourceLineNo">2573</span>    conf.setIfUnset(<a name="line.2573"></a>
+<span class="sourceLineNo">2574</span>        "yarn.nodemanager.disk-health-checker.max-disk-utilization-per-disk-percentage",<a name="line.2574"></a>
+<span class="sourceLineNo">2575</span>        "99.0");<a name="line.2575"></a>
+<span class="sourceLineNo">2576</span>    startMiniMapReduceCluster(2);<a name="line.2576"></a>
+<span class="sourceLineNo">2577</span>    return mrCluster;<a name="line.2577"></a>
+<span class="sourceLineNo">2578</span>  }<a name="line.2578"></a>
+<span class="sourceLineNo">2579</span><a name="line.2579"></a>
+<span class="sourceLineNo">2580</span>  /**<a name="line.2580"></a>
+<span class="sourceLineNo">2581</span>   * Tasktracker has a bug where changing the hadoop.log.dir system property<a name="line.2581"></a>
+<span class="sourceLineNo">2582</span>   * will not change its internal static LOG_DIR variable.<a name="line.2582"></a>
+<span class="sourceLineNo">2583</span>   */<a name="line.2583"></a>
+<span class="sourceLineNo">2584</span>  private void forceChangeTaskLogDir() {<a name="line.2584"></a>
+<span class="sourceLineNo">2585</span>    Field logDirField;<a name="line.2585"></a>
+<span class="sourceLineNo">2586</span>    try {<a name="line.2586"></a>
+<span class="sourceLineNo">2587</span>      logDirField = TaskLog.class.getDeclaredField("LOG_DIR");<a name="line.2587"></a>
+<span class="sourceLineNo">2588</span>      logDirField.setAccessible(true);<a name="line.2588"></a>
+<span class="sourceLineNo">2589</span><a name="line.2589"></a>
+<span class="sourceLineNo">2590</span>      Field modifiersField = Field.class.getDeclaredField("modifiers");<a name="line.2590"></a>
+<span class="sourceLineNo">2591</span>      modifiersField.setAccessible(true);<a name="line.2591"></a>
+<span class="sourceLineNo">2592</span>      modifiersField.setInt(logDirField, logDirField.getModifiers() &amp; ~Modifier.FINAL);<a name="line.2592"></a>
+<span class="sourceLineNo">2593</span><a name="line.2593"></a>
+<span class="sourceLineNo">2594</span>      logDirField.set(null, new File(hadoopLogDir, "userlogs"));<a name="line.2594"></a>
+<span class="sourceLineNo">2595</span>    } catch (SecurityException e) {<a name="line.2595"></a>
+<span class="sourceLineNo">2596</span>      throw new RuntimeException(e);<a name="line.2596"></a>
+<span class="sourceLineNo">2597</span>    } catch (NoSuchFieldException e) {<a name="line.2597"></a>
+<span class="sourceLineNo">2598</span>      // TODO Auto-generated catch block<a name="line.2598"></a>
+<span class="sourceLineNo">2599</span>      throw new RuntimeException(e);<a name="line.2599"></a>
+<span class="sourceLineNo">2600</span>    } catch (IllegalArgumentException e) {<a name="line.2600"></a>
+<span class="sourceLineNo">2601</span>      throw new RuntimeException(e);<a name="line.2601"></a>
+<span class="sourceLineNo">2602</span>    } catch (IllegalAccessException e) {<a name="line.2602"></a>
+<span class="sourceLineNo">2603</span>      throw new RuntimeException(e);<a name="line.2603"></a>
+<span class="sourceLineNo">2604</span>    }<a name="line.2604"></a>
+<span class="sourceLineNo">2605</span>  }<a name="line.2605"></a>
+<span class="sourceLineNo">2606</span><a name="line.2606"></a>
+<span class="sourceLineNo">2607</span>  /**<a name="line.2607"></a>
+<span class="sourceLineNo">2608</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt;. Call {@link #setFileSystemURI(String)} to use a different<a name="line.2608"></a>
+<span class="sourceLineNo">2609</span>   * filesystem.<a name="line.2609"></a>
+<span class="sourceLineNo">2610</span>   * @param servers  The number of &lt;code&gt;TaskTracker&lt;/code&gt;'s to start.<a name="line.2610"></a>
+<span class="sourceLineNo">2611</span>   * @throws IOException When starting the cluster fails.<a name="line.2611"></a>
+<span class="sourceLineNo">2612</span>   */<a name="line.2612"></a>
+<span class="sourceLineNo">2613</span>  private void startMiniMapReduceCluster(final int servers) throws IOException {<a name="line.2613"></a>
+<span class="sourceLineNo">2614</span>    if (mrCluster != null) {<a name="line.2614"></a>
+<span class="sourceLineNo">2615</span>      throw new IllegalStateException("MiniMRCluster is already running");<a name="line.2615"></a>
+<span class="sourceLineNo">2616</span>    }<a name="line.2616"></a>
+<span class="sourceLineNo">2617</span>    LOG.info("Starting mini mapreduce cluster...");<a name="line.2617"></a>
+<span class="sourceLineNo">2618</span>    setupClusterTestDir();<a name="line.2618"></a>
+<span class="sourceLineNo">2619</span>    createDirsAndSetProperties();<a name="line.2619"></a>
+<span class="sourceLineNo">2620</span><a name="line.2620"></a>
+<span class="sourceLineNo">2621</span>    forceChangeTaskLogDir();<a name="line.2621"></a>
+<span class="sourceLineNo">2622</span><a name="line.2622"></a>
+<span class="sourceLineNo">2623</span>    //// hadoop2 specific settings<a name="line.2623"></a>
+<span class="sourceLineNo">2624</span>    // Tests were failing because this process used 6GB of virtual memory and was getting killed.<a name="line.2624"></a>
+<span class="sourceLineNo">2625</span>    // we up the VM usable so that processes don't get killed.<a name="line.2625"></a>
+<span class="sourceLineNo">2626</span>    conf.setFloat("yarn.nodemanager.vmem-pmem-ratio", 8.0f);<a name="line.2626"></a>
 <span class="sourceLineNo">2627</span><a name="line.2627"></a>
-<span class="sourceLineNo">2628</span>    jobConf.set("mapreduce.cluster.local.dir",<a name="line.2628"></a>
-<span class="sourceLineNo">2629</span>      conf.get("mapreduce.cluster.local.dir")); //Hadoop MiniMR overwrites this while it should not<a name="line.2629"></a>
-<span class="sourceLineNo">2630</span>    LOG.info("Mini mapreduce cluster started");<a name="line.2630"></a>
-<span class="sourceLineNo">2631</span><a name="line.2631"></a>
-<span class="sourceLineNo">2632</span>    // In hadoop2, YARN/MR2 starts a mini cluster with its own conf instance and updates settings.<a name="line.2632"></a>
-<span class="sourceLineNo">2633</span>    // Our HBase MR jobs need several of these settings in order to properly run.  So we copy the<a name="line.2633"></a>
-<span class="sourceLineNo">2634</span>    // necessary config properties here.  YARN-129 required adding a few properties.<a name="line.2634"></a>
-<span class="sourceLineNo">2635</span>    conf.set("mapreduce.jobtracker.address", jobConf.get("mapreduce.jobtracker.address"));<a name="line.2635"></a>
-<span class="sourceLineNo">2636</span>    // this for mrv2 support; mr1 ignores this<a name="line.2636"></a>
-<span class="sourceLineNo">2637</span>    conf.set("mapreduce.framework.name", "yarn");<a name="line.2637"></a>
-<span class="sourceLineNo">2638</span>    conf.setBoolean("yarn.is.minicluster", true);<a name="line.2638"></a>
-<span class="sourceLineNo">2639</span>    String rmAddress = jobConf.get("yarn.resourcemanager.address");<a name="line.2639"></a>
-<span class="sourceLineNo">2640</span>    if (rmAddress != null) {<a name="line.2640"></a>
-<span class="sourceLineNo">2641</span>      conf.set("yarn.resourcemanager.address", rmAddress);<a name="line.2641"></a>
-<span class="sourceLineNo">2642</span>    }<a name="line.2642"></a>
-<span class="sourceLineNo">2643</span>    String historyAddress = jobConf.get("mapreduce.jobhistory.address");<a name="line.2643"></a>
-<span class="sourceLineNo">2644</span>    if (historyAddress != null) {<a name="line.2644"></a>
-<span class="sourceLineNo">2645</span>      conf.set("mapreduce.jobhistory.address", historyAddress);<a name="line.2645"></a>
-<span class="sourceLineNo">2646</span>    }<a name="line.2646"></a>
-<span class="sourceLineNo">2647</span>    String schedulerAddress =<a name="line.2647"></a>
-<span class="sourceLineNo">2648</span>      jobConf.get("yarn.resourcemanager.scheduler.address");<a name="line.2648"></a>
-<span class="sourceLineNo">2649</span>    if (schedulerAddress != null) {<a name="line.2649"></a>
-<span class="sourceLineNo">2650</span>      conf.set("yarn.resourcemanager.scheduler.address", schedulerAddress);<a name="line.2650"></a>
-<span class="sourceLineNo">2651</span>    }<a name="line.2651"></a>
-<span class="sourceLineNo">2652</span>    String mrJobHistoryWebappAddress =<a name="line.2652"></a>
-<span class="sourceLineNo">2653</span>      jobConf.get("mapreduce.jobhistory.webapp.address");<a name="line.2653"></a>
-<span class="sourceLineNo">2654</span>    if (mrJobHistoryWebappAddress != null) {<a name="line.2654"></a>
-<span class="sourceLineNo">2655</span>      conf.set("mapreduce.jobhistory.webapp.address", mrJobHistoryWebappAddress);<a name="line.2655"></a>
-<span class="sourceLineNo">2656</span>    }<a name="line.2656"></a>
-<span class="sourceLineNo">2657</span>    String yarnRMWebappAddress =<a name="line.2657"></a>
-<span class="sourceLineNo">2658</span>      jobConf.get("yarn.resourcemanager.webapp.address");<a name="line.2658"></a>
-<span class="sourceLineNo">2659</span>    if (yarnRMWebappAddress != null) {<a name="line.2659"></a>
-<span class="sourceLineNo">2660</span>      conf.set("yarn.resourcemanager.webapp.address", yarnRMWebappAddress);<a name="line.2660"></a>
+<span class="sourceLineNo">2628</span>    // Tests were failing due to MAPREDUCE-4880 / MAPREDUCE-4607 against hadoop 2.0.2-alpha and<a name="line.2628"></a>
+<span class="sourceLineNo">2629</span>    // this avoids the problem by disabling speculative task execution in tests.<a name="line.2629"></a>
+<span class="sourceLineNo">2630</span>    conf.setBoolean("mapreduce.map.speculative", false);<a name="line.2630"></a>
+<span class="sourceLineNo">2631</span>    conf.setBoolean("mapreduce.reduce.speculative", false);<a name="line.2631"></a>
+<span class="sourceLineNo">2632</span>    ////<a name="line.2632"></a>
+<span class="sourceLineNo">2633</span><a name="line.2633"></a>
+<span class="sourceLineNo">2634</span>    // Allow the user to override FS URI for this map-reduce cluster to use.<a name="line.2634"></a>
+<span class="sourceLineNo">2635</span>    mrCluster = new MiniMRCluster(servers,<a name="line.2635"></a>
+<span class="sourceLineNo">2636</span>      FS_URI != null ? FS_URI : FileSystem.get(conf).getUri().toString(), 1,<a name="line.2636"></a>
+<span class="sourceLineNo">2637</span>      null, null, new JobConf(this.conf));<a name="line.2637"></a>
+<span class="sourceLineNo">2638</span>    JobConf jobConf = MapreduceTestingShim.getJobConf(mrCluster);<a name="line.2638"></a>
+<span class="sourceLineNo">2639</span>    if (jobConf == null) {<a name="line.2639"></a>
+<span class="sourceLineNo">2640</span>      jobConf = mrCluster.createJobConf();<a name="line.2640"></a>
+<span class="sourceLineNo">2641</span>    }<a name="line.2641"></a>
+<span class="sourceLineNo">2642</span><a name="line.2642"></a>
+<span class="sourceLineNo">2643</span>    jobConf.set("mapreduce.cluster.local.dir",<a name="line.2643"></a>
+<span class="sourceLineNo">2644</span>      conf.get("mapreduce.cluster.local.dir")); //Hadoop MiniMR overwrites this while it should not<a name="line.2644"></a>
+<span class="sourceLineNo">2645</span>    LOG.info("Mini mapreduce cluster started");<a name="line.2645"></a>
+<span class="sourceLineNo">2646</span><a name="line.2646"></a>
+<span class="sourceLineNo">2647</span>    // In hadoop2, YARN/MR2 starts a mini cluster with its own conf instance and updates settings.<a name="line.2647"></a>
+<span class="sourceLineNo">2648</span>    // Our HBase MR jobs need several of these settings in order to properly run.  So we copy the<a name="line.2648"></a>
+<span class="sourceLineNo">2649</span>    // necessary config properties here.  YARN-129 required adding a few properties.<a name="line.2649"></a>
+<span class="sourceLineNo">2650</span>    conf.set("mapreduce.jobtracker.address", jobConf.get("mapreduce.jobtracker.address"));<a name="line.2650"></a>
+<span class="sourceLineNo">2651</span>    // this for mrv2 support; mr1 ignores this<a name="line.2651"></a>
+<span class="sourceLineNo">2652</span>    conf.set("mapreduce.framework.name", "yarn");<a name="line.2652"></a>
+<span class="sourceLineNo">2653</span>    conf.setBoolean("yarn.is.minicluster", true);<a name="line.2653"></a>
+<span class="sourceLineNo">2654</span>    String rmAddress = jobConf.get("yarn.resourcemanager.address");<a name="line.2654"></a>
+<span class="sourceLineNo">2655</span>    if (rmAddress != null) {<a name="line.2655"></a>
+<span class="sourceLineNo">2656</span>      conf.set("yarn.resourcemanager.address", rmAddress);<a name="line.2656"></a>
+<span class="sourceLineNo">2657</span>    }<a name="line.2657"></a>
+<span class="sourceLineNo">2658</span>    String historyAddress = jobConf.get("mapreduce.jobhistory.address");<a name="line.2658"></a>
+<span class="sourceLineNo">2659</span>    if (historyAddress != null) {<a name="line.2659"></a>
+<span class="sourceLineNo">2660</span>      conf.set("mapreduce.jobhistory.address", historyAddress);<a name="line.2660"></a>
 <span class="sourceLineNo">2661</span>    }<a name="line.2661"></a>
-<span class="sourceLineNo">2662</span>  }<a name="line.2662"></a>
-<span class="sourceLineNo">2663</span><a name="line.2663"></a>
-<span class="sourceLineNo">2664</span>  /**<a name="line.2664"></a>
-<span class="sourceLineNo">2665</span>   * Stops the previously started &lt;code&gt;MiniMRCluster&lt;/code&gt;.<a name="line.2665"></a>
-<span class="sourceLineNo">2666</span>   */<a name="line.2666"></a>
-<span class="sourceLineNo">2667</span>  public void shutdownMiniMapReduceCluster() {<a name="line.2667"></a>
-<span class="sourceLineNo">2668</span>    if (mrCluster != null) {<a name="line.2668"></a>
-<span class="sourceLineNo">2669</span>      LOG.info("Stopping mini mapreduce cluster...");<a name="line.2669"></a>
-<span class="sourceLineNo">2670</span>      mrCluster.shutdown();<a name="line.2670"></a>
-<span class="sourceLineNo">2671</span>      mrCluster = null;<a name="line.2671"></a>
-<span class="sourceLineNo">2672</span>      LOG.info("Mini mapreduce cluster stopped");<a name="line.2672"></a>
-<span class="sourceLineNo">2673</span>    }<a name="line.2673"></a>
-<span class="sourceLineNo">2674</span>    // Restore configuration to point to local jobtracker<a name="line.2674"></a>
-<span class="sourceLineNo">2675</span>    conf.set("mapreduce.jobtracker.address", "local");<a name="line.2675"></a>
-<span class="sourceLineNo">2676</span>  }<a name="line.2676"></a>
-<span class="sourceLineNo">2677</span><a name="line.2677"></a>
-<span class="sourceLineNo">2678</span>  /**<a name="line.2678"></a>
-<span class="sourceLineNo">2679</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2679"></a>
-<span class="sourceLineNo">2680</span>   */<a name="line.2680"></a>
-<span class="sourceLineNo">2681</span>  public RegionServerServices createMockRegionServerService() throws IOException {<a name="line.2681"></a>
-<span class="sourceLineNo">2682</span>    return createMockRegionServerService((ServerName)null);<a name="line.2682"></a>
-<span class="sourceLineNo">2683</span>  }<a name="line.2683"></a>
-<span class="sourceLineNo">2684</span><a name="line.2684"></a>
-<span class="sourceLineNo">2685</span>  /**<a name="line.2685"></a>
-<span class="sourceLineNo">2686</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2686"></a>
-<span class="sourceLineNo">2687</span>   * This version is used by TestTokenAuthentication<a name="line.2687"></a>
-<span class="sourceLineNo">2688</span>   */<a name="line.2688"></a>
-<span class="sourceLineNo">2689</span>  public RegionServerServices createMockRegionServerService(RpcServerInterface rpc) throws<a name="line.2689"></a>
-<span class="sourceLineNo">2690</span>      IOException {<a name="line.2690"></a>
-<span class="sourceLineNo">2691</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher());<a name="line.2691"></a>
-<span class="sourceLineNo">2692</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2692"></a>
-<span class="sourceLineNo">2693</span>    rss.setRpcServer(rpc);<a name="line.2693"></a>
-<span class="sourceLineNo">2694</span>    return rss;<a name="line.2694"></a>
-<span class="sourceLineNo">2695</span>  }<a name="line.2695"></a>
-<span class="sourceLineNo">2696</span><a name="line.2696"></a>
-<span class="sourceLineNo">2697</span>  /**<a name="line.2697"></a>
-<span class="sourceLineNo">2698</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2698"></a>
-<span class="sourceLineNo">2699</span>   * This version is used by TestOpenRegionHandler<a name="line.2699"></a>
-<span class="sourceLineNo">2700</span>   */<a name="line.2700"></a>
-<span class="sourceLineNo">2701</span>  public RegionServerServices createMockRegionServerService(ServerName name) throws IOException {<a name="line.2701"></a>
-<span class="sourceLineNo">2702</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher(), name);<a name="line.2702"></a>
-<span class="sourceLineNo">2703</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2703"></a>
-<span class="sourceLineNo">2704</span>    return rss;<a name="line.2704"></a>
-<span class="sourceLineNo">2705</span>  }<a name="line.2705"></a>
-<span class="sourceLineNo">2706</span><a name="line.2706"></a>
-<span class="sourceLineNo">2707</span>  /**<a name="line.2707"></a>
-<span class="sourceLineNo">2708</span>   * Switches the logger for the given class to DEBUG level.<a name="line.2708"></a>
-<span class="sourceLineNo">2709</span>   *<a name="line.2709"></a>
-<span class="sourceLineNo">2710</span>   * @param clazz  The class for which to switch to debug logging.<a name="line.2710"></a>
-<span class="sourceLineNo">2711</span>   */<a name="line.2711"></a>
-<span class="sourceLineNo">2712</span>  public void enableDebug(Class&lt;?&gt; clazz) {<a name="line.2712"></a>
-<span class="sourceLineNo">2713</span>    Log l = LogFactory.getLog(clazz);<a name="line.2713"></a>
-<span class="sourceLineNo">2714</span>    if (l instanceof Log4JLogger) {<a name="line.2714"></a>
-<span class="sourceLineNo">2715</span>      ((Log4JLogger) l).getLogger().setLevel(org.apache.log4j.Level.DEBUG);<a name="line.2715"></a>
-<span class="sourceLineNo">2716</span>    } else if (l instanceof Jdk14Logger) {<a name="line.2716"></a>
-<span class="sourceLineNo">2717</span>      ((Jdk14Logger) l).getLogger().setLevel(java.util.logging.Level.ALL);<a name="line.2717"></a>
-<span class="sourceLineNo">2718</span>    }<a name="line.2718"></a>
-<span class="sourceLineNo">2719</span>  }<a name="line.2719"></a>
-<span class="sourceLineNo">2720</span><a name="line.2720"></a>
-<span class="sourceLineNo">2721</span>  /**<a name="line.2721"></a>
-<span class="sourceLineNo">2722</span>   * Expire the Master's session<a name="line.2722"></a>
-<span class="sourceLineNo">2723</span>   * @throws Exception<a name="line.2723"></a>
-<span class="sourceLineNo">2724</span>   */<a name="line.2724"></a>
-<span class="sourceLineNo">2725</span>  public void expireMasterSession() throws Exception {<a name="line.2725"></a>
-<span class="sourceLineNo">2726</span>    HMaster master = getMiniHBaseCluster().getMaster();<a name="line.2726"></a>
-<span class="sourceLineNo">2727</span>    expireSession(master.getZooKeeper(), false);<a name="line.2727"></a>
-<span class="sourceLineNo">2728</span>  }<a name="line.2728"></a>
-<span class="sourceLineNo">2729</span><a name="line.2729"></a>
-<span class="sourceLineNo">2730</span>  /**<a name="line.2730"></a>
-<span class="sourceLineNo">2731</span>   * Expire a region server's session<a name="line.2731"></a>
-<span class="sourceLineNo">2732</span>   * @param index which RS<a name="line.2732"></a>
-<span class="sourceLineNo">2733</span>   * @throws Exception<a name="line.2733"></a>
-<span class="sourceLineNo">2734</span>   */<a name="line.2734"></a>
-<span class="sourceLineNo">2735</span>  public void expireRegionServerSession(int index) throws Exception {<a name="line.2735"></a>
-<span class="sourceLineNo">2736</span>    HRegionServer rs = getMiniHBaseCluster().getRegionServer(index);<a name="line.2736"></a>
-<span class="sourceLineNo">2737</span>    expireSession(rs.getZooKeeper(), false);<a name="line.2737"></a>
-<span class="sourceLineNo">2738</span>    decrementMinRegionServerCount();<a name="line.2738"></a>
-<span class="sourceLineNo">2739</span>  }<a name="line.2739"></a>
-<span class="sourceLineNo">2740</span><a name="line.2740"></a>
-<span class="sourceLineNo">2741</span>  private void decrementMinRegionServerCount() {<a name="line.2741"></a>
-<span class="sourceLineNo">2742</span>    // decrement the count for this.conf, for newly spwaned master<a name="line.2742"></a>
-<span class="sourceLineNo">2743</span>    // this.hbaseCluster shares this configuration too<a name="line.2743"></a>
-<span class="sourceLineNo">2744</span>    decrementMinRegionServerCount(getConfiguration());<a name="line.2744"></a>
-<span class="sourceLineNo">2745</span><a name="line.2745"></a>
-<span class="sourceLineNo">2746</span>    // each master thread keeps a copy of configuration<a name="line.2746"></a>
-<span class="sourceLineNo">2747</span>    for (MasterThread master : getHBaseCluster().getMasterThreads()) {<a name="line.2747"></a>
-<span class="sourceLineNo">2748</span>      decrementMinRegionServerCount(master.getMaster().getConfiguration());<a name="line.2748"></a>
-<span class="sourceLineNo">2749</span>    }<a name="line.2749"></a>
-<span class="sourceLineNo">2750</span>  }<a name="line.2750"></a>
-<span class="sourceLineNo">2751</span><a name="line.2751"></a>
-<span class="sourceLineNo">2752</span>  private void decrementMinRegionServerCount(Configuration conf) {<a name="line.2752"></a>
-<span class="sourceLineNo">2753</span>    int currentCount = conf.getInt(<a name="line.2753"></a>
-<span class="sourceLineNo">2754</span>        ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART, -1);<a name="line.2754"></a>
-<span class="sourceLineNo">2755</span>    if (currentCount != -1) {<a name="line.2755"></a>
-<span class="sourceLineNo">2756</span>      conf.setInt(ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART,<a name="line.2756"></a>
-<span class="sourceLineNo">2757</span>          Math.max(currentCount - 1, 1));<a name="line.2757"></a>
-<span class="sourceLineNo">2758</span>    }<a name="line.2758"></a>
-<span class="sourceLineNo">2759</span>  }<a name="line.2759"></a>
+<span class="sourceLineNo">2662</span>    String schedulerAddress =<a name="line.2662"></a>
+<span class="sourceLineNo">2663</span>      jobConf.get("yarn.resourcemanager.scheduler.address");<a name="line.2663"></a>
+<span class="sourceLineNo">2664</span>    if (schedulerAddress != null) {<a name="line.2664"></a>
+<span class="sourceLineNo">2665</span>      conf.set("yarn.resourcemanager.scheduler.address", schedulerAddress);<a name="line.2665"></a>
+<span class="sourceLineNo">2666</span>    }<a name="line.2666"></a>
+<span class="sourceLineNo">2667</span>    String mrJobHistoryWebappAddress =<a name="line.2667"></a>
+<span class="sourceLineNo">2668</span>      jobConf.get("mapreduce.jobhistory.webapp.address");<a name="line.2668"></a>
+<span class="sourceLineNo">2669</span>    if (mrJobHistoryWebappAddress != null) {<a name="line.2669"></a>
+<span class="sourceLineNo">2670</span>      conf.set("mapreduce.jobhistory.webapp.address", mrJobHistoryWebappAddress);<a name="line.2670"></a>
+<span class="sourceLineNo">2671</span>    }<a name="line.2671"></a>
+<span class="sourceLineNo">2672</span>    String yarnRMWebappAddress =<a name="line.2672"></a>
+<span class="sourceLineNo">2673</span>      jobConf.get("yarn.resourcemanager.webapp.address");<a name="line.2673"></a>
+<span class="sourceLineNo">2674</span>    if (yarnRMWebappAddress != null) {<a name="line.2674"></a>
+<span class="sourceLineNo">2675</span>      conf.set("yarn.resourcemanager.webapp.address", yarnRMWebappAddress);<a name="line.2675"></a>
+<span class="sourceLineNo">2676</span>    }<a name="line.2676"></a>
+<span class="sourceLineNo">2677</span>  }<a name="line.2677"></a>
+<span class="sourceLineNo">2678</span><a name="line.2678"></a>
+<span class="sourceLineNo">2679</span>  /**<a name="line.2679"></a>
+<span class="sourceLineNo">2680</span>   * Stops the previously started &lt;code&gt;MiniMRCluster&lt;/code&gt;.<a name="line.2680"></a>
+<span class="sourceLineNo">2681</span>   */<a name="line.2681"></a>
+<span class="sourceLineNo">2682</span>  public void shutdownMiniMapReduceCluster() {<a name="line.2682"></a>
+<span class="sourceLineNo">2683</span>    if (mrCluster != null) {<a name="line.2683"></a>
+<span class="sourceLineNo">2684</span>      LOG.info("Stopping mini mapreduce cluster...");<a name="line.2684"></a>
+<span class="sourceLineNo">2685</span>      mrCluster.shutdown();<a name="line.2685"></a>
+<span class="sourceLineNo">2686</span>      mrCluster = null;<a name="line.2686"></a>
+<span class="sourceLineNo">2687</span>      LOG.info("Mini mapreduce cluster stopped");<a name="line.2687"></a>
+<span class="sourceLineNo">2688</span>    }<a name="line.2688"></a>
+<span class="sourceLineNo">2689</span>    // Restore configuration to point to local jobtracker<a name="line.2689"></a>
+<span class="sourceLineNo">2690</span>    conf.set("mapreduce.jobtracker.address", "local");<a name="line.2690"></a>
+<span class="sourceLineNo">2691</span>  }<a name="line.2691"></a>
+<span class="sourceLineNo">2692</span><a name="line.2692"></a>
+<span class="sourceLineNo">2693</span>  /**<a name="line.2693"></a>
+<span class="sourceLineNo">2694</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2694"></a>
+<span class="sourceLineNo">2695</span>   */<a name="line.2695"></a>
+<span class="sourceLineNo">2696</span>  public RegionServerServices createMockRegionServerService() throws IOException {<a name="line.2696"></a>
+<span class="sourceLineNo">2697</span>    return createMockRegionServerService((ServerName)null);<a name="line.2697"></a>
+<span class="sourceLineNo">2698</span>  }<a name="line.2698"></a>
+<span class="sourceLineNo">2699</span><a name="line.2699"></a>
+<span class="sourceLineNo">2700</span>  /**<a name="line.2700"></a>
+<span class="sourceLineNo">2701</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2701"></a>
+<span class="sourceLineNo">2702</span>   * This version is used by TestTokenAuthentication<a name="line.2702"></a>
+<span class="sourceLineNo">2703</span>   */<a name="line.2703"></a>
+<span class="sourceLineNo">2704</span>  public RegionServerServices createMockRegionServerService(RpcServerInterface rpc) throws<a name="line.2704"></a>
+<span class="sourceLineNo">2705</span>      IOException {<a name="line.2705"></a>
+<span class="sourceLineNo">2706</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher());<a name="line.2706"></a>
+<span class="sourceLineNo">2707</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2707"></a>
+<span class="sourceLineNo">2708</span>    rss.setRpcServer(rpc);<a name="line.2708"></a>
+<span class="sourceLineNo">2709</span>    return rss;<a name="line.2709"></a>
+<span class="sourceLineNo">2710</span>  }<a name="line.2710"></a>
+<span class="sourceLineNo">2711</span><a name="line.2711"></a>
+<span class="sourceLineNo">2712</span>  /**<a name="line.2712"></a>
+<span class="sourceLineNo">2713</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2713"></a>
+<span class="sourceLineNo">2714</span>   * This version is used by TestOpenRegionHandler<a name="line.2714"></a>
+<span class="sourceLineNo">2715</span>   */<a name="line.2715"></a>
+<span class="sourceLineNo">2716</span>  public RegionServerServices createMockRegionServerService(ServerName name) throws IOException {<a name="line.2716"></a>
+<span class="sourceLineNo">2717</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher(), name);<a name="line.2717"></a>
+<span class="sourceLineNo">2718</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2718"></a>
+<span class="sourceLineNo">2719</span>    return rss;<a name="line.2719"></a>
+<span class="sourceLineNo">2720</span>  }<a name="line.2720"></a>
+<span class="sourceLineNo">2721</span><a name="line.2721"></a>
+<span class="sourceLineNo">2722</span>  /**<a name="line.2722"></a>
+<span class="sourceLineNo">2723</span>   * Switches the logger for the given class to DEBUG level.<a name="line.2723"></a>
+<span class="sourceLineNo">2724</span>   *<a name="line.2724"></a>
+<span class="sourceLineNo">2725</span>   * @param clazz  The class for which to switch to debug logging.<a name="line.2725"></a>
+<span class="sourceLineNo">2726</span>   */<a name="line.2726"></a>
+<span class="sourceLineNo">2727</span>  public void enableDebug(Class&lt;?&gt; clazz) {<a name="line.2727"></a>
+<span class="sourceLineNo">2728</span>    Log l = LogFactory.getLog(clazz);<a name="line.2728"></a>
+<span class="sourceLineNo">2729</span>    if (l instanceof Log4JLogger) {<a name="line.2729"></a>
+<span class="sourceLineNo">2730</span>      ((Log4JLogger) l).getLogger().setLevel(org.apache.log4j.Level.DEBUG);<a name="line.2730"></a>
+<span class="sourceLineNo">2731</span>    } else if (l instanceof Jdk14Logger) {<a name="line.2731"></a>
+<span class="sourceLineNo">2732</span>      ((Jdk14Logger) l).getLogger().setLevel(java.util.logging.Level.ALL);<a name="line.2732"></a>
+<span class="sourceLineNo">2733</span>    }<a name="line.2733"></a>
+<span class="sourceLineNo">2734</span>  }<a name="line.2734"></a>
+<span class="sourceLineNo">2735</span><a name="line.2735"></a>
+<span class="sourceLineNo">2736</span>  /**<a name="line.2736"></a>
+<span class="sourceLineNo">2737</span>   * Expire the Master's session<a name="line.2737"></a>
+<span class="sourceLineNo">2738</span>   * @throws Exception<a name="line.2738"></a>
+<span class="sourceLineNo">2739</span>   */<a name="line.2739"></a>
+<span class="sourceLineNo">2740</span>  public void expireMasterSession() throws Exception {<a name="line.2740"></a>
+<span class="sourceLineNo">2741</span>    HMaster master = getMiniHBaseCluster().getMaster();<a name="line.2741"></a>
+<span class="sourceLineNo">2742</span>    expireSession(master.getZooKeeper(), false);<a name="line.2742"></a>
+<span class="sourceLineNo">2743</span>  }<a name="line.2743"></a>
+<span class="sourceLineNo">2744</span><a name="line.2744"></a>
+<span class="sourceLineNo">2745</span>  /**<a name="line.2745"></a>
+<span class="sourceLineNo">2746</span>   * Expire a region server's session<a name="line.2746"></a>
+<span class="sourceLineNo">2747</span>   * @param index which RS<a name="line.2747"></a>
+<span class="sourceLineNo">2748</span>   * @throws Exception<a name="line.2748"></a>
+<span class="sourceLineNo">2749</span>   */<a name="line.2749"></a>
+<span class="sourceLineNo">2750</span>  public void expireRegionServerSession(int index) throws Exception {<a name="line.2750"></a>
+<span class="sourceLineNo">2751</span>    HRegionServer rs = getMiniHBaseCluster().getRegionServer(index);<a name="line.2751"></a>
+<span class="sourceLineNo">2752</span>    expireSession(rs.getZooKeeper(), false);<a name="line.2752"></a>
+<span class="sourceLineNo">2753</span>    decrementMinRegionServerCount();<a name="line.2753"></a>
+<span class="sourceLineNo">2754</span>  }<a name="line.2754"></a>
+<span class="sourceLineNo">2755</span><a name="line.2755"></a>
+<span class="sourceLineNo">2756</span>  private void decrementMinRegionServerCount() {<a name="line.2756"></a>
+<span class="sourceLineNo">2757</span>    // decrement the count for this.conf, for newly spwaned master<a name="line.2757"></a>
+<span class="sourceLineNo">2758</span>    // this.hbaseCluster shares this configuration too<a name="line.2758"></a>
+<span class="sourceLineNo">2759</span>    decrementMinRegionServerCount(getConfiguration());<a name="line.2759"></a>
 <span class="sourceLineNo">2760</span><a name="line.2760"></a>
-<span class="sourceLineNo">2761</span>  public void expireSession(ZKWatcher nodeZK) throws Exception {<a name="line.2761"></a>
-<span class="sourceLineNo">2762</span>   expireSession(nodeZK, false);<a name="line.2762"></a>
-<span class="sourceLineNo">2763</span>  }<a name="line.2763"></a>
-<span class="sourceLineNo">2764</span><a name="line.2764"></a>
-<span class="sourceLineNo">2765</span>  /**<a name="line.2765"></a>
-<span class="sourceLineNo">2766</span>   * Expire a ZooKeeper session as recommended in ZooKeeper documentation<a name="line.2766"></a>
-<span class="sourceLineNo">2767</span>   * http://hbase.apache.org/book.html#trouble.zookeeper<a name="line.2767"></a>
-<span class="sourceLineNo">2768</span>   * There are issues when doing this:<a name="line.2768"></a>
-<span class="sourceLineNo">2769</span>   * [1] http://www.mail-archive.com/dev@zookeeper.apache.org/msg01942.html<a name="line.2769"></a>
-<span class="sourceLineNo">2770</span>   * [2] https://issues.apache.org/jira/browse/ZOOKEEPER-1105<a name="line.2770"></a>
-<span class="sourceLineNo">2771</span>   *<a name="line.2771"></a>
-<span class="sourceLineNo">2772</span>   * @param nodeZK - the ZK watcher to expire<a name="line.2772"></a>
-<span class="sourceLineNo">2773</span>   * @param checkStatus - true to check if we can create a Table with the<a name="line.2773"></a>
-<span class="sourceLineNo">2774</span>   *                    current configuration.<a name="line.2774"></a>
-<span class="sourceLineNo">2775</span>   */<a name="line.2775"></a>
-<span class="sourceLineNo">2776</span>  public void expireSession(ZKWatcher nodeZK, boolean checkStatus)<a name="line.2776"></a>
-<span class="sourceLineNo">2777</span>    throws Exception {<a name="line.2777"></a>
-<span class="sourceLineNo">2778</span>    Configuration c = new Configuration(this.conf);<a name="line.2778"></a>
-<span class="sourceLineNo">2779</span>    String quorumServers = ZKConfig.getZKQuorumServersString(c);<a name="line.2779"></a>
-<span class="sourceLineNo">2780</span>    ZooKeeper zk = nodeZK.getRecoverableZooKeeper().getZooKeeper();<a name="line.2780"></a>
-<span class="sourceLineNo">2781</span>    byte[] password = zk.getSessionPasswd();<a name="line.2781"></a>
-<span class="sourceLineNo">2782</span>    long sessionID = zk.getSessionId();<a name="line.2782"></a>
-<span class="sourceLineNo">2783</span><a name="line.2783"></a>
-<span class="sourceLineNo">2784</span>    // Expiry seems to be asynchronous (see comment from P. Hunt in [1]),<a name="line.2784"></a>
-<span class="sourceLineNo">2785</span>    //  so we create a first watcher to be sure that the<a name="line.2785"></a>
-<span class="sourceLineNo">2786</span>    //  event was sent. We expect that if our watcher receives the event<a name="line.2786"></a>
-<span class="sourceLineNo">2787</span>    //  other watchers on the same machine will get is as well.<a name="line.2787"></a>
-<span class="sourceLineNo">2788</span>    // When we ask to close the connection, ZK does not close it before<a name="line.2788"></a>
-<span class="sourceLineNo">2789</span>    //  we receive all the events, so don't have to capture the event, just<a name="line.2789"></a>
-<span class="sourceLineNo">2790</span>    //  closing the connection should be enough.<a name="line.2790"></a>
-<span class="sourceLineNo">2791</span>    ZooKeeper monitor = new ZooKeeper(quorumServers,<a name="line.2791"></a>
-<span class="sourceLineNo">2792</span>      1000, new org.apache.zookeeper.Watcher(){<a name="line.2792"></a>
-<span class="sourceLineNo">2793</span>      @Override<a name="line.2793"></a>
-<span class="sourceLineNo">2794</span>      public void process(WatchedEvent watchedEvent) {<a name="line.2794"></a>
-<span class="sourceLineNo">2795</span>        LOG.info("Monitor ZKW received event="+watchedEvent);<a name="line.2795"></a>
-<span class="sourceLineNo">2796</span>      }<a name="line.2796"></a>
-<span class="sourceLineNo">2797</span>    } , sessionID, password);<a name="line.2797"></a>
+<span class="sourceLineNo">2761</span>    // each master thread keeps a copy of configuration<a name="line.2761"></a>
+<span class="sourceLineNo">2762</span>    for (MasterThread master : getHBaseCluster().getMasterThreads()) {<a name="line.2762"></a>
+<span class="sourceLineNo">2763</span>      decrementMinRegionServerCount(master.getMaster().getConfiguration());<a name="line.2763"></a>
+<span class="sourceLineNo">2764</span>    }<a name="line.2764"></a>
+<span class="sourceLineNo">2765</span>  }<a name="line.2765"></a>
+<span class="sourceLineNo">2766</span><a name="line.2766"></a>
+<span class="sourceLineNo">2767</span>  private void decrementMinRegionServerCount(Configuration conf) {<a name="line.2767"></a>
+<span class="sourceLineNo">2768</span>    int currentCount = conf.getInt(<a name="line.2768"></a>
+<span class="sourceLineNo">2769</span>        ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART, -1);<a name="line.2769"></a>
+<span class="sourceLineNo">2770</span>    if (currentCount != -1) {<a name="line.2770"></a>
+<span class="sourceLineNo">2771</span>      conf.setInt(ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART,<a name="line.2771"></a>
+<span class="sourceLineNo">2772</span>          Math.max(currentCount - 1, 1));<a name="line.2772"></a>
+<span class="sourceLineNo">2773</span>    }<a name="line.2773"></a>
+<span class="sourceLineNo">2774</span>  }<a name="line.2774"></a>
+<span class="sourceLineNo">2775</span><a name="line.2775"></a>
+<span class="sourceLineNo">2776</span>  public void expireSession(ZKWatcher nodeZK) throws Exception {<a name="line.2776"></a>
+<span class="sourceLineNo">2777</span>   expireSession(nodeZK, false);<a name="line.2777"></a>
+<span class="sourceLineNo">2778</span>  }<a name="line.2778"></a>
+<span class="sourceLineNo">2779</span><a name="line.2779"></a>
+<span class="sourceLineNo">2780</span>  /**<a name="line.2780"></a>
+<span class="sourceLineNo">2781</span>   * Expire a ZooKeeper session as recommended in ZooKeeper documentation<a name="line.2781"></a>
+<span class="sourceLineNo">2782</span>   * http://hbase.apache.org/book.html#trouble.zookeeper<a name="line.2782"></a>
+<span class="sourceLineNo">2783</span>   * There are issues when doing this:<a name="line.2783"></a>
+<span class="sourceLineNo">2784</span>   * [1] http://www.mail-archive.com/dev@zookeeper.apache.org/msg01942.html<a name="line.2784"></a>
+<span class="sourceLineNo">2785</span>   * [2] https://issues.apache.org/jira/browse/ZOOKEEPER-1105<a name="line.2785"></a>
+<span class="sourceLineNo">2786</span>   *<a name="line.2786"></a>
+<span class="sourceLineNo">2787</span>   * @param nodeZK - the ZK watcher to expire<a name="line.2787"></a>
+<span class="sourceLineNo">2788</span>   * @param checkStatus - true to check if we can create a Table with the<a name="line.2788"></a>
+<span class="sourceLineNo">2789</span>   *                    current configuration.<a name="line.2789"></a>
+<span class="sourceLineNo">2790</span>   */<a name="line.2790"></a>
+<span class="sourceLineNo">2791</span>  public void expireSession(ZKWatcher nodeZK, boolean checkStatus)<a name="line.2791"></a>
+<span class="sourceLineNo">2792</span>    throws Exception {<a name="line.2792"></a>
+<span class="sourceLineNo">2793</span>    Configuration c = new Configuration(this.conf);<a name="line.2793"></a>
+<span class="sourceLineNo">2794</span>    String quorumServers = ZKConfig.getZKQuorumServersString(c);<a name="line.2794"></a>
+<span class="sourceLineNo">2795</span>    ZooKeeper zk = nodeZK.getRecoverableZooKeeper().getZooKeeper();<a name="line.2795"></a>
+<span class="sourceLineNo">2796</span>    byte[] password = zk.getSessionPasswd();<a name="line.2796"></a>
+<span class="sourceLineNo">2797</span>    long sessionID = zk.getSessionId();<a name="line.2797"></a>
 <span class="sourceLineNo">2798</span><a name="line.2798"></a>
-<span class="sourceLineNo">2799</span>    // Making it expire<a name="line.2799"></a>
-<span class="sourceLineNo">2800</span>    ZooKeeper newZK = new ZooKeeper(quorumServers,<a name="line.2800"></a>
-<span class="sourceLineNo">2801</span>        1000, EmptyWatcher.instance, sessionID, password);<a name="line.2801"></a>
-<span class="sourceLineNo">2802</span><a name="line.2802"></a>
-<span class="sourceLineNo">2803</span>    //ensure that we have connection to the server before closing down, otherwise<a name="line.2803"></a>
-<span class="sourceLineNo">2804</span>    //the close session event will be eaten out before we start CONNECTING state<a name="line.2804"></a>
-<span class="sourceLineNo">2805</span>    long start = System.currentTimeMillis();<a name="line.2805"></a>
-<span class="sourceLineNo">2806</span>    while (newZK.getState() != States.CONNECTED<a name="line.2806"></a>
-<span class="sourceLineNo">2807</span>         &amp;&amp; System.currentTimeMillis() - start &lt; 1000) {<a name="line.2807"></a>
-<span class="sourceLineNo">2808</span>       Thread.sleep(1);<a name="line.2808"></a>
-<span class="sourceLineNo">2809</span>    }<a name="line.2809"></a>
-<span class="sourceLineNo">2810</span>    newZK.close();<a name="line.2810"></a>
-<span class="sourceLineNo">2811</span>    LOG.info("ZK Closed Session 0x" + Long.toHexString(sessionID));<a name="line.2811"></a>
-<span class="sourceLineNo">2812</span><a name="line.2812"></a>
-<span class="sourceLineNo">2813</span>    // Now closing &amp; waiting to be sure that the clients get it.<a name="line.2813"></a>
-<span class="sourceLineNo">2814</span>    monitor.close();<a name="line.2814"></a>
-<span class="sourceLineNo">2815</span><a name="line.2815"></a>
-<span class="sourceLineNo">2816</span>    if (checkStatus) {<a name="line.2816"></a>
-<span class="sourceLineNo">2817</span>      getConnection().getTable(TableName.META_TABLE_NAME).close();<a name="line.2817"></a>
-<span class="sourceLineNo">2818</span>    }<a name="line.2818"></a>
-<span class="sourceLineNo">2819</span>  }<a name="line.2819"></a>
-<span class="sourceLineNo">2820</span><a name="line.2820"></a>
-<span class="sourceLineNo">2821</span>  /**<a name="line.2821"></a>
-<span class="sourceLineNo">2822</span>   * Get the Mini HBase cluster.<a name="line.2822"></a>
-<span class="sourceLineNo">2823</span>   *<a name="line.2823"></a>
-<span class="sourceLineNo">2824</span>   * @return hbase cluster<a name="line.2824"></a>
-<span class="sourceLineNo">2825</span>   * @see #getHBaseClusterInterface()<a name="line.2825"></a>
-<span class="sourceLineNo">2826</span>   */<a name="line.2826"></a>
-<span class="sourceLineNo">2827</span>  public MiniHBaseCluster getHBaseCluster() {<a name="line.2827"></a>
-<span class="sourceLineNo">2828</span>    return getMiniHBaseCluster();<a name="line.2828"></a>
-<span class="sourceLineNo">2829</span>  }<a name="line.2829"></a>
+<span class="sourceLineNo">2799</span>    // Expiry seems to be asynchronous (see comment from P. Hunt in [1]),<a name="line.2799"></a>
+<span class="sourceLineNo">2800</span>    //  so we create a first watcher to be sure that the<a name="line.2800"></a>
+<span class="sourceLineNo">2801</span>    //  event was sent. We expect that if our watcher receives the event<a name="line.2801"></a>
+<span class="sourceLineNo">2802</span>    //  other watchers on the same machine will get is as well.<a name="line.2802"></a>
+<span class="sourceLineNo">2803</span>    // When we ask to close the connection, ZK does not close it before<a name="line.2803"></a>
+<span class="sourceLineNo">2804</span>    //  we receive all the events, so don't have to capture the event, just<a name="line.2804"></a>
+<span class="sourceLineNo">2805</span>    //  closing the connection should be enough.<a name="line.2805"></a>
+<span class="sourceLineNo">2806</span>    ZooKeeper monitor = new ZooKeeper(quorumServers,<a name="line.2806"></a>
+<span class="sourceLineNo">2807</span>      1000, new org.apache.zookeeper.Watcher(){<a name="line.2807"></a>
+<span class="sourceLineNo">2808</span>      @Override<a name="line.2808"></a>
+<span class="sourceLineNo">2809</span>      public void process(WatchedEvent watchedEvent) {<a name="line.2809"></a>
+<span class="sourceLineNo">2810</span>        LOG.info("Monitor ZKW received event="+watchedEvent);<a name="line.2810"></a>
+<span class="sourceLineNo">2811</span>      }<a name="line.2811"></a>
+<span class="sourceLineNo">2812</span>    } , sessionID, password);<a name="line.2812"></a>
+<span class="sourceLineNo">2813</span><a name="line.2813"></a>
+<span class="sourceLineNo">2814</span>    // Making it expire<a name="line.2814"></a>
+<span class="sourceLineNo">2815</span>    ZooKeeper newZK = new ZooKeeper(quorumServers,<a name="line.2815"></a>
+<span class="sourceLineNo">2816</span>        1000, EmptyWatcher.instance, sessionID, password);<a name="line.2816"></a>
+<span class="sourceLineNo">2817</span><a name="line.2817"></a>
+<span class="sourceLineNo">2818</span>    //ensure that we have connection to the server before closing down, otherwise<a name="line.2818"></a>
+<span class="sourceLineNo">2819</span>    //the close session event will be eaten out before we start CONNECTING state<a name="line.2819"></a>
+<span class="sourceLineNo">2820</span>    long start = System.currentTimeMillis();<a name="line.2820"></a>
+<span class="sourceLineNo">2821</span>    while (newZK.getState() != States.CONNECTED<a name="line.2821"></a>
+<span class="sourceLineNo">2822</span>         &amp;&amp; System.currentTimeMillis() - start &lt; 1000) {<a name="line.2822"></a>
+<span class="sourceLineNo">2823</span>       Thread.sleep(1);<a name="line.2823"></a>
+<span class="sourceLineNo">2824</span>    }<a name="line.2824"></a>
+<span class="sourceLineNo">2825</span>    newZK.close();<a name="line.2825"></a>
+<span class="sourceLineNo">2826</span>    LOG.info("ZK Closed Session 0x" + Long.toHexString(sessionID));<a name="line.2826"></a>
+<span class="sourceLineNo">2827</span><a name="line.2827"></a>
+<span class="sourceLineNo">2828</span>    // Now closing &amp; waiting to be sure that the clients get it.<a name="line.2828"></a>
+<span class="sourceLineNo">2829</span>    monitor.close();<a name="line.2829"></a>
 <span class="sourceLineNo">2830</span><a name="line.2830"></a>
-<span class="sourceLineNo">2831</span>  /**<a name="line.2831"></a>
-<span class="sourceLineNo">2832</span>   * Returns the HBaseCluster instance.<a name="line.2832"></a>
-<span class="sourceLineNo">2833</span>   * &lt;p&gt;Returned object can be any of the subclasses of HBaseCluster, and the<a name="line.2833"></a>
-<span class="sourceLineNo">2834</span>   * tests referring this should not assume that the cluster is a mini cluster or a<a name="line.2834"></a>
-<span class="sourceLineNo">2835</span>   * distributed one. If the test only works on a mini cluster, then specific<a name="line.2835"></a>
-<span class="sourceLineNo">2836</span>   * method {@link #getMiniHBaseCluster()} can be used instead w/o the<a name="line.2836"></a>
-<span class="sourceLineNo">2837</span>   * need to type-cast.<a name="line.2837"></a>
-<span class="sourceLineNo">2838</span>   */<a name="line.2838"></a>
-<span class="sourceLineNo">2839</span>  public HBaseCluster getHBaseClusterInterface() {<a name="line.2839"></a>
-<span class="sourceLineNo">2840</span>    //implementation note: we should rename this method as #getHBaseCluster(),<a name="line.2840"></a>
-<span class="sourceLineNo">2841</span>    //but this would require refactoring 90+ calls.<a name="line.2841"></a>
-<span class="sourceLineNo">2842</span>    return hbaseCluster;<a name="line.2842"></a>
-<span class="sourceLineNo">2843</span>  }<a name="line.2843"></a>
-<span class="sourceLineNo">2844</span><a name="line.2844"></a>
-<span class="sourceLineNo">2845</span>  /**<a name="line.2845"></a>
-<span class="sourceLineNo">2846</span>   * Get a Connection to the cluster.<a name="line.2846"></a>
-<span class="sourceLineNo">2847</span>   * Not thread-safe (This class needs a lot of work to make it thread-safe).<a name="line.2847"></a>
-<span class="sourceLineNo">2848</span>   * @return A Connection that can be shared. Don't close. Will be closed on shutdown of cluster.<a name="line.2848"></a>
-<span class="sourceLineNo">2849</span>   * @throws IOException<a name="line.2849"></a>
-<span class="sourceLineNo">2850</span>   */<a name="line.2850"></a>
-<span class="sourceLineNo">2851</span>  public Connection getConnection() throws IOException {<a name="line.2851"></a>
-<span class="sourceLineNo">2852</span>    if (this.connection == null) {<a name="line.2852"></a>
-<span class="sourceLineNo">2853</span>      this.connection = ConnectionFactory.createConnection(this.conf);<a name="line.2853"></a>
-<span class="sourceLineNo">2854</span>    }<a name="line.2854"></a>
-<span class="sourceLineNo">2855</span>    return this.connection;<a name="line.2855"></a>
-<span class="sourceLineNo">2856</span>  }<a name="line.2856"></a>
-<span class="sourceLineNo">2857</span><a name="line.2857"></a>
-<span class="sourceLineNo">2858</span>  /**<a name="line.2858"></a>
-<span class="sourceLineNo">2859</span>   * Returns a Admin instance.<a name="line.2859"></a>
-<span class="sourceLineNo">2860</span>   * This instance is shared between HBaseTestingUtility instance users. Closing it has no effect,<a name="line.2860"></a>
-<span class="sourceLineNo">2861</span>   * it will be closed automatically when the cluster shutdowns<a name="line.2861"></a>
-<span class="sourceLineNo">2862</span>   *<a name="line.2862"></a>
-<span class="sourceLineNo">2863</span>   * @return HBaseAdmin instance which is guaranteed to support only {@link Admin} interface.<a name="line.2863"></a>
-<span class="sourceLineNo">2864</span>   *   Functions in HBaseAdmin not provided by {@link Admin} interface can be changed/deleted<a name="line.2864"></a>
-<span class="sourceLineNo">2865</span>   *   anytime.<a name="line.2865"></a>
-<span class="sourceLineNo">2866</span>   * @deprecated Since 2.0. Will be removed in 3.0. Use {@link #getAdmin()} instead.<a name="line.2866"></a>
-<span class="sourceLineNo">2867</span>   */<a name="line.2867"></a>
-<span class="sourceLineNo">2868</span>  @Deprecated<a name="line.2868"></a>
-<span class="sourceLineNo">2869</span>  public synchronized HBaseAdmin getHBaseAdmin()<a name="line.2869"></a>
-<span class="sourceLineNo">2870</span>  throws IOException {<a name="line.2870"></a>
-<span class="sourceLineNo">2871</span>    if (hbaseAdmin == null){<a name="line.2871"></a>
-<span class="sourceLineNo">2872</span>      this.hbaseAdmin = (HBaseAdmin) getConnection().getAdmin();<a name="line.2872"></a>
-<span class="sourceLineNo">2873</span>    }<a name="line.2873"></a>
-<span class="sourceLineNo">2874</span>    return hbaseAdmin;<a name="line.2874"></a>
-<span class="sourceLineNo">2875</span>  }<a name="line.2875"></a>
-<span class="sourceLineNo">2876</span><a name="line.2876"></a>
-<span class="sourceLineNo">2877</span>  /**<a name="line.2877"></a>
-<span class="sourceLineNo">2878</span>   * Returns an Admin instance which is shared between HBaseTestingUtility instance users.<a name="line.2878"></a>
-<span class="sourceLineNo">2879</span>   * Closing it has no effect, it will be closed automatically when the cluster shutdowns<a name="line.2879"></a>
-<span class="sourceLineNo">2880</span>   */<a name="line.2880"></a>
-<span class="sourceLineNo">2881</span>  public synchronized Admin getAdmin() throws IOException {<a name="line.2881"></a>
-<span class="sourceLineNo">2882</span>    if (hbaseAdmin == null){<a name="line.2882"></a>
-<span class="sourceLineNo">2883</span>      this.hbaseAdmin = (HBaseAdmin) getConnection().getAdmin();<a name="line.2883"></a>
-<span class="sourceLineNo">2884</span>    }<a name="line.2884"></a>
-<span class="sourceLineNo">2885</span>    return hbaseAdmin;<a name="line.2885"></a>
-<span class="sourceLineNo">2886</span>  }<a name="line.2886"></a>
-<span class="sourceLineNo">2887</span><a name="line.2887"></a>
-<span class="sourceLineNo">2888</span>  private HBaseAdmin hbaseAdmin = null;<a name="line.2888"></a>
-<span class="sourceLineNo">2889</span><a name="line.2889"></a>
-<span class="sourceLineNo">2890</span>  /**<a name="line.2890"></a>
-<span class="sourceLineNo">2891</span>   * Returns a ZKWatcher instance.<a name="line.2891"></a>
-<span class="sourceLineNo">2892</span>   * This instance is shared between HBaseTestingUtility instance users.<a name="line.2892"></a>
-<span class="sourceLineNo">2893</span>   * Don't close it, it will be closed automatically when the<a name="line.2893"></a>
-<span class="sourceLineNo">2894</span>   * cluster shutdowns<a name="line.2894"></a>
-<span class="sourceLineNo">2895</span>   *<a name="line.2895"></a>
-<span class="sourceLineNo">2896</span>   * @return The ZKWatcher instance.<a name="line.2896"></a>
-<span class="sourceLineNo">2897</span>   * @throws IOException<a name="line.2897"></a>
-<span class="sourceLineNo">2898</span>   */<a name="line.2898"></a>
-<span class="sourceLineNo">2899</span>  public synchronized ZKWatcher getZooKeeperWatcher()<a name="line.2899"></a>
-<span class="sourceLineNo">2900</span>    throws IOException {<a name="line.2900"></a>
-<span class="sourceLineNo">2901</span>    if (zooKeeperWatcher == null) {<a name="line.2901"></a>
-<span class="sourceLineNo">2902</span>      zooKeeperWatcher = new ZKWatcher(conf, "testing utility",<a name="line.2902"></a>
-<span class="sourceLineNo">2903</span>        new Abortable() {<a name="line.2903"></a>
-<span class="sourceLineNo">2904</span>        @Override public void abort(String why, Throwable e) {<a name="line.2904"></a>
-<span class="sourceLineNo">2905</span>          throw new RuntimeException("Unexpected abort in HBaseTestingUtility:"+why, e);<a name="line.2905"></a>
-<span class="sourceLineNo">2906</span>        }<a name="line.2906"></a>
-<span class="sourceLineNo">2907</span>        @Override public boolean isAborted() {return false;}<a name="line.2907"></a>
-<span class="sourceLineNo">2908</span>      });<a name="line.2908"></a>
-<span class="sourceLineNo">2909</span>    }<a name="line.2909"></a>
-<span class="sourceLineNo">2910</span>    return zooKeeperWatcher;<a name="line.2910"></a>
-<span class="sourceLineNo">2911</span>  }<a name="line.2911"></a>
-<span class="sourceLineNo">2912</span>  private ZKWatcher zooKeeperWatcher;<a name="line.2912"></a>
-<span class="sourceLineNo">2913</span><a name="line.2913"></a>
-<span class="sourceLineNo">2914</span><a name="line.2914"></a>
-<span class="sourceLineNo">2915</span><a name="line.2915"></a>
-<span class="sourceLineNo">2916</span>  /**<a name="line.2916"></a>
-<span class="sourceLineNo">2917</span>   * Unassign the named region.<a name="line.2917"></a>
-<span class="sourceLineNo">2918</span>   *<a name="line.2918"></a>
-<span class="sourceLineNo">2919</span>   * @param regionName  The region to unassign.<a name="line.2919"></a>
-<span class="sourceLineNo">2920</span>   */<a name="line.2920"></a>
-<span class="sourceLineNo">2921</span>  public void unassignRegion(String regionName) throws IOException {<a name="line.2921"></a>
-<span class="sourceLineNo">2922</span>    unassignRegion(Bytes.toBytes(regionName));<a name="line.2922"></a>
-<span class="sourceLineNo">2923</span>  }<a name="line.2923"></a>
-<span class="sourceLineNo">2924</span><a name="line.2924"></a>
-<span class="sourceLineNo">2925</span>  /**<a name="line.2925"></a>
-<span class="sourceLineNo">2926</span>   * Unassign the named region.<a name="line.2926"></a>
-<span class="sourceLineNo">2927</span>   *<a name="line.2927"></a>
-<span class="sourceLineNo">2928</span>   * @param regionName  The region to unassign.<a name="line.2928"></a>
-<span class="sourceLineNo">2929</span>   */<a name="line.2929"></a>
-<span class="sourceLineNo">2930</span>  public void unassignRegion(byte[] regionName) throws IOException {<a name="line.2930"></a>
-<span class="sourceLineNo">2931</span>    getAdmin().unassign(regionName, true);<a name="line.2931"></a>
-<span class="sourceLineNo">2932</span>  }<a name="line.2932"></a>
-<span class="sourceLineNo">2933</span><a name="line.2933"></a>
-<span class="sourceLineNo">2934</span>  /**<a name="line.2934"></a>
-<span class="sourceLineNo">2935</span>   * Closes the region containing the given row.<a name="line.2935"></a>
-<span class="sourceLineNo">2936</span>   *<a name="line.2936"></a>
-<span class="sourceLineNo">2937</span>   * @param row  The row to find the containing region.<a name="line.2937"></a>
-<span class="sourceLineNo">2938</span>   * @param table  The table to find the region.<a name="line.2938"></a>
-<span class="sourceLineNo">2939</span>   */<a name="line.2939"></a>
-<span class="sourceLineNo">2940</span>  public void unassignRegionByRow(String row, RegionLocator table) throws IOException {<a name="line.2940"></a>
-<span class="sourceLineNo">2941</span>    unassignRegionByRow(Bytes.toBytes(row), table);<a name="line.2941"></a>
-<span class="sourceLineNo">2942</span>  }<a name="line.2942"></a>
-<span class="sourceLineNo">2943</span><a name="line.2943"></a>
-<span class="sourceLineNo">2944</span>  /**<a name="line.2944"></a>
-<span class="sourceLineNo">2945</span>   * Closes the region containing the given row.<a name="line.2945"></a>
-<span class="sourceLineNo">2946</span>   *<a name="line.2946"></a>
-<span class="sourceLineNo">2947</span>   * @param row  The row to find the containing region.<a name="line.2947"></a>
-<span class="sourceLineNo">2948</span>   * @param table  The table to find the region.<a name="line.2948"></a>
-<span class="sourceLineNo">2949</span>   * @throws IOException<a name="line.2949"></a>
-<span class="sourceLineNo">2950</span>   */<a name="line.2950"></a>
-<span class="sourceLineNo">2951</span>  public void unassignRegionByRow(byte[] row, RegionLocator table) throws IOException {<a name="line.2951"></a>
-<span class="sourceLineNo">2952</span>    HRegionLocation hrl = table.getRegionLocation(row);<a name="line.2952"></a>
-<span class="sourceLineNo">2953</span>    unassignRegion(hrl.getRegionInfo().getRegionName());<a name="line.2953"></a>
-<span class="sourceLineNo">2954</span>  }<a name="line.2954"></a>
-<span class="sourceLineNo">2955</span><a name="line.2955"></a>
-<span class="sourceLineNo">2956</span>  /*<a name="line.2956"></a>
-<span class="sourceLineNo">2957</span>   * Retrieves a splittable region randomly from tableName<a name="line.2957"></a>
-<span class="sourceLineNo">2958</span>   *<a name="line.2958"></a>
-<span class="sourceLineNo">2959</span>   * @param tableName name of table<a name="line.2959"></a>
-<span class="sourceLineNo">2960</span>   * @param maxAttempts maximum number of attempts, unlimited for value of -1<a name="line.2960"></a>
-<span class="sourceLineNo">2961</span>   * @return the HRegion chosen, null if none was found within limit of maxAttempts<a name="line.2961"></a>
-<span class="sourceLineNo">2962</span>   */<a name="line.2962"></a>
-<span class="sourceLineNo">2963</span>  public HRegion getSplittableRegion(TableName tableName, int maxAttempts) {<a name="line.2963"></a>
-<span class="sourceLineNo">2964</span>    List&lt;HRegion&gt; regions = getHBaseCluster().getRegions(tableName);<a name="line.2964"></a>
-<span class="sourceLineNo">2965</span>    int regCount = regions.size();<a name="line.2965"></a>
-<span class="sourceLineNo">2966</span>    Set&lt;Integer&gt; attempted = new HashSet&lt;&gt;();<a name="line.2966"></a>
-<span class="sourceLineNo">2967</span>    int idx;<a name="line.2967"></a>
-<span class="sourceLineNo">2968</span>    int attempts = 0;<a name="line.2968"></a>
-<span class="sourceLineNo">2969</span>    do {<a name="line.2969"></a>
-<span class="sourceLineNo">2970</span>      regions = getHBaseCluster().getRegions(tableName);<a name="line.2970"></a>
-<span class="sourceLineNo">2971</span>      if (regCount != regions.size()) {<a name="line.2971"></a>
-<span class="sourceLineNo">2972</span>        // if there was region movement, clear attempted Set<a name="line.2972"></a>
-<span class="sourceLineNo">2973</span>        attempted.clear();<a name="line.2973"></a>
-<span class="sourceLineNo">2974</span>      }<a name="line.2974"></a>
-<span class="sourceLineNo">2975</span>      regCount = regions.size();<a name="line.2975"></a>
-<span class="sourceLineNo">2976</span>      // There are chances that before we get the region for the table from an RS the region may<a name="line.2976"></a>
-<span class="sourceLineNo">2977</span>      // be going for CLOSE.  This may be because online schema change is enabled<a name="line.2977"></a>
-<span class="sourceLineNo">2978</span>      if (regCount &gt; 0) {<a name="line.2978"></a>
-<span class="sourceLineNo">2979</span>        idx = random.nextInt(regCount);<a name="line.2979"></a>
-<span class="sourceLineNo">2980</span>        // if we have just tried this region, there is no need to try again<a name="line.2980"></a>
-<span class="sourceLineNo">2981</span>        if (attempted.contains(idx))<a name="line.2981"></a>
-<span class="sourceLineNo">2982</span>          continue;<a name="line.2982"></a>
-<span class="sourceLineNo">2983</span>        try {<a name="line.2983"></a>
-<span class="sourceLineNo">2984</span>          regions.get(idx).checkSplit();<a name="line.2984"></a>
-<span class="sourceLineNo">2985</span>          return regions.get(idx);<a name="line.2985"></a>
-<span class="sourceLineNo">2986</span>        } catch (Exception ex) {<a name="line.2986"></a>
-<span class="sourceLineNo">2987</span>          LOG.warn("Caught exception", ex);<a name="line.2987"></a>
-<span class="sourceLineNo">2988</span>          attempted.add(idx);<a name="line.2988"></a>
-<span class="sourceLineNo">2989</span>        }<a name="line.2989"></a>
-<span class="sourceLineNo">2990</span>      }<a name="line.2990"></a>
-<span class="sourceLineNo">2991</span>      attempts++;<a name="line.2991"></a>
-<span class="sourceLineNo">2992</span>    } while (maxAttempts == -1 || attempts &lt; maxAttempts);<a name="line.2992"></a>
-<span class="sourceLineNo">2993</span>    return null;<a name="line.2993"></a>
-<span class="sourceLineNo">2994</span>  }<a name="line.2994"></a>
-<span class="sourceLineNo">2995</span><a name="line.2995"></a>
-<span class="sourceLineNo">2996</span>  public MiniZooKeeperCluster getZkCluster() {<a name="line.2996"></a>
-<span class="sourceLineNo">2997</span>    return zkCluster;<a name="line.2997"></a>
-<span class="sourceLineNo">2998</span>  }<a name="line.2998"></a>
-<span class="sourceLineNo">2999</span><a name="line.2999"></a>
-<span class="sourceLineNo">3000</span>  public void setZkCluster(MiniZooKeeperCluster zkCluster) {<a name="line.3000"></a>
-<span class="sourceLineNo">3001</span>    this.passedZkCluster = true;<a name="line.3001"></a>
-<span class="sourceLineNo">3002</span>    this.zkCluster = zkCluster;<a name="line.3002"></a>
-<span class="sourceLineNo">3003</span>    conf.setInt(HConstants.ZOOKEEPER_CLIENT_PORT, zkCluster.getClientPort());<a name="line.3003"></a>
-<span class="sourceLineNo">3004</span>  }<a name="line.3004"></a>
-<span class="sourceLineNo">3005</span><a name="line.3005"></a>
-<span class="sourceLineNo">3006</span>  public MiniDFSCluster getDFSCluster() {<a name="line.3006"></a>
-<span class="sourceLineNo">3007</span>    return dfsCluster;<a name="line.3007"></a>
-<span class="sourceLineNo">3008</span>  }<a name="line.3008"></a>
-<span class="sourceLineNo">3009</span><a name="line.3009"></a>
-<span class="sourceLineNo">3010</span>  public void setDFSCluster(MiniDFSCluster cluster) throws IllegalStateException, IOException {<a name="line.3010"></a>
-<span class="sourceLineNo">3011</span>    setDFSCluster(cluster, true);<a name="line.3011"></a>
-<span class="sourceLineNo">3012</span>  }<a name="line.3012"></a>
-<span class="sourceLineNo">3013</span><a name="line.3013"></a>
-<span class="sourceLineNo">3014</span>  /**<a name="line.3014"></a>
-<span class="sourceLineNo">3015</span>   * Set the MiniDFSCluster<a name="line.3015"></a>
-<span class="sourceLineNo">3016</span>   * @param cluster cluster to use<a name="line.3016"></a>
-<span class="sourceLineNo">3017</span>   * @param requireDown require the that cluster not be "up" (MiniDFSCluster#isClusterUp) before<a name="line.3017"></a>
-<span class="sourceLineNo">3018</span>   * it is set.<a name="line.3018"></a>
-<span class="sourceLineNo">3019</span>   * @throws IllegalStateException if the passed cluster is up when it is required to be down<a name="line.3019"></a>
-<span class="sourceLineNo">3020</span>   * @throws IOException if the FileSystem could not be set from the passed dfs cluster<a name="line.3020"></a>
-<span class="sourceLineNo">3021</span>   */<a name="line.3021"></a>
-<span class="sourceLineNo">3022</span>  public void setDFSCluster(MiniDFSCluster cluster, boolean requireDown)<a name="line.3022"></a>
-<span class="sourceLineNo">3023</span>      throws IllegalStateException, IOException {<a name="line.3023"></a>
-<span class="sourceLineNo">3024</span>    if (dfsCluster != null &amp;&amp; requireDown &amp;&amp; dfsCluster.isClusterUp()) {<a name="line.3024"></a>
-<span class="sourceLineNo">3025</span>      throw new IllegalStateException("DFSCluster is already running! Shut it down first.");<a name="line.3025"></a>
-<span class="sourceLineNo">3026</span>    }<a name="line.3026"></a>
-<span class="sourceLineNo">3027</span>    this.dfsCluster = cluster;<a name="line.3027"></a>
-<span class="sourceLineNo">3028</span>    this.setFs();<a name="line.3028"></a>
-<span class="sourceLineNo">3029</span>  }<a name="line.3029"></a>
-<span class="sourceLineNo">3030</span><a name="line.3030"></a>
-<span class="sourceLineNo">3031</span>  public FileSystem getTestFileSystem() throws IOException {<a name="line.3031"></a>
-<span class="sourceLineNo">3032</span>    return HFileSystem.get(conf);<a name="line.3032"></a>
-<span class="sourceLineNo">3033</span>  }<a name="line.3033"></a>
-<span class="sourceLineNo">3034</span><a name="line.3034"></a>
-<span class="sourceLineNo">3035</span>  /**<a name="line.3035"></a>
-<span class="sourceLineNo">3036</span>   * Wait until all regions in a table have been assigned.  Waits default timeout before giving up<a name="line.3036"></a>
-<span class="sourceLineNo">3037</span>   * (30 seconds).<a name="line.3037"></a>
-<span class="sourceLineNo">3038</span>   * @param table Table to wait on.<a name="line.3038"></a>
-<span class="sourceLineNo">3039</span>   * @throws InterruptedException<a name="line.3039"></a>
-<span class="sourceLineNo">3040</span>   * @throws IOException<a name="line.3040"></a>
-<span class="sourceLineNo">3041</span>   */<a name="line.3041"></a>
-<span class="sourceLineNo">3042</span>  public void waitTableAvailable(TableName table)<a name="line.3042"></a>
-<span class="sourceLineNo">3043</span>      throws InterruptedException, IOException {<a name="line.3043"></a>
-<span class="sourceLineNo">3044</span>    waitTableAvailable(table.getName(), 30000);<a name="line.3044"></a>
-<span class="sourceLineNo">3045</span>  }<a name="line.3045"></a>
-<span class="sourceLineNo">3046</span><a name="line.3046"></a>
-<span class="sourceLineNo">3047</span>  public void waitTableAvailable(TableName table, long timeoutMillis)<a name="line.3047"></a>
-<span class="sourceLineNo">3048</span>      throws InterruptedException, IOException {<a name="line.3048"></a>
-<span class="sourceLineNo">3049</span>    waitFor(timeoutMillis, predicateTableAvailable(table));<a name="line.3049"></a>
-<span class="sourceLineNo">3050</span>  }<a name="line.3050"></a>
-<span class="sourceLineNo">3051</span><a name="line.3051"></a>
-<span class="sourceLineNo">3052</span>  /**<a name="line.3052"></a>
-<span class="sourceLineNo">3053</span>   * Wait until all regions in a table have been assigned<a name="line.3053"></a>
-<span class="sourceLineNo">3054</span>   * @param table Table to wait on.<a name="line.3054"></a>
-<span class="sourceLineNo">3055</span>   * @param timeoutMillis Timeout.<a name="line.3055"></a>
-<span class="sourceLineNo">3056</span>   * @throws InterruptedException<a name="line.3056"></a>
-<span class="sourceLineNo">3057</span>   * @throws IOException<a name="line.3057"></a>
-<span class="sourceLineNo">3058</span>   */<a name="line.3058"></a>
-<span class="sourceLineNo">3059</span>  public void waitTableAvailable(byte[] table, long timeoutMillis)<a name="line.3059"></a>
-<span class="sourceLineNo">3060</span>  throws InterruptedException, IOException {<a name="line.3060"></a>
-<span class="sourceLineNo">3061</span>    waitFor(timeoutMillis, predicateTableAvailable(TableName.valueOf(table)));<a name="line.3061"></a>
-<span class="sourceLineNo">3062</span>  }<a name="line.3062"></a>
-<span class="sourceLineNo">3063</span><a name="line.3063"></a>
-<span class="sourceLineNo">3064</span>  public String explainTableAvailability(TableName tableName) throws IOException {<a name="line.3064"></a>
-<span class="sourceLineNo">3065</span>    String msg = explainTableState(tableName, TableState.State.ENABLED) + ", ";<a name="line.3065"></a>
-<span class="sourceLineNo">3066</span>    if (getHBaseCluster().getMaster().isAlive()) {<a name="line.3066"></a>
-<span class="sourceLineNo">3067</span>      Map&lt;RegionInfo, ServerName&gt; assignments =<a name="line.3067"></a>
-<span class="sourceLineNo">3068</span>          getHBaseCluster().getMaster().getAssignmentManager().getRegionStates()<a name="line.3068"></a>
-<span class="sourceLineNo">3069</span>              .getRegionAssignments();<a name="line.3069"></a>
-<span class="sourceLineNo">3070</span>      final List&lt;Pair&lt;RegionInfo, ServerName&gt;&gt; metaLocations =<a name="line.3070"></a>
-<span class="sourceLineNo">3071</span>          MetaTableAccessor.getTableRegionsAndLocations(connection, tableName);<a name="line.3071"></a>
-<span class="sourceLineNo">3072</span>      for (Pair&lt;RegionInfo, ServerName&gt; metaLocation : metaLocations) {<a name="line.3072"></a>
-<span class="sourceLineNo">3073</span>        RegionInfo hri = metaLocation.getFirst();<a name="line.3073"></a>
-<span class="sourceLineNo">3074</span>        ServerName sn = metaLocation.getSecond();<a name="line.3074"></a>
-<span class="sourceLineNo">3075</span>        if (!assignments.containsKey(hri)) {<a name="line.3075"></a>
-<span class="sourceLineNo">3076</span>          msg += ", region " + hri<a name="line.3076"></a>
-<span class="sourceLineNo">3077</span>              + " not assign

<TRUNCATED>

[07/14] hbase-site git commit: Published site at .

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/org/apache/hadoop/hbase/IntegrationTestingUtility.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/IntegrationTestingUtility.html b/testdevapidocs/org/apache/hadoop/hbase/IntegrationTestingUtility.html
index e9557b4..cffe907 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/IntegrationTestingUtility.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/IntegrationTestingUtility.html
@@ -273,7 +273,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html" t
 <!--   -->
 </a>
 <h3>Methods inherited from class&nbsp;org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility</a></h3>
-<code><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#assertKVListsEqual-java.lang.String-java.util.List-java.util.List-">assertKVListsEqual</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#assertRegionOnlyOnServer-org.apache.hadoop.hbase.client.RegionInfo-org.apache.hadoop.hbase.ServerName-long-">assertRegionOnlyOnServer</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#assertRegionOnServer-org.apache.hadoop.hbase.client.RegionInfo-org.apache.hadoop.hbase.ServerName-long-">assertRegionOnServer</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#assignRegion-org.apache.hadoop.hbase.client.RegionInfo-">assignRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#available-int-">available</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#checksumRows-org.apache.hadoop.hbase.client.Table-">checksumRows</a>, <a href="../../../../org/apache/h
 adoop/hbase/HBaseTestingUtility.html#cleanupDataTestDirOnTestFS--">cleanupDataTestDirOnTestFS</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#cleanupDataTestDirOnTestFS-java.lang.String-">cleanupDataTestDirOnTestFS</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#cleanupTestDir--">cleanupTestDir</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#closeRegionAndWAL-org.apache.hadoop.hbase.regionserver.HRegion-">closeRegionAndWAL</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#closeRegionAndWAL-org.apache.hadoop.hbase.regionserver.Region-">closeRegionAndWAL</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#compact-boolean-">compact</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#compact-org.apache.hadoop.hbase.TableName-boolean-">compact</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#countRows-org.apache.
 hadoop.hbase.regionserver.InternalScanner-">countRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#countRows-org.apache.hadoop.hbase.regionserver.Region-">countRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#countRows-org.apache.hadoop.hbase.regionserver.Region-org.apache.hadoop.hbase.client.Scan-">countRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#countRows-org.apache.hadoop.hbase.client.Table-">countRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#countRows-org.apache.hadoop.hbase.client.Table-byte:A...-">countRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#countRows-org.apache.hadoop.hbase.TableName-">countRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#countRows-org.apache.hadoop.hbase.client.Table-org.apache.hadoop.hbase.client.Scan-">countRows</a>, <a href="../../../../org/apache/hadoop/hb
 ase/HBaseTestingUtility.html#createLocalHRegion-byte:A-byte:A-byte:A-java.lang.String-org.apache.hadoop.conf.Configuration-boolean-org.apache.hadoop.hbase.client.Durability-org.apache.hadoop.hbase.wal.WAL-byte:A...-">createLocalHRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createLocalHRegion-org.apache.hadoop.hbase.client.RegionInfo-org.apache.hadoop.hbase.client.TableDescriptor-">createLocalHRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createLocalHRegion-org.apache.hadoop.hbase.client.RegionInfo-org.apache.hadoop.hbase.client.TableDescriptor-org.apache.hadoop.hbase.wal.WAL-">createLocalHRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createLocalHRegion-org.apache.hadoop.hbase.client.TableDescriptor-byte:A-byte:A-">createLocalHRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createLocalHRegion-org.apache.hadoop.hbase.TableName-byte:A-byte:A-boo
 lean-org.apache.hadoop.hbase.client.Durability-org.apache.hadoop.hbase.wal.WAL-byte:A...-">createLocalHRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createLocalHRegionWithInMemoryFlags-org.apache.hadoop.hbase.TableName-byte:A-byte:A-boolean-org.apache.hadoop.hbase.client.Durability-org.apache.hadoop.hbase.wal.WAL-boolean:A-byte:A...-">createLocalHRegionWithInMemoryFlags</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createLocalHTU--">createLocalHTU</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createLocalHTU-org.apache.hadoop.conf.Configuration-">createLocalHTU</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createMockRegionServerService--">createMockRegionServerService</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createMockRegionServerService-org.apache.hadoop.hbase.ipc.RpcServerInterface-">createMockRegionServerService</a>, <a href="
 ../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createMockRegionServerService-org.apache.hadoop.hbase.ServerName-">createMockRegionServerService</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createMultiRegionsInMeta-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.HTableDescriptor-byte:A:A-">createMultiRegionsInMeta</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createMultiRegionsInMeta-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.client.TableDescriptor-byte:A:A-">createMultiRegionsInMeta</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createMultiRegionTable-org.apache.hadoop.hbase.TableName-byte:A-">createMultiRegionTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createMultiRegionTable-org.apache.hadoop.hbase.TableName-byte:A:A-">createMultiRegionTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#
 createMultiRegionTable-org.apache.hadoop.hbase.TableName-byte:A:A-int-">createMultiRegionTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createMultiRegionTable-org.apache.hadoop.hbase.TableName-byte:A-int-">createMultiRegionTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createPreSplitLoadTestTable-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.client.TableDescriptor-org.apache.hadoop.hbase.client.ColumnFamilyDescriptor-">createPreSplitLoadTestTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createPreSplitLoadTestTable-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.client.TableDescriptor-org.apache.hadoop.hbase.client.ColumnFamilyDescriptor:A-int-">createPreSplitLoadTestTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createPreSplitLoadTestTable-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.client.TableDescriptor
 -org.apache.hadoop.hbase.client.ColumnFamilyDescriptor:A-org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm-int-">createPreSplitLoadTestTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createPreSplitLoadTestTable-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.client.TableDescriptor-org.apache.hadoop.hbase.client.ColumnFamilyDescriptor-int-">createPreSplitLoadTestTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createPreSplitLoadTestTable-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.TableName-byte:A:A-org.apache.hadoop.hbase.io.compress.Compression.Algorithm-org.apache.hadoop.hbase.io.encoding.DataBlockEncoding-int-int-org.apache.hadoop.hbase.client.Durability-">createPreSplitLoadTestTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createPreSplitLoadTestTable-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.TableName-byte:A-org.apache.hadoo
 p.hbase.io.compress.Compression.Algorithm-org.apache.hadoop.hbase.io.encoding.DataBlockEncoding-">createPreSplitLoadTestTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createPreSplitLoadTestTable-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.TableName-byte:A-org.apache.hadoop.hbase.io.compress.Compression.Algorithm-org.apache.hadoop.hbase.io.encoding.DataBlockEncoding-int-int-org.apache.hadoop.hbase.client.Durability-">createPreSplitLoadTestTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createRandomTable-org.apache.hadoop.hbase.TableName-java.util.Collection-int-int-int-int-int-">createRandomTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createRegionAndWAL-org.apache.hadoop.hbase.client.RegionInfo-org.apache.hadoop.fs.Path-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.client.TableDescriptor-">createRegionAndWAL</a>, <a href="../../../../org/apache/hadoop
 /hbase/HBaseTestingUtility.html#createRegionAndWAL-org.apache.hadoop.hbase.client.RegionInfo-org.apache.hadoop.fs.Path-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.client.TableDescriptor-boolean-">createRegionAndWAL</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createRootDir--">createRootDir</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createRootDir-boolean-">createRootDir</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.client.TableDescriptor-byte:A:A-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.client.TableDescriptor-byte:A:A-byte:A:A-org.apache.hadoop.conf.Configuration-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.client.TableDescriptor-byte:A:A-org.apache.hadoop.conf.Configuration-">crea
 teTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-byte:A:A-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-byte:A:A-org.apache.hadoop.conf.Configuration-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-int-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-int:A-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTesting
 Utility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-int-byte:A:A-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-int-byte:A-byte:A-int-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-int-int-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-int-int-java.lang.String-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A-byte:A:A-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A-int-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableNa
 me-java.lang.String-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-java.lang.String:A-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTableDescriptor-java.lang.String-">createTableDescriptor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTableDescriptor-java.lang.String-int-int-int-org.apache.hadoop.hbase.KeepDeletedCells-">createTableDescriptor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTableDescriptor-org.apache.hadoop.hbase.TableName-">createTableDescriptor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTableDescriptor-org.apache.hadoop.hbase.TableName-byte:A-">createTableDescriptor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTableDescriptor-org.apache.hadoop.hbase.TableName-byte:A:A-int-">createTableDescri
 ptor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTableDescriptor-org.apache.hadoop.hbase.TableName-int-int-int-org.apache.hadoop.hbase.KeepDeletedCells-">createTableDescriptor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTestRegion-java.lang.String-org.apache.hadoop.hbase.client.ColumnFamilyDescriptor-">createTestRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createWal-org.apache.hadoop.conf.Configuration-org.apache.hadoop.fs.Path-org.apache.hadoop.hbase.client.RegionInfo-">createWal</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createWALRootDir--">createWALRootDir</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#deleteNumericRows-org.apache.hadoop.hbase.client.Table-byte:A-int-int-">deleteNumericRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#deleteTable-org.apache.hadoop.hbase.TableName-">
 deleteTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#deleteTableData-org.apache.hadoop.hbase.TableName-">deleteTableData</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#deleteTableIfAny-org.apache.hadoop.hbase.TableName-">deleteTableIfAny</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#enableDebug-java.lang.Class-">enableDebug</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#ensureSomeNonStoppedRegionServersAvailable-int-">ensureSomeNonStoppedRegionServersAvailable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#ensureSomeRegionServersAvailable-int-">ensureSomeRegionServersAvailable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#expireMasterSession--">expireMasterSession</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#expireRegionServerSession-int-">expireRegionServerSession</a>, <a href=".
 ./../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#expireSession-org.apache.hadoop.hbase.zookeeper.ZKWatcher-">expireSession</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#expireSession-org.apache.hadoop.hbase.zookeeper.ZKWatcher-boolean-">expireSession</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#explainTableAvailability-org.apache.hadoop.hbase.TableName-">explainTableAvailability</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#explainTableState-org.apache.hadoop.hbase.TableName-org.apache.hadoop.hbase.client.TableState.State-">explainTableState</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#findLastTableState-org.apache.hadoop.hbase.TableName-">findLastTableState</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#flush--">flush</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#flush-org.apache.hadoop.hbase.TableN
 ame-">flush</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#generateColumnDescriptors--">generateColumnDescriptors</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#generateColumnDescriptors-java.lang.String-">generateColumnDescriptors</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getAdmin--">getAdmin</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getAllOnlineRegions-org.apache.hadoop.hbase.MiniHBaseCluster-">getAllOnlineRegions</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getClosestRowBefore-org.apache.hadoop.hbase.regionserver.Region-byte:A-byte:A-">getClosestRowBefore</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getClusterKey--">getClusterKey</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getClusterTestDir--">getClusterTestDir</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTesti
 ngUtility.html#getConfiguration--">getConfiguration</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getConnection--">getConnection</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getDataTestDirOnTestFS--">getDataTestDirOnTestFS</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getDataTestDirOnTestFS-java.lang.String-">getDataTestDirOnTestFS</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getDefaultRootDirPath--">getDefaultRootDirPath</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getDefaultRootDirPath-boolean-">getDefaultRootDirPath</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getDFSCluster--">getDFSCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getDifferentUser-org.apache.hadoop.conf.Configuration-java.lang.String-">getDifferentUser</a>, <a href="../../../../org/apache/hadoop/hbase/HBa
 seTestingUtility.html#getFromStoreFile-org.apache.hadoop.hbase.regionserver.HStore-byte:A-java.util.NavigableSet-">getFromStoreFile</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getFromStoreFile-org.apache.hadoop.hbase.regionserver.HStore-org.apache.hadoop.hbase.client.Get-">getFromStoreFile</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getHBaseAdmin--">getHBaseAdmin</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getHBaseCluster--">getHBaseCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getHBaseClusterInterface--">getHBaseClusterInterface</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getMetaRSPort-org.apache.hadoop.hbase.client.Connection-">getMetaRSPort</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getMetaTableDescriptor--">getMetaTableDescriptor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTesti
 ngUtility.html#getMetaTableDescriptorBuilder--">getMetaTableDescriptorBuilder</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getMetaTableRows--">getMetaTableRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getMetaTableRows-org.apache.hadoop.hbase.TableName-">getMetaTableRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getMiniHBaseCluster--">getMiniHBaseCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getNumHFiles-org.apache.hadoop.hbase.TableName-byte:A-">getNumHFiles</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getNumHFilesForRS-org.apache.hadoop.hbase.regionserver.HRegionServer-org.apache.hadoop.hbase.TableName-byte:A-">getNumHFilesForRS</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getRegionSplitStartKeys-byte:A-byte:A-int-">getRegionSplitStartKeys</a>, <a href="../../../../org/apache/hadoop/hbase/HB
 aseTestingUtility.html#getRSForFirstRegionInTable-org.apache.hadoop.hbase.TableName-">getRSForFirstRegionInTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getSplittableRegion-org.apache.hadoop.hbase.TableName-int-">getSplittableRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getSupportedCompressionAlgorithms--">getSupportedCompressionAlgorithms</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getTestFileSystem--">getTestFileSystem</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getZkCluster--">getZkCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getZooKeeperWatcher--">getZooKeeperWatcher</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getZooKeeperWatcher-org.apache.hadoop.hbase.HBaseTestingUtility-">getZooKeeperWatcher</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#isReadShort
 CircuitOn--">isReadShortCircuitOn</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadNumericRows-org.apache.hadoop.hbase.client.Table-byte:A-int-int-">loadNumericRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadRandomRows-org.apache.hadoop.hbase.client.Table-byte:A-int-int-">loadRandomRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadRegion-org.apache.hadoop.hbase.regionserver.HRegion-byte:A-">loadRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadRegion-org.apache.hadoop.hbase.regionserver.HRegion-byte:A-boolean-">loadRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadRegion-org.apache.hadoop.hbase.regionserver.Region-byte:A-">loadRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A-">loadTable</a>, <a href="../../../../org/apache/hadoo
 p/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A:A-">loadTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A:A-byte:A-">loadTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A:A-byte:A-boolean-">loadTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A-boolean-">loadTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#memStoreTSTagsAndOffheapCombination--">memStoreTSTagsAndOffheapCombination</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#modifyTableSync-org.apache.hadoop.hbase.client.Admin-org.apache.hadoop.hbase.client.TableDescriptor-">modifyTableSync</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#moveRegionAndWait-org
 .apache.hadoop.hbase.client.RegionInfo-org.apache.hadoop.hbase.ServerName-">moveRegionAndWait</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#predicateNoRegionsInTransition--">predicateNoRegionsInTransition</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#predicateTableAvailable-org.apache.hadoop.hbase.TableName-">predicateTableAvailable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#predicateTableDisabled-org.apache.hadoop.hbase.TableName-">predicateTableDisabled</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#predicateTableEnabled-org.apache.hadoop.hbase.TableName-">predicateTableEnabled</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#randomFreePort--">randomFreePort</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#randomMultiCastAddress--">randomMultiCastAddress</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTesti
 ngUtility.html#restartHBaseCluster-int-">restartHBaseCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#safeGetAsStr-java.util.List-int-">safeGetAsStr</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setDFSCluster-org.apache.hadoop.hdfs.MiniDFSCluster-">setDFSCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setDFSCluster-org.apache.hadoop.hdfs.MiniDFSCluster-boolean-">setDFSCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setFileSystemURI-java.lang.String-">setFileSystemURI</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setHBaseCluster-org.apache.hadoop.hbase.HBaseCluster-">setHBaseCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setMaxRecoveryErrorCount-java.io.OutputStream-int-">setMaxRecoveryErrorCount</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setReplicas-org.apa
 che.hadoop.hbase.client.Admin-org.apache.hadoop.hbase.TableName-int-">setReplicas</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setupDataTestDir--">setupDataTestDir</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setupMiniKdc-java.io.File-">setupMiniKdc</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setZkCluster-org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster-">setZkCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniCluster--">shutdownMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniDFSCluster--">shutdownMiniDFSCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniHBaseCluster--">shutdownMiniHBaseCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniMapReduceCluster--">shutdownMiniMapReduceCluster</a>, <a href="../../../
 ../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniZKCluster--">shutdownMiniZKCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster--">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-boolean-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-boolean-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-boolean-boolean-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-boolean-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HB
 aseTestingUtility.html#startMiniCluster-int-int-int-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-int-java.lang.String:A-java.lang.Class-java.lang.Class-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-int-java.lang.String:A-java.lang.Class-java.lang.Class-boolean-boolean-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-java.lang.String:A-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-java.lang.String:A-boolean-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-java.lang.String:A-java.lang.Class-java.lang.Class-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-int-">startMi
 niDFSCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-int-java.lang.String:A-">startMiniDFSCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-int-java.lang.String:A-java.lang.String:A-">startMiniDFSCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-java.lang.String:A-">startMiniDFSCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSClusterForTestWAL-int-">startMiniDFSClusterForTestWAL</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniHBaseCluster-int-int-">startMiniHBaseCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniHBaseCluster-int-int-java.lang.Class-java.lang.Class-boolean-boolean-">startMiniHBaseCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniMapReduceCluster--
 ">startMiniMapReduceCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniZKCluster--">startMiniZKCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniZKCluster-int-int...-">startMiniZKCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#truncateTable-org.apache.hadoop.hbase.TableName-">truncateTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#truncateTable-org.apache.hadoop.hbase.TableName-boolean-">truncateTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#unassignRegion-byte:A-">unassignRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#unassignRegion-java.lang.String-">unassignRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#unassignRegionByRow-byte:A-org.apache.hadoop.hbase.client.RegionLocator-">unassignRegionByRow</a>, <a href="../../../../org/apac
 he/hadoop/hbase/HBaseTestingUtility.html#unassignRegionByRow-java.lang.String-org.apache.hadoop.hbase.client.RegionLocator-">unassignRegionByRow</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.regionserver.HRegion-byte:A-int-int-">verifyNumericRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.regionserver.HRegion-byte:A-int-int-boolean-">verifyNumericRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.regionserver.Region-byte:A-int-int-">verifyNumericRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.regionserver.Region-byte:A-int-int-boolean-">verifyNumericRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.client.Table-byte:A-int-int-i
 nt-">verifyNumericRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitFor-long-long-boolean-org.apache.hadoop.hbase.Waiter.Predicate-">waitFor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitFor-long-long-org.apache.hadoop.hbase.Waiter.Predicate-">waitFor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitFor-long-org.apache.hadoop.hbase.Waiter.Predicate-">waitFor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitForHostPort-java.lang.String-int-">waitForHostPort</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitLabelAvailable-long-java.lang.String...-">waitLabelAvailable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableAvailable-byte:A-long-">waitTableAvailable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableAvailable-org.apache.hadoop.hbase.TableName-">waitTableAva
 ilable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableAvailable-org.apache.hadoop.hbase.TableName-long-">waitTableAvailable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableDisabled-byte:A-">waitTableDisabled</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableDisabled-byte:A-long-">waitTableDisabled</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableDisabled-org.apache.hadoop.hbase.TableName-long-">waitTableDisabled</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableEnabled-byte:A-long-">waitTableEnabled</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableEnabled-org.apache.hadoop.hbase.TableName-">waitTableEnabled</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableEnabled-org.apache.hadoop.hbase.TableName-long-">waitTableEnabled</a>, <a href="../../.
 ./../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilAllRegionsAssigned-org.apache.hadoop.hbase.TableName-">waitUntilAllRegionsAssigned</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilAllRegionsAssigned-org.apache.hadoop.hbase.TableName-long-">waitUntilAllRegionsAssigned</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilAllSystemRegionsAssigned--">waitUntilAllSystemRegionsAssigned</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilNoRegionsInTransition--">waitUntilNoRegionsInTransition</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilNoRegionsInTransition-long-">waitUntilNoRegionsInTransition</a></code></li>
+<code><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#assertKVListsEqual-java.lang.String-java.util.List-java.util.List-">assertKVListsEqual</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#assertRegionOnlyOnServer-org.apache.hadoop.hbase.client.RegionInfo-org.apache.hadoop.hbase.ServerName-long-">assertRegionOnlyOnServer</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#assertRegionOnServer-org.apache.hadoop.hbase.client.RegionInfo-org.apache.hadoop.hbase.ServerName-long-">assertRegionOnServer</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#assignRegion-org.apache.hadoop.hbase.client.RegionInfo-">assignRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#available-int-">available</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#checksumRows-org.apache.hadoop.hbase.client.Table-">checksumRows</a>, <a href="../../../../org/apache/h
 adoop/hbase/HBaseTestingUtility.html#cleanupDataTestDirOnTestFS--">cleanupDataTestDirOnTestFS</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#cleanupDataTestDirOnTestFS-java.lang.String-">cleanupDataTestDirOnTestFS</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#cleanupTestDir--">cleanupTestDir</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#closeRegionAndWAL-org.apache.hadoop.hbase.regionserver.HRegion-">closeRegionAndWAL</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#closeRegionAndWAL-org.apache.hadoop.hbase.regionserver.Region-">closeRegionAndWAL</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#compact-boolean-">compact</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#compact-org.apache.hadoop.hbase.TableName-boolean-">compact</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#countRows-org.apache.
 hadoop.hbase.regionserver.InternalScanner-">countRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#countRows-org.apache.hadoop.hbase.regionserver.Region-">countRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#countRows-org.apache.hadoop.hbase.regionserver.Region-org.apache.hadoop.hbase.client.Scan-">countRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#countRows-org.apache.hadoop.hbase.client.Table-">countRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#countRows-org.apache.hadoop.hbase.client.Table-byte:A...-">countRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#countRows-org.apache.hadoop.hbase.TableName-">countRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#countRows-org.apache.hadoop.hbase.client.Table-org.apache.hadoop.hbase.client.Scan-">countRows</a>, <a href="../../../../org/apache/hadoop/hb
 ase/HBaseTestingUtility.html#createLocalHRegion-byte:A-byte:A-byte:A-java.lang.String-org.apache.hadoop.conf.Configuration-boolean-org.apache.hadoop.hbase.client.Durability-org.apache.hadoop.hbase.wal.WAL-byte:A...-">createLocalHRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createLocalHRegion-org.apache.hadoop.hbase.client.RegionInfo-org.apache.hadoop.hbase.client.TableDescriptor-">createLocalHRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createLocalHRegion-org.apache.hadoop.hbase.client.RegionInfo-org.apache.hadoop.hbase.client.TableDescriptor-org.apache.hadoop.hbase.wal.WAL-">createLocalHRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createLocalHRegion-org.apache.hadoop.hbase.client.TableDescriptor-byte:A-byte:A-">createLocalHRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createLocalHRegion-org.apache.hadoop.hbase.TableName-byte:A-byte:A-boo
 lean-org.apache.hadoop.hbase.client.Durability-org.apache.hadoop.hbase.wal.WAL-byte:A...-">createLocalHRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createLocalHRegionWithInMemoryFlags-org.apache.hadoop.hbase.TableName-byte:A-byte:A-boolean-org.apache.hadoop.hbase.client.Durability-org.apache.hadoop.hbase.wal.WAL-boolean:A-byte:A...-">createLocalHRegionWithInMemoryFlags</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createLocalHTU--">createLocalHTU</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createLocalHTU-org.apache.hadoop.conf.Configuration-">createLocalHTU</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createMockRegionServerService--">createMockRegionServerService</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createMockRegionServerService-org.apache.hadoop.hbase.ipc.RpcServerInterface-">createMockRegionServerService</a>, <a href="
 ../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createMockRegionServerService-org.apache.hadoop.hbase.ServerName-">createMockRegionServerService</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createMultiRegionsInMeta-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.HTableDescriptor-byte:A:A-">createMultiRegionsInMeta</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createMultiRegionsInMeta-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.client.TableDescriptor-byte:A:A-">createMultiRegionsInMeta</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createMultiRegionTable-org.apache.hadoop.hbase.TableName-byte:A-">createMultiRegionTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createMultiRegionTable-org.apache.hadoop.hbase.TableName-byte:A:A-">createMultiRegionTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#
 createMultiRegionTable-org.apache.hadoop.hbase.TableName-byte:A:A-int-">createMultiRegionTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createMultiRegionTable-org.apache.hadoop.hbase.TableName-byte:A-int-">createMultiRegionTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createPreSplitLoadTestTable-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.client.TableDescriptor-org.apache.hadoop.hbase.client.ColumnFamilyDescriptor-">createPreSplitLoadTestTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createPreSplitLoadTestTable-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.client.TableDescriptor-org.apache.hadoop.hbase.client.ColumnFamilyDescriptor:A-int-">createPreSplitLoadTestTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createPreSplitLoadTestTable-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.client.TableDescriptor
 -org.apache.hadoop.hbase.client.ColumnFamilyDescriptor:A-org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm-int-">createPreSplitLoadTestTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createPreSplitLoadTestTable-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.client.TableDescriptor-org.apache.hadoop.hbase.client.ColumnFamilyDescriptor-int-">createPreSplitLoadTestTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createPreSplitLoadTestTable-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.TableName-byte:A:A-org.apache.hadoop.hbase.io.compress.Compression.Algorithm-org.apache.hadoop.hbase.io.encoding.DataBlockEncoding-int-int-org.apache.hadoop.hbase.client.Durability-">createPreSplitLoadTestTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createPreSplitLoadTestTable-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.TableName-byte:A-org.apache.hadoo
 p.hbase.io.compress.Compression.Algorithm-org.apache.hadoop.hbase.io.encoding.DataBlockEncoding-">createPreSplitLoadTestTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createPreSplitLoadTestTable-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.TableName-byte:A-org.apache.hadoop.hbase.io.compress.Compression.Algorithm-org.apache.hadoop.hbase.io.encoding.DataBlockEncoding-int-int-org.apache.hadoop.hbase.client.Durability-">createPreSplitLoadTestTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createRandomTable-org.apache.hadoop.hbase.TableName-java.util.Collection-int-int-int-int-int-">createRandomTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createRegionAndWAL-org.apache.hadoop.hbase.client.RegionInfo-org.apache.hadoop.fs.Path-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.client.TableDescriptor-">createRegionAndWAL</a>, <a href="../../../../org/apache/hadoop
 /hbase/HBaseTestingUtility.html#createRegionAndWAL-org.apache.hadoop.hbase.client.RegionInfo-org.apache.hadoop.fs.Path-org.apache.hadoop.conf.Configuration-org.apache.hadoop.hbase.client.TableDescriptor-boolean-">createRegionAndWAL</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createRootDir--">createRootDir</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createRootDir-boolean-">createRootDir</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.client.TableDescriptor-byte:A:A-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.client.TableDescriptor-byte:A:A-byte:A:A-org.apache.hadoop.conf.Configuration-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.client.TableDescriptor-byte:A:A-org.apache.hadoop.conf.Configuration-">crea
 teTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-byte:A:A-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-byte:A:A-org.apache.hadoop.conf.Configuration-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-int-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-int:A-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTesting
 Utility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-int-byte:A:A-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-int-byte:A-byte:A-int-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-int-int-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A:A-int-int-java.lang.String-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A-byte:A:A-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-byte:A-int-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableNa
 me-java.lang.String-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTable-org.apache.hadoop.hbase.TableName-java.lang.String:A-">createTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTableDescriptor-java.lang.String-">createTableDescriptor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTableDescriptor-java.lang.String-int-int-int-org.apache.hadoop.hbase.KeepDeletedCells-">createTableDescriptor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTableDescriptor-org.apache.hadoop.hbase.TableName-">createTableDescriptor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTableDescriptor-org.apache.hadoop.hbase.TableName-byte:A-">createTableDescriptor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTableDescriptor-org.apache.hadoop.hbase.TableName-byte:A:A-int-">createTableDescri
 ptor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTableDescriptor-org.apache.hadoop.hbase.TableName-int-int-int-org.apache.hadoop.hbase.KeepDeletedCells-">createTableDescriptor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createTestRegion-java.lang.String-org.apache.hadoop.hbase.client.ColumnFamilyDescriptor-">createTestRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createWal-org.apache.hadoop.conf.Configuration-org.apache.hadoop.fs.Path-org.apache.hadoop.hbase.client.RegionInfo-">createWal</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#createWALRootDir--">createWALRootDir</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#deleteNumericRows-org.apache.hadoop.hbase.client.Table-byte:A-int-int-">deleteNumericRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#deleteTable-org.apache.hadoop.hbase.TableName-">
 deleteTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#deleteTableData-org.apache.hadoop.hbase.TableName-">deleteTableData</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#deleteTableIfAny-org.apache.hadoop.hbase.TableName-">deleteTableIfAny</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#enableDebug-java.lang.Class-">enableDebug</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#ensureSomeNonStoppedRegionServersAvailable-int-">ensureSomeNonStoppedRegionServersAvailable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#ensureSomeRegionServersAvailable-int-">ensureSomeRegionServersAvailable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#expireMasterSession--">expireMasterSession</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#expireRegionServerSession-int-">expireRegionServerSession</a>, <a href=".
 ./../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#expireSession-org.apache.hadoop.hbase.zookeeper.ZKWatcher-">expireSession</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#expireSession-org.apache.hadoop.hbase.zookeeper.ZKWatcher-boolean-">expireSession</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#explainTableAvailability-org.apache.hadoop.hbase.TableName-">explainTableAvailability</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#explainTableState-org.apache.hadoop.hbase.TableName-org.apache.hadoop.hbase.client.TableState.State-">explainTableState</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#findLastTableState-org.apache.hadoop.hbase.TableName-">findLastTableState</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#flush--">flush</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#flush-org.apache.hadoop.hbase.TableN
 ame-">flush</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#generateColumnDescriptors--">generateColumnDescriptors</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#generateColumnDescriptors-java.lang.String-">generateColumnDescriptors</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getAdmin--">getAdmin</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getAllOnlineRegions-org.apache.hadoop.hbase.MiniHBaseCluster-">getAllOnlineRegions</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getClosestRowBefore-org.apache.hadoop.hbase.regionserver.Region-byte:A-byte:A-">getClosestRowBefore</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getClusterKey--">getClusterKey</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getClusterTestDir--">getClusterTestDir</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTesti
 ngUtility.html#getConfiguration--">getConfiguration</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getConnection--">getConnection</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getDataTestDirOnTestFS--">getDataTestDirOnTestFS</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getDataTestDirOnTestFS-java.lang.String-">getDataTestDirOnTestFS</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getDefaultRootDirPath--">getDefaultRootDirPath</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getDefaultRootDirPath-boolean-">getDefaultRootDirPath</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getDFSCluster--">getDFSCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getDifferentUser-org.apache.hadoop.conf.Configuration-java.lang.String-">getDifferentUser</a>, <a href="../../../../org/apache/hadoop/hbase/HBa
 seTestingUtility.html#getFromStoreFile-org.apache.hadoop.hbase.regionserver.HStore-byte:A-java.util.NavigableSet-">getFromStoreFile</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getFromStoreFile-org.apache.hadoop.hbase.regionserver.HStore-org.apache.hadoop.hbase.client.Get-">getFromStoreFile</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getHBaseAdmin--">getHBaseAdmin</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getHBaseCluster--">getHBaseCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getHBaseClusterInterface--">getHBaseClusterInterface</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getMetaRSPort-org.apache.hadoop.hbase.client.Connection-">getMetaRSPort</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getMetaTableDescriptor--">getMetaTableDescriptor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTesti
 ngUtility.html#getMetaTableDescriptorBuilder--">getMetaTableDescriptorBuilder</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getMetaTableRows--">getMetaTableRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getMetaTableRows-org.apache.hadoop.hbase.TableName-">getMetaTableRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getMiniHBaseCluster--">getMiniHBaseCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getNumHFiles-org.apache.hadoop.hbase.TableName-byte:A-">getNumHFiles</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getNumHFilesForRS-org.apache.hadoop.hbase.regionserver.HRegionServer-org.apache.hadoop.hbase.TableName-byte:A-">getNumHFilesForRS</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getOtherRegionServer-org.apache.hadoop.hbase.regionserver.HRegionServer-">getOtherRegionServer</a>, <a href="../../../..
 /org/apache/hadoop/hbase/HBaseTestingUtility.html#getRegionSplitStartKeys-byte:A-byte:A-int-">getRegionSplitStartKeys</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getRSForFirstRegionInTable-org.apache.hadoop.hbase.TableName-">getRSForFirstRegionInTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getSplittableRegion-org.apache.hadoop.hbase.TableName-int-">getSplittableRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getSupportedCompressionAlgorithms--">getSupportedCompressionAlgorithms</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getTestFileSystem--">getTestFileSystem</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getZkCluster--">getZkCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getZooKeeperWatcher--">getZooKeeperWatcher</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#ge
 tZooKeeperWatcher-org.apache.hadoop.hbase.HBaseTestingUtility-">getZooKeeperWatcher</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#isReadShortCircuitOn--">isReadShortCircuitOn</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadNumericRows-org.apache.hadoop.hbase.client.Table-byte:A-int-int-">loadNumericRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadRandomRows-org.apache.hadoop.hbase.client.Table-byte:A-int-int-">loadRandomRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadRegion-org.apache.hadoop.hbase.regionserver.HRegion-byte:A-">loadRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadRegion-org.apache.hadoop.hbase.regionserver.HRegion-byte:A-boolean-">loadRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadRegion-org.apache.hadoop.hbase.regionserver.Region-byte:A-">loadRegion</a>, <a href=
 "../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A-">loadTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A:A-">loadTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A:A-byte:A-">loadTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A:A-byte:A-boolean-">loadTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A-boolean-">loadTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#memStoreTSTagsAndOffheapCombination--">memStoreTSTagsAndOffheapCombination</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#modifyTableSync-org.apache.hadoop.hbase.clie
 nt.Admin-org.apache.hadoop.hbase.client.TableDescriptor-">modifyTableSync</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#moveRegionAndWait-org.apache.hadoop.hbase.client.RegionInfo-org.apache.hadoop.hbase.ServerName-">moveRegionAndWait</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#predicateNoRegionsInTransition--">predicateNoRegionsInTransition</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#predicateTableAvailable-org.apache.hadoop.hbase.TableName-">predicateTableAvailable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#predicateTableDisabled-org.apache.hadoop.hbase.TableName-">predicateTableDisabled</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#predicateTableEnabled-org.apache.hadoop.hbase.TableName-">predicateTableEnabled</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#randomFreePort--">randomFreePort</a>, <a href="
 ../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#randomMultiCastAddress--">randomMultiCastAddress</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#restartHBaseCluster-int-">restartHBaseCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#safeGetAsStr-java.util.List-int-">safeGetAsStr</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setDFSCluster-org.apache.hadoop.hdfs.MiniDFSCluster-">setDFSCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setDFSCluster-org.apache.hadoop.hdfs.MiniDFSCluster-boolean-">setDFSCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setFileSystemURI-java.lang.String-">setFileSystemURI</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setHBaseCluster-org.apache.hadoop.hbase.HBaseCluster-">setHBaseCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#s
 etMaxRecoveryErrorCount-java.io.OutputStream-int-">setMaxRecoveryErrorCount</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setReplicas-org.apache.hadoop.hbase.client.Admin-org.apache.hadoop.hbase.TableName-int-">setReplicas</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setupDataTestDir--">setupDataTestDir</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setupMiniKdc-java.io.File-">setupMiniKdc</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setZkCluster-org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster-">setZkCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniCluster--">shutdownMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniDFSCluster--">shutdownMiniDFSCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniHBaseCluster--">shutdownMiniHB
 aseCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniMapReduceCluster--">shutdownMiniMapReduceCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniZKCluster--">shutdownMiniZKCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster--">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-boolean-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-boolean-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-boolean-boolean-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-">startMiniCluster</a>, <a h
 ref="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-boolean-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-int-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-int-java.lang.String:A-java.lang.Class-java.lang.Class-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-int-java.lang.String:A-java.lang.Class-java.lang.Class-boolean-boolean-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-java.lang.String:A-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-java.lang.String:A-boolean-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-java.lan
 g.String:A-java.lang.Class-java.lang.Class-">startMiniCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-int-">startMiniDFSCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-int-java.lang.String:A-">startMiniDFSCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-int-java.lang.String:A-java.lang.String:A-">startMiniDFSCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-java.lang.String:A-">startMiniDFSCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSClusterForTestWAL-int-">startMiniDFSClusterForTestWAL</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniHBaseCluster-int-int-">startMiniHBaseCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniHBaseCluster-int-int-java
 .lang.Class-java.lang.Class-boolean-boolean-">startMiniHBaseCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniMapReduceCluster--">startMiniMapReduceCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniZKCluster--">startMiniZKCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniZKCluster-int-int...-">startMiniZKCluster</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#truncateTable-org.apache.hadoop.hbase.TableName-">truncateTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#truncateTable-org.apache.hadoop.hbase.TableName-boolean-">truncateTable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#unassignRegion-byte:A-">unassignRegion</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#unassignRegion-java.lang.String-">unassignRegion</a>, <a href="../../../../org/apa
 che/hadoop/hbase/HBaseTestingUtility.html#unassignRegionByRow-byte:A-org.apache.hadoop.hbase.client.RegionLocator-">unassignRegionByRow</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#unassignRegionByRow-java.lang.String-org.apache.hadoop.hbase.client.RegionLocator-">unassignRegionByRow</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.regionserver.HRegion-byte:A-int-int-">verifyNumericRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.regionserver.HRegion-byte:A-int-int-boolean-">verifyNumericRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.regionserver.Region-byte:A-int-int-">verifyNumericRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.regionserver.Region-byte:A-int-int-bool
 ean-">verifyNumericRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.client.Table-byte:A-int-int-int-">verifyNumericRows</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitFor-long-long-boolean-org.apache.hadoop.hbase.Waiter.Predicate-">waitFor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitFor-long-long-org.apache.hadoop.hbase.Waiter.Predicate-">waitFor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitFor-long-org.apache.hadoop.hbase.Waiter.Predicate-">waitFor</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitForHostPort-java.lang.String-int-">waitForHostPort</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitLabelAvailable-long-java.lang.String...-">waitLabelAvailable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableAvailable-byte:
 A-long-">waitTableAvailable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableAvailable-org.apache.hadoop.hbase.TableName-">waitTableAvailable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableAvailable-org.apache.hadoop.hbase.TableName-long-">waitTableAvailable</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableDisabled-byte:A-">waitTableDisabled</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableDisabled-byte:A-long-">waitTableDisabled</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableDisabled-org.apache.hadoop.hbase.TableName-long-">waitTableDisabled</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableEnabled-byte:A-long-">waitTableEnabled</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableEnabled-org.apache.hadoop.hbase.TableName-">waitTableEnabled</
 a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableEnabled-org.apache.hadoop.hbase.TableName-long-">waitTableEnabled</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilAllRegionsAssigned-org.apache.hadoop.hbase.TableName-">waitUntilAllRegionsAssigned</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilAllRegionsAssigned-org.apache.hadoop.hbase.TableName-long-">waitUntilAllRegionsAssigned</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilAllSystemRegionsAssigned--">waitUntilAllSystemRegionsAssigned</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilNoRegionsInTransition--">waitUntilNoRegionsInTransition</a>, <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilNoRegionsInTransition-long-">waitUntilNoRegionsInTransition</a></code></li>
 </ul>
 <ul class="blockList">
 <li class="blockList"><a name="methods.inherited.from.class.org.apache.hadoop.hbase.HBaseCommonTestingUtility">

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/org/apache/hadoop/hbase/backup/package-tree.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/backup/package-tree.html b/testdevapidocs/org/apache/hadoop/hbase/backup/package-tree.html
index 1f4569c..7651965 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/backup/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/backup/package-tree.html
@@ -142,8 +142,8 @@
 <ul>
 <li type="circle">java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Enum.html?is-external=true" title="class or interface in java.lang"><span class="typeNameLink">Enum</span></a>&lt;E&gt; (implements java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Comparable.html?is-external=true" title="class or interface in java.lang">Comparable</a>&lt;T&gt;, java.io.<a href="http://docs.oracle.com/javase/8/docs/api/java/io/Serializable.html?is-external=true" title="class or interface in java.io">Serializable</a>)
 <ul>
-<li type="circle">org.apache.hadoop.hbase.backup.<a href="../../../../../org/apache/hadoop/hbase/backup/TestBackupDeleteWithFailures.Failure.html" title="enum in org.apache.hadoop.hbase.backup"><span class="typeNameLink">TestBackupDeleteWithFailures.Failure</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.backup.<a href="../../../../../org/apache/hadoop/hbase/backup/TestIncrementalBackupMergeWithFailures.FailurePhase.html" title="enum in org.apache.hadoop.hbase.backup"><span class="typeNameLink">TestIncrementalBackupMergeWithFailures.FailurePhase</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.backup.<a href="../../../../../org/apache/hadoop/hbase/backup/TestBackupDeleteWithFailures.Failure.html" title="enum in org.apache.hadoop.hbase.backup"><span class="typeNameLink">TestBackupDeleteWithFailures.Failure</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/org/apache/hadoop/hbase/io/hfile/package-tree.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/io/hfile/package-tree.html b/testdevapidocs/org/apache/hadoop/hbase/io/hfile/package-tree.html
index e6bc9ca..b89116f 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/io/hfile/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/io/hfile/package-tree.html
@@ -158,8 +158,8 @@
 <ul>
 <li type="circle">java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Enum.html?is-external=true" title="class or interface in java.lang"><span class="typeNameLink">Enum</span></a>&lt;E&gt; (implements java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Comparable.html?is-external=true" title="class or interface in java.lang">Comparable</a>&lt;T&gt;, java.io.<a href="http://docs.oracle.com/javase/8/docs/api/java/io/Serializable.html?is-external=true" title="class or interface in java.io">Serializable</a>)
 <ul>
-<li type="circle">org.apache.hadoop.hbase.io.hfile.<a href="../../../../../../org/apache/hadoop/hbase/io/hfile/TagUsage.html" title="enum in org.apache.hadoop.hbase.io.hfile"><span class="typeNameLink">TagUsage</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.io.hfile.<a href="../../../../../../org/apache/hadoop/hbase/io/hfile/TestCacheOnWrite.CacheOnWriteType.html" title="enum in org.apache.hadoop.hbase.io.hfile"><span class="typeNameLink">TestCacheOnWrite.CacheOnWriteType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.io.hfile.<a href="../../../../../../org/apache/hadoop/hbase/io/hfile/TagUsage.html" title="enum in org.apache.hadoop.hbase.io.hfile"><span class="typeNameLink">TagUsage</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/org/apache/hadoop/hbase/package-tree.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/package-tree.html b/testdevapidocs/org/apache/hadoop/hbase/package-tree.html
index db66b4b..8e23d34 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/package-tree.html
@@ -574,15 +574,15 @@
 <ul>
 <li type="circle">java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Enum.html?is-external=true" title="class or interface in java.lang"><span class="typeNameLink">Enum</span></a>&lt;E&gt; (implements java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Comparable.html?is-external=true" title="class or interface in java.lang">Comparable</a>&lt;T&gt;, java.io.<a href="http://docs.oracle.com/javase/8/docs/api/java/io/Serializable.html?is-external=true" title="class or interface in java.io">Serializable</a>)
 <ul>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/ResourceChecker.Phase.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">ResourceChecker.Phase</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/ScanPerformanceEvaluation.ScanCounter.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">ScanPerformanceEvaluation.ScanCounter</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/RESTApiClusterManager.RoleCommand.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">RESTApiClusterManager.RoleCommand</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/IntegrationTestDDLMasterFailover.ACTION.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">IntegrationTestDDLMasterFailover.ACTION</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/RESTApiClusterManager.Service.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">RESTApiClusterManager.Service</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/PerformanceEvaluation.Counter.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">PerformanceEvaluation.Counter</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/IntegrationTestRegionReplicaPerf.Stat.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">IntegrationTestRegionReplicaPerf.Stat</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/HBaseClusterManager.CommandProvider.Operation.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">HBaseClusterManager.CommandProvider.Operation</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/IntegrationTestDDLMasterFailover.ACTION.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">IntegrationTestDDLMasterFailover.ACTION</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/RESTApiClusterManager.RoleCommand.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">RESTApiClusterManager.RoleCommand</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/ClusterManager.ServiceType.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">ClusterManager.ServiceType</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/ResourceChecker.Phase.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">ResourceChecker.Phase</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/RESTApiClusterManager.Service.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">RESTApiClusterManager.Service</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/ScanPerformanceEvaluation.ScanCounter.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">ScanPerformanceEvaluation.ScanCounter</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/HBaseClusterManager.CommandProvider.Operation.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">HBaseClusterManager.CommandProvider.Operation</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/org/apache/hadoop/hbase/procedure/package-tree.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/procedure/package-tree.html b/testdevapidocs/org/apache/hadoop/hbase/procedure/package-tree.html
index 46c9672..dec1fae 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/procedure/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/procedure/package-tree.html
@@ -81,14 +81,14 @@
 <ul>
 <li type="circle">java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true" title="class or interface in java.lang"><span class="typeNameLink">Object</span></a>
 <ul>
-<li type="circle">org.apache.hadoop.hbase.procedure.Procedure (implements java.util.concurrent.<a href="http://docs.oracle.com/javase/8/docs/api/java/util/concurrent/Callable.html?is-external=true" title="class or interface in java.util.concurrent">Callable</a>&lt;V&gt;, org.apache.hadoop.hbase.errorhandling.ForeignExceptionListener)
+<li type="circle">org.apache.hadoop.hbase.procedure2.Procedure&lt;TEnvironment&gt; (implements java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Comparable.html?is-external=true" title="class or interface in java.lang">Comparable</a>&lt;T&gt;)
 <ul>
-<li type="circle">org.apache.hadoop.hbase.procedure.<a href="../../../../../org/apache/hadoop/hbase/procedure/TestProcedure.LatchedProcedure.html" title="class in org.apache.hadoop.hbase.procedure"><span class="typeNameLink">TestProcedure.LatchedProcedure</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.procedure.<a href="../../../../../org/apache/hadoop/hbase/procedure/TestProcedureDescriber.TestProcedure.html" title="class in org.apache.hadoop.hbase.procedure"><span class="typeNameLink">TestProcedureDescriber.TestProcedure</span></a></li>
 </ul>
 </li>
-<li type="circle">org.apache.hadoop.hbase.procedure2.Procedure&lt;TEnvironment&gt; (implements java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Comparable.html?is-external=true" title="class or interface in java.lang">Comparable</a>&lt;T&gt;)
+<li type="circle">org.apache.hadoop.hbase.procedure.Procedure (implements java.util.concurrent.<a href="http://docs.oracle.com/javase/8/docs/api/java/util/concurrent/Callable.html?is-external=true" title="class or interface in java.util.concurrent">Callable</a>&lt;V&gt;, org.apache.hadoop.hbase.errorhandling.ForeignExceptionListener)
 <ul>
-<li type="circle">org.apache.hadoop.hbase.procedure.<a href="../../../../../org/apache/hadoop/hbase/procedure/TestProcedureDescriber.TestProcedure.html" title="class in org.apache.hadoop.hbase.procedure"><span class="typeNameLink">TestProcedureDescriber.TestProcedure</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.procedure.<a href="../../../../../org/apache/hadoop/hbase/procedure/TestProcedure.LatchedProcedure.html" title="class in org.apache.hadoop.hbase.procedure"><span class="typeNameLink">TestProcedure.LatchedProcedure</span></a></li>
 </ul>
 </li>
 <li type="circle">org.apache.hadoop.hbase.procedure.ProcedureManager

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html b/testdevapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html
index b9a9b1d..f73ba8e 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/procedure2/package-tree.html
@@ -205,9 +205,9 @@
 <ul>
 <li type="circle">java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Enum.html?is-external=true" title="class or interface in java.lang"><span class="typeNameLink">Enum</span></a>&lt;E&gt; (implements java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Comparable.html?is-external=true" title="class or interface in java.lang">Comparable</a>&lt;T&gt;, java.io.<a href="http://docs.oracle.com/javase/8/docs/api/java/io/Serializable.html?is-external=true" title="class or interface in java.io">Serializable</a>)
 <ul>
-<li type="circle">org.apache.hadoop.hbase.procedure2.<a href="../../../../../org/apache/hadoop/hbase/procedure2/TestStateMachineProcedure.TestSMProcedureState.html" title="enum in org.apache.hadoop.hbase.procedure2"><span class="typeNameLink">TestStateMachineProcedure.TestSMProcedureState</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.procedure2.<a href="../../../../../org/apache/hadoop/hbase/procedure2/TestYieldProcedures.TestStateMachineProcedure.State.html" title="enum in org.apache.hadoop.hbase.procedure2"><span class="typeNameLink">TestYieldProcedures.TestStateMachineProcedure.State</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.procedure2.<a href="../../../../../org/apache/hadoop/hbase/procedure2/TestProcedureRecovery.TestStateMachineProcedure.State.html" title="enum in org.apache.hadoop.hbase.procedure2"><span class="typeNameLink">TestProcedureRecovery.TestStateMachineProcedure.State</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.procedure2.<a href="../../../../../org/apache/hadoop/hbase/procedure2/TestStateMachineProcedure.TestSMProcedureState.html" title="enum in org.apache.hadoop.hbase.procedure2"><span class="typeNameLink">TestStateMachineProcedure.TestSMProcedureState</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.IgnoreYouAreDeadRS.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.IgnoreYouAreDeadRS.html b/testdevapidocs/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.IgnoreYouAreDeadRS.html
index 3c3311d..bce7cc3 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.IgnoreYouAreDeadRS.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.IgnoreYouAreDeadRS.html
@@ -127,7 +127,7 @@ var activeTableTab = "activeTableTab";
 </dl>
 <hr>
 <br>
-<pre>public static final class <a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.71">TestCompactionInDeadRegionServer.IgnoreYouAreDeadRS</a>
+<pre>public static final class <a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.74">TestCompactionInDeadRegionServer.IgnoreYouAreDeadRS</a>
 extends org.apache.hadoop.hbase.regionserver.HRegionServer</pre>
 </li>
 </ul>
@@ -248,7 +248,7 @@ extends org.apache.hadoop.hbase.regionserver.HRegionServer</pre>
 <ul class="blockListLast">
 <li class="blockList">
 <h4>IgnoreYouAreDeadRS</h4>
-<pre>public&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.IgnoreYouAreDeadRS.html#line.73">IgnoreYouAreDeadRS</a>(org.apache.hadoop.conf.Configuration&nbsp;conf)
+<pre>public&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.IgnoreYouAreDeadRS.html#line.76">IgnoreYouAreDeadRS</a>(org.apache.hadoop.conf.Configuration&nbsp;conf)
                    throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a>,
                           <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/InterruptedException.html?is-external=true" title="class or interface in java.lang">InterruptedException</a></pre>
 <dl>
@@ -272,7 +272,7 @@ extends org.apache.hadoop.hbase.regionserver.HRegionServer</pre>
 <ul class="blockListLast">
 <li class="blockList">
 <h4>tryRegionServerReport</h4>
-<pre>protected&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.IgnoreYouAreDeadRS.html#line.78">tryRegionServerReport</a>(long&nbsp;reportStartTime,
+<pre>protected&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.IgnoreYouAreDeadRS.html#line.81">tryRegionServerReport</a>(long&nbsp;reportStartTime,
                                      long&nbsp;reportEndTime)
                               throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <dl>


[08/14] hbase-site git commit: Published site at .

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.html b/testdevapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.html
index c140aa7..de2fa28 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.html
@@ -18,7 +18,7 @@
     catch(err) {
     }
 //-->
-var methods = {"i0":9,"i1":10,"i2":10,"i3":10,"i4":9,"i5":9,"i6":10,"i7":10,"i8":10,"i9":10,"i10":9,"i11":9,"i12":10,"i13":10,"i14":10,"i15":10,"i16":10,"i17":10,"i18":10,"i19":10,"i20":10,"i21":10,"i22":10,"i23":42,"i24":10,"i25":10,"i26":10,"i27":10,"i28":10,"i29":9,"i30":9,"i31":10,"i32":10,"i33":10,"i34":42,"i35":10,"i36":10,"i37":10,"i38":10,"i39":10,"i40":9,"i41":9,"i42":9,"i43":9,"i44":9,"i45":9,"i46":9,"i47":10,"i48":9,"i49":9,"i50":10,"i51":10,"i52":10,"i53":10,"i54":10,"i55":10,"i56":10,"i57":10,"i58":10,"i59":10,"i60":10,"i61":10,"i62":10,"i63":10,"i64":10,"i65":10,"i66":10,"i67":10,"i68":10,"i69":10,"i70":42,"i71":42,"i72":10,"i73":10,"i74":10,"i75":10,"i76":10,"i77":9,"i78":10,"i79":10,"i80":10,"i81":10,"i82":10,"i83":10,"i84":10,"i85":10,"i86":10,"i87":10,"i88":10,"i89":10,"i90":10,"i91":10,"i92":10,"i93":10,"i94":10,"i95":10,"i96":10,"i97":10,"i98":10,"i99":9,"i100":9,"i101":10,"i102":9,"i103":10,"i104":10,"i105":10,"i106":10,"i107":10,"i108":10,"i109":10,"i110":10,"i
 111":10,"i112":10,"i113":10,"i114":9,"i115":9,"i116":9,"i117":42,"i118":10,"i119":10,"i120":9,"i121":42,"i122":10,"i123":10,"i124":10,"i125":10,"i126":10,"i127":10,"i128":10,"i129":10,"i130":10,"i131":10,"i132":9,"i133":10,"i134":10,"i135":10,"i136":9,"i137":10,"i138":10,"i139":10,"i140":10,"i141":10,"i142":10,"i143":10,"i144":10,"i145":10,"i146":10,"i147":10,"i148":10,"i149":9,"i150":9,"i151":9,"i152":10,"i153":10,"i154":10,"i155":10,"i156":10,"i157":9,"i158":9,"i159":10,"i160":9,"i161":10,"i162":10,"i163":10,"i164":10,"i165":10,"i166":10,"i167":9,"i168":9,"i169":10,"i170":10,"i171":10,"i172":10,"i173":10,"i174":10,"i175":10,"i176":10,"i177":10,"i178":10,"i179":10,"i180":10,"i181":10,"i182":10,"i183":10,"i184":10,"i185":10,"i186":10,"i187":10,"i188":10,"i189":10,"i190":10,"i191":10,"i192":10,"i193":10,"i194":10,"i195":10,"i196":10,"i197":10,"i198":10,"i199":10,"i200":10,"i201":10,"i202":10,"i203":10,"i204":10,"i205":10,"i206":10,"i207":10,"i208":10,"i209":10,"i210":10,"i211":10,"i2
 12":10,"i213":10,"i214":10,"i215":10,"i216":10,"i217":10,"i218":10,"i219":9,"i220":10,"i221":10,"i222":10,"i223":10,"i224":10,"i225":10,"i226":10,"i227":10,"i228":10,"i229":10,"i230":10,"i231":10,"i232":10,"i233":10,"i234":10};
+var methods = {"i0":9,"i1":10,"i2":10,"i3":10,"i4":9,"i5":9,"i6":10,"i7":10,"i8":10,"i9":10,"i10":9,"i11":9,"i12":10,"i13":10,"i14":10,"i15":10,"i16":10,"i17":10,"i18":10,"i19":10,"i20":10,"i21":10,"i22":10,"i23":42,"i24":10,"i25":10,"i26":10,"i27":10,"i28":10,"i29":9,"i30":9,"i31":10,"i32":10,"i33":10,"i34":42,"i35":10,"i36":10,"i37":10,"i38":10,"i39":10,"i40":9,"i41":9,"i42":9,"i43":9,"i44":9,"i45":9,"i46":9,"i47":10,"i48":9,"i49":9,"i50":10,"i51":10,"i52":10,"i53":10,"i54":10,"i55":10,"i56":10,"i57":10,"i58":10,"i59":10,"i60":10,"i61":10,"i62":10,"i63":10,"i64":10,"i65":10,"i66":10,"i67":10,"i68":10,"i69":10,"i70":42,"i71":42,"i72":10,"i73":10,"i74":10,"i75":10,"i76":10,"i77":9,"i78":10,"i79":10,"i80":10,"i81":10,"i82":10,"i83":10,"i84":10,"i85":10,"i86":10,"i87":10,"i88":10,"i89":10,"i90":10,"i91":10,"i92":10,"i93":10,"i94":10,"i95":10,"i96":10,"i97":10,"i98":10,"i99":9,"i100":9,"i101":10,"i102":9,"i103":10,"i104":10,"i105":10,"i106":10,"i107":10,"i108":10,"i109":10,"i110":10,"i
 111":10,"i112":10,"i113":10,"i114":9,"i115":9,"i116":9,"i117":42,"i118":10,"i119":10,"i120":9,"i121":42,"i122":10,"i123":10,"i124":10,"i125":10,"i126":10,"i127":10,"i128":10,"i129":10,"i130":10,"i131":10,"i132":10,"i133":9,"i134":10,"i135":10,"i136":10,"i137":9,"i138":10,"i139":10,"i140":10,"i141":10,"i142":10,"i143":10,"i144":10,"i145":10,"i146":10,"i147":10,"i148":10,"i149":10,"i150":9,"i151":9,"i152":9,"i153":10,"i154":10,"i155":10,"i156":10,"i157":10,"i158":9,"i159":9,"i160":10,"i161":9,"i162":10,"i163":10,"i164":10,"i165":10,"i166":10,"i167":10,"i168":9,"i169":9,"i170":10,"i171":10,"i172":10,"i173":10,"i174":10,"i175":10,"i176":10,"i177":10,"i178":10,"i179":10,"i180":10,"i181":10,"i182":10,"i183":10,"i184":10,"i185":10,"i186":10,"i187":10,"i188":10,"i189":10,"i190":10,"i191":10,"i192":10,"i193":10,"i194":10,"i195":10,"i196":10,"i197":10,"i198":10,"i199":10,"i200":10,"i201":10,"i202":10,"i203":10,"i204":10,"i205":10,"i206":10,"i207":10,"i208":10,"i209":10,"i210":10,"i211":10,"i2
 12":10,"i213":10,"i214":10,"i215":10,"i216":10,"i217":10,"i218":10,"i219":10,"i220":9,"i221":10,"i222":10,"i223":10,"i224":10,"i225":10,"i226":10,"i227":10,"i228":10,"i229":10,"i230":10,"i231":10,"i232":10,"i233":10,"i234":10,"i235":10};
 var tabs = {65535:["t0","All Methods"],1:["t1","Static Methods"],2:["t2","Instance Methods"],8:["t4","Concrete Methods"],32:["t6","Deprecated Methods"]};
 var altColor = "altColor";
 var rowColor = "rowColor";
@@ -1280,6 +1280,10 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
                  byte[]&nbsp;family)</code>&nbsp;</td>
 </tr>
 <tr id="i129" class="rowColor">
+<td class="colFirst"><code>org.apache.hadoop.hbase.regionserver.HRegionServer</code></td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getOtherRegionServer-org.apache.hadoop.hbase.regionserver.HRegionServer-">getOtherRegionServer</a></span>(org.apache.hadoop.hbase.regionserver.HRegionServer&nbsp;rs)</code>&nbsp;</td>
+</tr>
+<tr id="i130" class="altColor">
 <td class="colFirst"><code>byte[][]</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getRegionSplitStartKeys-byte:A-byte:A-int-">getRegionSplitStartKeys</a></span>(byte[]&nbsp;startKey,
                        byte[]&nbsp;endKey,
@@ -1287,75 +1291,75 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Create region split keys between startkey and endKey</div>
 </td>
 </tr>
-<tr id="i130" class="altColor">
+<tr id="i131" class="rowColor">
 <td class="colFirst"><code>org.apache.hadoop.hbase.regionserver.HRegionServer</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getRSForFirstRegionInTable-org.apache.hadoop.hbase.TableName-">getRSForFirstRegionInTable</a></span>(org.apache.hadoop.hbase.TableName&nbsp;tableName)</code>
 <div class="block">Tool to get the reference to the region server object that holds the
  region of the specified user table.</div>
 </td>
 </tr>
-<tr id="i131" class="rowColor">
+<tr id="i132" class="altColor">
 <td class="colFirst"><code>org.apache.hadoop.hbase.regionserver.HRegion</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getSplittableRegion-org.apache.hadoop.hbase.TableName-int-">getSplittableRegion</a></span>(org.apache.hadoop.hbase.TableName&nbsp;tableName,
                    int&nbsp;maxAttempts)</code>&nbsp;</td>
 </tr>
-<tr id="i132" class="altColor">
+<tr id="i133" class="rowColor">
 <td class="colFirst"><code>static org.apache.hadoop.hbase.io.compress.Compression.Algorithm[]</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getSupportedCompressionAlgorithms--">getSupportedCompressionAlgorithms</a></span>()</code>
 <div class="block">Get supported compression algorithms.</div>
 </td>
 </tr>
-<tr id="i133" class="rowColor">
+<tr id="i134" class="altColor">
 <td class="colFirst"><code>org.apache.hadoop.fs.FileSystem</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getTestFileSystem--">getTestFileSystem</a></span>()</code>&nbsp;</td>
 </tr>
-<tr id="i134" class="altColor">
+<tr id="i135" class="rowColor">
 <td class="colFirst"><code>org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getZkCluster--">getZkCluster</a></span>()</code>&nbsp;</td>
 </tr>
-<tr id="i135" class="rowColor">
+<tr id="i136" class="altColor">
 <td class="colFirst"><code>org.apache.hadoop.hbase.zookeeper.ZKWatcher</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getZooKeeperWatcher--">getZooKeeperWatcher</a></span>()</code>
 <div class="block">Returns a ZKWatcher instance.</div>
 </td>
 </tr>
-<tr id="i136" class="altColor">
+<tr id="i137" class="rowColor">
 <td class="colFirst"><code>static org.apache.hadoop.hbase.zookeeper.ZKWatcher</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getZooKeeperWatcher-org.apache.hadoop.hbase.HBaseTestingUtility-">getZooKeeperWatcher</a></span>(<a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility</a>&nbsp;TEST_UTIL)</code>
 <div class="block">Gets a ZKWatcher.</div>
 </td>
 </tr>
-<tr id="i137" class="rowColor">
+<tr id="i138" class="altColor">
 <td class="colFirst"><code>boolean</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#isReadShortCircuitOn--">isReadShortCircuitOn</a></span>()</code>
 <div class="block">Get the HBase setting for dfs.client.read.shortcircuit from the conf or a system property.</div>
 </td>
 </tr>
-<tr id="i138" class="altColor">
+<tr id="i139" class="rowColor">
 <td class="colFirst"><code>private boolean</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#isTargetTable-byte:A-org.apache.hadoop.hbase.Cell-">isTargetTable</a></span>(byte[]&nbsp;inRow,
              org.apache.hadoop.hbase.Cell&nbsp;c)</code>&nbsp;</td>
 </tr>
-<tr id="i139" class="rowColor">
+<tr id="i140" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadNumericRows-org.apache.hadoop.hbase.client.Table-byte:A-int-int-">loadNumericRows</a></span>(org.apache.hadoop.hbase.client.Table&nbsp;t,
                byte[]&nbsp;f,
                int&nbsp;startRow,
                int&nbsp;endRow)</code>&nbsp;</td>
 </tr>
-<tr id="i140" class="altColor">
+<tr id="i141" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadRandomRows-org.apache.hadoop.hbase.client.Table-byte:A-int-int-">loadRandomRows</a></span>(org.apache.hadoop.hbase.client.Table&nbsp;t,
               byte[]&nbsp;f,
               int&nbsp;rowSize,
               int&nbsp;totalRows)</code>&nbsp;</td>
 </tr>
-<tr id="i141" class="rowColor">
+<tr id="i142" class="altColor">
 <td class="colFirst"><code>int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadRegion-org.apache.hadoop.hbase.regionserver.HRegion-byte:A-">loadRegion</a></span>(org.apache.hadoop.hbase.regionserver.HRegion&nbsp;r,
           byte[]&nbsp;f)</code>&nbsp;</td>
 </tr>
-<tr id="i142" class="altColor">
+<tr id="i143" class="rowColor">
 <td class="colFirst"><code>int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadRegion-org.apache.hadoop.hbase.regionserver.HRegion-byte:A-boolean-">loadRegion</a></span>(org.apache.hadoop.hbase.regionserver.HRegion&nbsp;r,
           byte[]&nbsp;f,
@@ -1363,26 +1367,26 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Load region with rows from 'aaa' to 'zzz'.</div>
 </td>
 </tr>
-<tr id="i143" class="rowColor">
+<tr id="i144" class="altColor">
 <td class="colFirst"><code>int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadRegion-org.apache.hadoop.hbase.regionserver.Region-byte:A-">loadRegion</a></span>(org.apache.hadoop.hbase.regionserver.Region&nbsp;r,
           byte[]&nbsp;f)</code>&nbsp;</td>
 </tr>
-<tr id="i144" class="altColor">
+<tr id="i145" class="rowColor">
 <td class="colFirst"><code>int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A-">loadTable</a></span>(org.apache.hadoop.hbase.client.Table&nbsp;t,
          byte[]&nbsp;f)</code>
 <div class="block">Load table with rows from 'aaa' to 'zzz'.</div>
 </td>
 </tr>
-<tr id="i145" class="rowColor">
+<tr id="i146" class="altColor">
 <td class="colFirst"><code>int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A:A-">loadTable</a></span>(org.apache.hadoop.hbase.client.Table&nbsp;t,
          byte[][]&nbsp;f)</code>
 <div class="block">Load table of multiple column families with rows from 'aaa' to 'zzz'.</div>
 </td>
 </tr>
-<tr id="i146" class="altColor">
+<tr id="i147" class="rowColor">
 <td class="colFirst"><code>int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A:A-byte:A-">loadTable</a></span>(org.apache.hadoop.hbase.client.Table&nbsp;t,
          byte[][]&nbsp;f,
@@ -1390,7 +1394,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Load table of multiple column families with rows from 'aaa' to 'zzz'.</div>
 </td>
 </tr>
-<tr id="i147" class="rowColor">
+<tr id="i148" class="altColor">
 <td class="colFirst"><code>int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A:A-byte:A-boolean-">loadTable</a></span>(org.apache.hadoop.hbase.client.Table&nbsp;t,
          byte[][]&nbsp;f,
@@ -1399,7 +1403,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Load table of multiple column families with rows from 'aaa' to 'zzz'.</div>
 </td>
 </tr>
-<tr id="i148" class="altColor">
+<tr id="i149" class="rowColor">
 <td class="colFirst"><code>int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A-boolean-">loadTable</a></span>(org.apache.hadoop.hbase.client.Table&nbsp;t,
          byte[]&nbsp;f,
@@ -1407,109 +1411,109 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Load table with rows from 'aaa' to 'zzz'.</div>
 </td>
 </tr>
-<tr id="i149" class="rowColor">
+<tr id="i150" class="altColor">
 <td class="colFirst"><code>private static <a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true" title="class or interface in java.lang">Object</a>[]&gt;</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#memStoreTSAndTagsCombination--">memStoreTSAndTagsCombination</a></span>()</code>
 <div class="block">Create combination of memstoreTS and tags</div>
 </td>
 </tr>
-<tr id="i150" class="altColor">
+<tr id="i151" class="rowColor">
 <td class="colFirst"><code>static <a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true" title="class or interface in java.lang">Object</a>[]&gt;</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#memStoreTSTagsAndOffheapCombination--">memStoreTSTagsAndOffheapCombination</a></span>()</code>&nbsp;</td>
 </tr>
-<tr id="i151" class="rowColor">
+<tr id="i152" class="altColor">
 <td class="colFirst"><code>static void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#modifyTableSync-org.apache.hadoop.hbase.client.Admin-org.apache.hadoop.hbase.client.TableDescriptor-">modifyTableSync</a></span>(org.apache.hadoop.hbase.client.Admin&nbsp;admin,
                org.apache.hadoop.hbase.client.TableDescriptor&nbsp;desc)</code>
 <div class="block">Modify a table, synchronous.</div>
 </td>
 </tr>
-<tr id="i152" class="altColor">
+<tr id="i153" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#moveRegionAndWait-org.apache.hadoop.hbase.client.RegionInfo-org.apache.hadoop.hbase.ServerName-">moveRegionAndWait</a></span>(org.apache.hadoop.hbase.client.RegionInfo&nbsp;destRegion,
                  org.apache.hadoop.hbase.ServerName&nbsp;destServer)</code>
 <div class="block">Move region to destination server and wait till region is completely moved and online</div>
 </td>
 </tr>
-<tr id="i153" class="rowColor">
+<tr id="i154" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/Waiter.ExplainingPredicate.html" title="interface in org.apache.hadoop.hbase">Waiter.ExplainingPredicate</a>&lt;<a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a>&gt;</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#predicateNoRegionsInTransition--">predicateNoRegionsInTransition</a></span>()</code>
 <div class="block">Returns a <a href="../../../../org/apache/hadoop/hbase/Waiter.Predicate.html" title="interface in org.apache.hadoop.hbase"><code>Waiter.Predicate</code></a> for checking that there are no regions in transition in master</div>
 </td>
 </tr>
-<tr id="i154" class="altColor">
+<tr id="i155" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/Waiter.Predicate.html" title="interface in org.apache.hadoop.hbase">Waiter.Predicate</a>&lt;<a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a>&gt;</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#predicateTableAvailable-org.apache.hadoop.hbase.TableName-">predicateTableAvailable</a></span>(org.apache.hadoop.hbase.TableName&nbsp;tableName)</code>
 <div class="block">Returns a <a href="../../../../org/apache/hadoop/hbase/Waiter.Predicate.html" title="interface in org.apache.hadoop.hbase"><code>Waiter.Predicate</code></a> for checking that table is enabled</div>
 </td>
 </tr>
-<tr id="i155" class="rowColor">
+<tr id="i156" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/Waiter.Predicate.html" title="interface in org.apache.hadoop.hbase">Waiter.Predicate</a>&lt;<a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a>&gt;</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#predicateTableDisabled-org.apache.hadoop.hbase.TableName-">predicateTableDisabled</a></span>(org.apache.hadoop.hbase.TableName&nbsp;tableName)</code>
 <div class="block">Returns a <a href="../../../../org/apache/hadoop/hbase/Waiter.Predicate.html" title="interface in org.apache.hadoop.hbase"><code>Waiter.Predicate</code></a> for checking that table is enabled</div>
 </td>
 </tr>
-<tr id="i156" class="altColor">
+<tr id="i157" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/Waiter.Predicate.html" title="interface in org.apache.hadoop.hbase">Waiter.Predicate</a>&lt;<a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a>&gt;</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#predicateTableEnabled-org.apache.hadoop.hbase.TableName-">predicateTableEnabled</a></span>(org.apache.hadoop.hbase.TableName&nbsp;tableName)</code>
 <div class="block">Returns a <a href="../../../../org/apache/hadoop/hbase/Waiter.Predicate.html" title="interface in org.apache.hadoop.hbase"><code>Waiter.Predicate</code></a> for checking that table is enabled</div>
 </td>
 </tr>
-<tr id="i157" class="rowColor">
+<tr id="i158" class="altColor">
 <td class="colFirst"><code>static int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#randomFreePort--">randomFreePort</a></span>()</code>&nbsp;</td>
 </tr>
-<tr id="i158" class="altColor">
+<tr id="i159" class="rowColor">
 <td class="colFirst"><code>static <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#randomMultiCastAddress--">randomMultiCastAddress</a></span>()</code>&nbsp;</td>
 </tr>
-<tr id="i159" class="rowColor">
+<tr id="i160" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#restartHBaseCluster-int-">restartHBaseCluster</a></span>(int&nbsp;servers)</code>
 <div class="block">Starts the hbase cluster up again after shutting it down previously in a
  test.</div>
 </td>
 </tr>
-<tr id="i160" class="altColor">
+<tr id="i161" class="rowColor">
 <td class="colFirst"><code>static &lt;T&gt;&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#safeGetAsStr-java.util.List-int-">safeGetAsStr</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;T&gt;&nbsp;lst,
             int&nbsp;i)</code>&nbsp;</td>
 </tr>
-<tr id="i161" class="rowColor">
+<tr id="i162" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setDFSCluster-org.apache.hadoop.hdfs.MiniDFSCluster-">setDFSCluster</a></span>(org.apache.hadoop.hdfs.MiniDFSCluster&nbsp;cluster)</code>&nbsp;</td>
 </tr>
-<tr id="i162" class="altColor">
+<tr id="i163" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setDFSCluster-org.apache.hadoop.hdfs.MiniDFSCluster-boolean-">setDFSCluster</a></span>(org.apache.hadoop.hdfs.MiniDFSCluster&nbsp;cluster,
              boolean&nbsp;requireDown)</code>
 <div class="block">Set the MiniDFSCluster</div>
 </td>
 </tr>
-<tr id="i163" class="rowColor">
+<tr id="i164" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setFileSystemURI-java.lang.String-">setFileSystemURI</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;fsURI)</code>&nbsp;</td>
 </tr>
-<tr id="i164" class="altColor">
+<tr id="i165" class="rowColor">
 <td class="colFirst"><code>private void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setFs--">setFs</a></span>()</code>&nbsp;</td>
 </tr>
-<tr id="i165" class="rowColor">
+<tr id="i166" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setHBaseCluster-org.apache.hadoop.hbase.HBaseCluster-">setHBaseCluster</a></span>(<a href="../../../../org/apache/hadoop/hbase/HBaseCluster.html" title="class in org.apache.hadoop.hbase">HBaseCluster</a>&nbsp;hbaseCluster)</code>&nbsp;</td>
 </tr>
-<tr id="i166" class="altColor">
+<tr id="i167" class="rowColor">
 <td class="colFirst"><code>private void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setHBaseFsTmpDir--">setHBaseFsTmpDir</a></span>()</code>&nbsp;</td>
 </tr>
-<tr id="i167" class="rowColor">
+<tr id="i168" class="altColor">
 <td class="colFirst"><code>static void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setMaxRecoveryErrorCount-java.io.OutputStream-int-">setMaxRecoveryErrorCount</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/io/OutputStream.html?is-external=true" title="class or interface in java.io">OutputStream</a>&nbsp;stream,
                         int&nbsp;max)</code>
 <div class="block">Set maxRecoveryErrorCount in DFSClient.</div>
 </td>
 </tr>
-<tr id="i168" class="altColor">
+<tr id="i169" class="rowColor">
 <td class="colFirst"><code>static void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setReplicas-org.apache.hadoop.hbase.client.Admin-org.apache.hadoop.hbase.TableName-int-">setReplicas</a></span>(org.apache.hadoop.hbase.client.Admin&nbsp;admin,
            org.apache.hadoop.hbase.TableName&nbsp;table,
@@ -1517,105 +1521,105 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Set the number of Region replicas.</div>
 </td>
 </tr>
-<tr id="i169" class="rowColor">
+<tr id="i170" class="altColor">
 <td class="colFirst"><code>private void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setupClusterTestDir--">setupClusterTestDir</a></span>()</code>
 <div class="block">Creates a directory for the DFS cluster, under the test data</div>
 </td>
 </tr>
-<tr id="i170" class="altColor">
+<tr id="i171" class="rowColor">
 <td class="colFirst"><code>protected org.apache.hadoop.fs.Path</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setupDataTestDir--">setupDataTestDir</a></span>()</code>
 <div class="block">Home our data in a dir under <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.html#DEFAULT_BASE_TEST_DIRECTORY"><code>HBaseCommonTestingUtility.DEFAULT_BASE_TEST_DIRECTORY</code></a>.</div>
 </td>
 </tr>
-<tr id="i171" class="rowColor">
+<tr id="i172" class="altColor">
 <td class="colFirst"><code>private void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setupDataTestDirOnTestFS--">setupDataTestDirOnTestFS</a></span>()</code>
 <div class="block">Sets up a path in test filesystem to be used by tests.</div>
 </td>
 </tr>
-<tr id="i172" class="altColor">
+<tr id="i173" class="rowColor">
 <td class="colFirst"><code>org.apache.hadoop.minikdc.MiniKdc</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setupMiniKdc-java.io.File-">setupMiniKdc</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/io/File.html?is-external=true" title="class or interface in java.io">File</a>&nbsp;keytabFile)</code>
 <div class="block">Sets up <code>MiniKdc</code> for testing security.</div>
 </td>
 </tr>
-<tr id="i173" class="rowColor">
+<tr id="i174" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setZkCluster-org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster-">setZkCluster</a></span>(org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster&nbsp;zkCluster)</code>&nbsp;</td>
 </tr>
-<tr id="i174" class="altColor">
+<tr id="i175" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniCluster--">shutdownMiniCluster</a></span>()</code>
 <div class="block">Stops mini hbase, zk, and hdfs clusters.</div>
 </td>
 </tr>
-<tr id="i175" class="rowColor">
+<tr id="i176" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniDFSCluster--">shutdownMiniDFSCluster</a></span>()</code>
 <div class="block">Shuts down instance created by call to <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-int-"><code>startMiniDFSCluster(int)</code></a>
  or does nothing.</div>
 </td>
 </tr>
-<tr id="i176" class="altColor">
+<tr id="i177" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniHBaseCluster--">shutdownMiniHBaseCluster</a></span>()</code>
 <div class="block">Shutdown HBase mini cluster.</div>
 </td>
 </tr>
-<tr id="i177" class="rowColor">
+<tr id="i178" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniMapReduceCluster--">shutdownMiniMapReduceCluster</a></span>()</code>
 <div class="block">Stops the previously started <code>MiniMRCluster</code>.</div>
 </td>
 </tr>
-<tr id="i178" class="altColor">
+<tr id="i179" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniZKCluster--">shutdownMiniZKCluster</a></span>()</code>
 <div class="block">Shuts down zk cluster created by call to <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniZKCluster-java.io.File-"><code>startMiniZKCluster(File)</code></a>
  or does nothing.</div>
 </td>
 </tr>
-<tr id="i179" class="rowColor">
+<tr id="i180" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster--">startMiniCluster</a></span>()</code>
 <div class="block">Start up a minicluster of hbase, dfs, and zookeeper.</div>
 </td>
 </tr>
-<tr id="i180" class="altColor">
+<tr id="i181" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-boolean-">startMiniCluster</a></span>(boolean&nbsp;withWALDir)</code>
 <div class="block">Start up a minicluster of hbase, dfs, and zookeeper where WAL's walDir is created separately.</div>
 </td>
 </tr>
-<tr id="i181" class="rowColor">
+<tr id="i182" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-">startMiniCluster</a></span>(int&nbsp;numSlaves)</code>
 <div class="block">Start up a minicluster of hbase, optionally dfs, and zookeeper.</div>
 </td>
 </tr>
-<tr id="i182" class="altColor">
+<tr id="i183" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-boolean-">startMiniCluster</a></span>(int&nbsp;numSlaves,
                 boolean&nbsp;create)</code>
 <div class="block">Start up a minicluster of hbase, dfs, and zookeeper.</div>
 </td>
 </tr>
-<tr id="i183" class="rowColor">
+<tr id="i184" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-boolean-boolean-">startMiniCluster</a></span>(int&nbsp;numSlaves,
                 boolean&nbsp;create,
                 boolean&nbsp;withWALDir)</code>&nbsp;</td>
 </tr>
-<tr id="i184" class="altColor">
+<tr id="i185" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-">startMiniCluster</a></span>(int&nbsp;numMasters,
                 int&nbsp;numSlaves)</code>
 <div class="block">start minicluster</div>
 </td>
 </tr>
-<tr id="i185" class="rowColor">
+<tr id="i186" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-boolean-">startMiniCluster</a></span>(int&nbsp;numMasters,
                 int&nbsp;numSlaves,
@@ -1623,7 +1627,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Start minicluster.</div>
 </td>
 </tr>
-<tr id="i186" class="altColor">
+<tr id="i187" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-int-">startMiniCluster</a></span>(int&nbsp;numMasters,
                 int&nbsp;numSlaves,
@@ -1631,7 +1635,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Same as <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-"><code>startMiniCluster(int, int)</code></a>, but with custom number of datanodes.</div>
 </td>
 </tr>
-<tr id="i187" class="rowColor">
+<tr id="i188" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-int-java.lang.String:A-java.lang.Class-java.lang.Class-">startMiniCluster</a></span>(int&nbsp;numMasters,
                 int&nbsp;numSlaves,
@@ -1640,7 +1644,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
                 <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Class.html?is-external=true" title="class or interface in java.lang">Class</a>&lt;? extends org.apache.hadoop.hbase.master.HMaster&gt;&nbsp;masterClass,
                 <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Class.html?is-external=true" title="class or interface in java.lang">Class</a>&lt;? extends <a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.MiniHBaseClusterRegionServer.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster.MiniHBaseClusterRegionServer</a>&gt;&nbsp;regionserverClass)</code>&nbsp;</td>
 </tr>
-<tr id="i188" class="altColor">
+<tr id="i189" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-int-java.lang.String:A-java.lang.Class-java.lang.Class-boolean-boolean-">startMiniCluster</a></span>(int&nbsp;numMasters,
                 int&nbsp;numSlaves,
@@ -1654,7 +1658,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
  number of datanodes.</div>
 </td>
 </tr>
-<tr id="i189" class="rowColor">
+<tr id="i190" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-java.lang.String:A-">startMiniCluster</a></span>(int&nbsp;numMasters,
                 int&nbsp;numSlaves,
@@ -1662,14 +1666,14 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Start up a minicluster of hbase, optionally dfs, and zookeeper.</div>
 </td>
 </tr>
-<tr id="i190" class="altColor">
+<tr id="i191" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-java.lang.String:A-boolean-">startMiniCluster</a></span>(int&nbsp;numMasters,
                 int&nbsp;numSlaves,
                 <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>[]&nbsp;dataNodeHosts,
                 boolean&nbsp;create)</code>&nbsp;</td>
 </tr>
-<tr id="i191" class="rowColor">
+<tr id="i192" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-java.lang.String:A-java.lang.Class-java.lang.Class-">startMiniCluster</a></span>(int&nbsp;numMasters,
                 int&nbsp;numSlaves,
@@ -1679,41 +1683,41 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Start up a minicluster of hbase, optionally dfs, and zookeeper.</div>
 </td>
 </tr>
-<tr id="i192" class="altColor">
+<tr id="i193" class="rowColor">
 <td class="colFirst"><code>org.apache.hadoop.hdfs.MiniDFSCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-int-">startMiniDFSCluster</a></span>(int&nbsp;servers)</code>
 <div class="block">Start a minidfscluster.</div>
 </td>
 </tr>
-<tr id="i193" class="rowColor">
+<tr id="i194" class="altColor">
 <td class="colFirst"><code>org.apache.hadoop.hdfs.MiniDFSCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-int-java.lang.String:A-">startMiniDFSCluster</a></span>(int&nbsp;servers,
                    <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>[]&nbsp;hosts)</code>
 <div class="block">Start a minidfscluster.</div>
 </td>
 </tr>
-<tr id="i194" class="altColor">
+<tr id="i195" class="rowColor">
 <td class="colFirst"><code>org.apache.hadoop.hdfs.MiniDFSCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-int-java.lang.String:A-java.lang.String:A-">startMiniDFSCluster</a></span>(int&nbsp;servers,
                    <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>[]&nbsp;racks,
                    <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>[]&nbsp;hosts)</code>&nbsp;</td>
 </tr>
-<tr id="i195" class="rowColor">
+<tr id="i196" class="altColor">
 <td class="colFirst"><code>org.apache.hadoop.hdfs.MiniDFSCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-java.lang.String:A-">startMiniDFSCluster</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>[]&nbsp;hosts)</code>
 <div class="block">Start a minidfscluster.</div>
 </td>
 </tr>
-<tr id="i196" class="altColor">
+<tr id="i197" class="rowColor">
 <td class="colFirst"><code>org.apache.hadoop.hdfs.MiniDFSCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSClusterForTestWAL-int-">startMiniDFSClusterForTestWAL</a></span>(int&nbsp;namenodePort)</code>&nbsp;</td>
 </tr>
-<tr id="i197" class="rowColor">
+<tr id="i198" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniHBaseCluster-int-int-">startMiniHBaseCluster</a></span>(int&nbsp;numMasters,
                      int&nbsp;numSlaves)</code>&nbsp;</td>
 </tr>
-<tr id="i198" class="altColor">
+<tr id="i199" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniHBaseCluster-int-int-java.lang.Class-java.lang.Class-boolean-boolean-">startMiniHBaseCluster</a></span>(int&nbsp;numMasters,
                      int&nbsp;numSlaves,
@@ -1724,30 +1728,30 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Starts up mini hbase cluster.</div>
 </td>
 </tr>
-<tr id="i199" class="rowColor">
+<tr id="i200" class="altColor">
 <td class="colFirst"><code>org.apache.hadoop.mapred.MiniMRCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniMapReduceCluster--">startMiniMapReduceCluster</a></span>()</code>
 <div class="block">Starts a <code>MiniMRCluster</code> with a default number of
  <code>TaskTracker</code>'s.</div>
 </td>
 </tr>
-<tr id="i200" class="altColor">
+<tr id="i201" class="rowColor">
 <td class="colFirst"><code>private void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniMapReduceCluster-int-">startMiniMapReduceCluster</a></span>(int&nbsp;servers)</code>
 <div class="block">Starts a <code>MiniMRCluster</code>.</div>
 </td>
 </tr>
-<tr id="i201" class="rowColor">
+<tr id="i202" class="altColor">
 <td class="colFirst"><code>org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniZKCluster--">startMiniZKCluster</a></span>()</code>
 <div class="block">Call this if you only want a zk cluster.</div>
 </td>
 </tr>
-<tr id="i202" class="altColor">
+<tr id="i203" class="rowColor">
 <td class="colFirst"><code>private org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniZKCluster-java.io.File-">startMiniZKCluster</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/io/File.html?is-external=true" title="class or interface in java.io">File</a>&nbsp;dir)</code>&nbsp;</td>
 </tr>
-<tr id="i203" class="rowColor">
+<tr id="i204" class="altColor">
 <td class="colFirst"><code>private org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniZKCluster-java.io.File-int-int:A-">startMiniZKCluster</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/io/File.html?is-external=true" title="class or interface in java.io">File</a>&nbsp;dir,
                   int&nbsp;zooKeeperServerNum,
@@ -1755,60 +1759,60 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Start a mini ZK cluster.</div>
 </td>
 </tr>
-<tr id="i204" class="altColor">
+<tr id="i205" class="rowColor">
 <td class="colFirst"><code>org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniZKCluster-int-int...-">startMiniZKCluster</a></span>(int&nbsp;zooKeeperServerNum,
                   int...&nbsp;clientPortList)</code>
 <div class="block">Call this if you only want a zk cluster.</div>
 </td>
 </tr>
-<tr id="i205" class="rowColor">
+<tr id="i206" class="altColor">
 <td class="colFirst"><code>org.apache.hadoop.hbase.client.Table</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#truncateTable-org.apache.hadoop.hbase.TableName-">truncateTable</a></span>(org.apache.hadoop.hbase.TableName&nbsp;tableName)</code>
 <div class="block">Truncate a table using the admin command.</div>
 </td>
 </tr>
-<tr id="i206" class="altColor">
+<tr id="i207" class="rowColor">
 <td class="colFirst"><code>org.apache.hadoop.hbase.client.Table</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#truncateTable-org.apache.hadoop.hbase.TableName-boolean-">truncateTable</a></span>(org.apache.hadoop.hbase.TableName&nbsp;tableName,
              boolean&nbsp;preserveRegions)</code>
 <div class="block">Truncate a table using the admin command.</div>
 </td>
 </tr>
-<tr id="i207" class="rowColor">
+<tr id="i208" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#unassignRegion-byte:A-">unassignRegion</a></span>(byte[]&nbsp;regionName)</code>
 <div class="block">Unassign the named region.</div>
 </td>
 </tr>
-<tr id="i208" class="altColor">
+<tr id="i209" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#unassignRegion-java.lang.String-">unassignRegion</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;regionName)</code>
 <div class="block">Unassign the named region.</div>
 </td>
 </tr>
-<tr id="i209" class="rowColor">
+<tr id="i210" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#unassignRegionByRow-byte:A-org.apache.hadoop.hbase.client.RegionLocator-">unassignRegionByRow</a></span>(byte[]&nbsp;row,
                    org.apache.hadoop.hbase.client.RegionLocator&nbsp;table)</code>
 <div class="block">Closes the region containing the given row.</div>
 </td>
 </tr>
-<tr id="i210" class="altColor">
+<tr id="i211" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#unassignRegionByRow-java.lang.String-org.apache.hadoop.hbase.client.RegionLocator-">unassignRegionByRow</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;row,
                    org.apache.hadoop.hbase.client.RegionLocator&nbsp;table)</code>
 <div class="block">Closes the region containing the given row.</div>
 </td>
 </tr>
-<tr id="i211" class="rowColor">
+<tr id="i212" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.regionserver.HRegion-byte:A-int-int-">verifyNumericRows</a></span>(org.apache.hadoop.hbase.regionserver.HRegion&nbsp;region,
                  byte[]&nbsp;f,
                  int&nbsp;startRow,
                  int&nbsp;endRow)</code>&nbsp;</td>
 </tr>
-<tr id="i212" class="altColor">
+<tr id="i213" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.regionserver.HRegion-byte:A-int-int-boolean-">verifyNumericRows</a></span>(org.apache.hadoop.hbase.regionserver.HRegion&nbsp;region,
                  byte[]&nbsp;f,
@@ -1816,14 +1820,14 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
                  int&nbsp;endRow,
                  boolean&nbsp;present)</code>&nbsp;</td>
 </tr>
-<tr id="i213" class="rowColor">
+<tr id="i214" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.regionserver.Region-byte:A-int-int-">verifyNumericRows</a></span>(org.apache.hadoop.hbase.regionserver.Region&nbsp;region,
                  byte[]&nbsp;f,
                  int&nbsp;startRow,
                  int&nbsp;endRow)</code>&nbsp;</td>
 </tr>
-<tr id="i214" class="altColor">
+<tr id="i215" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.regionserver.Region-byte:A-int-int-boolean-">verifyNumericRows</a></span>(org.apache.hadoop.hbase.regionserver.Region&nbsp;region,
                  byte[]&nbsp;f,
@@ -1831,7 +1835,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
                  int&nbsp;endRow,
                  boolean&nbsp;present)</code>&nbsp;</td>
 </tr>
-<tr id="i215" class="rowColor">
+<tr id="i216" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.client.Table-byte:A-int-int-int-">verifyNumericRows</a></span>(org.apache.hadoop.hbase.client.Table&nbsp;table,
                  byte[]&nbsp;f,
@@ -1839,7 +1843,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
                  int&nbsp;endRow,
                  int&nbsp;replicaId)</code>&nbsp;</td>
 </tr>
-<tr id="i216" class="altColor">
+<tr id="i217" class="rowColor">
 <td class="colFirst"><code>&lt;E extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a>&gt;<br>long</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitFor-long-long-boolean-org.apache.hadoop.hbase.Waiter.Predicate-">waitFor</a></span>(long&nbsp;timeout,
        long&nbsp;interval,
@@ -1848,7 +1852,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Wrapper method for <a href="../../../../org/apache/hadoop/hbase/Waiter.html#waitFor-org.apache.hadoop.conf.Configuration-long-long-boolean-org.apache.hadoop.hbase.Waiter.Predicate-"><code>Waiter.waitFor(Configuration, long, long, boolean, Predicate)</code></a>.</div>
 </td>
 </tr>
-<tr id="i217" class="rowColor">
+<tr id="i218" class="altColor">
 <td class="colFirst"><code>&lt;E extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a>&gt;<br>long</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitFor-long-long-org.apache.hadoop.hbase.Waiter.Predicate-">waitFor</a></span>(long&nbsp;timeout,
        long&nbsp;interval,
@@ -1856,80 +1860,80 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Wrapper method for <a href="../../../../org/apache/hadoop/hbase/Waiter.html#waitFor-org.apache.hadoop.conf.Configuration-long-long-org.apache.hadoop.hbase.Waiter.Predicate-"><code>Waiter.waitFor(Configuration, long, long, Predicate)</code></a>.</div>
 </td>
 </tr>
-<tr id="i218" class="altColor">
+<tr id="i219" class="rowColor">
 <td class="colFirst"><code>&lt;E extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a>&gt;<br>long</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitFor-long-org.apache.hadoop.hbase.Waiter.Predicate-">waitFor</a></span>(long&nbsp;timeout,
        <a href="../../../../org/apache/hadoop/hbase/Waiter.Predicate.html" title="interface in org.apache.hadoop.hbase">Waiter.Predicate</a>&lt;E&gt;&nbsp;predicate)</code>
 <div class="block">Wrapper method for <a href="../../../../org/apache/hadoop/hbase/Waiter.html#waitFor-org.apache.hadoop.conf.Configuration-long-org.apache.hadoop.hbase.Waiter.Predicate-"><code>Waiter.waitFor(Configuration, long, Predicate)</code></a>.</div>
 </td>
 </tr>
-<tr id="i219" class="rowColor">
+<tr id="i220" class="altColor">
 <td class="colFirst"><code>static void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitForHostPort-java.lang.String-int-">waitForHostPort</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;host,
                int&nbsp;port)</code>&nbsp;</td>
 </tr>
-<tr id="i220" class="altColor">
+<tr id="i221" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitLabelAvailable-long-java.lang.String...-">waitLabelAvailable</a></span>(long&nbsp;timeoutMillis,
                   <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>...&nbsp;labels)</code>
 <div class="block">Wait until labels is ready in VisibilityLabelsCache.</div>
 </td>
 </tr>
-<tr id="i221" class="rowColor">
+<tr id="i222" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableAvailable-byte:A-long-">waitTableAvailable</a></span>(byte[]&nbsp;table,
                   long&nbsp;timeoutMillis)</code>
 <div class="block">Wait until all regions in a table have been assigned</div>
 </td>
 </tr>
-<tr id="i222" class="altColor">
+<tr id="i223" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableAvailable-org.apache.hadoop.hbase.TableName-">waitTableAvailable</a></span>(org.apache.hadoop.hbase.TableName&nbsp;table)</code>
 <div class="block">Wait until all regions in a table have been assigned.</div>
 </td>
 </tr>
-<tr id="i223" class="rowColor">
+<tr id="i224" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableAvailable-org.apache.hadoop.hbase.TableName-long-">waitTableAvailable</a></span>(org.apache.hadoop.hbase.TableName&nbsp;table,
                   long&nbsp;timeoutMillis)</code>&nbsp;</td>
 </tr>
-<tr id="i224" class="altColor">
+<tr id="i225" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableDisabled-byte:A-">waitTableDisabled</a></span>(byte[]&nbsp;table)</code>
 <div class="block">Waits for a table to be 'disabled'.</div>
 </td>
 </tr>
-<tr id="i225" class="rowColor">
+<tr id="i226" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableDisabled-byte:A-long-">waitTableDisabled</a></span>(byte[]&nbsp;table,
                  long&nbsp;timeoutMillis)</code>
 <div class="block">Waits for a table to be 'disabled'.</div>
 </td>
 </tr>
-<tr id="i226" class="altColor">
+<tr id="i227" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableDisabled-org.apache.hadoop.hbase.TableName-long-">waitTableDisabled</a></span>(org.apache.hadoop.hbase.TableName&nbsp;table,
                  long&nbsp;millisTimeout)</code>&nbsp;</td>
 </tr>
-<tr id="i227" class="rowColor">
+<tr id="i228" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableEnabled-byte:A-long-">waitTableEnabled</a></span>(byte[]&nbsp;table,
                 long&nbsp;timeoutMillis)</code>
 <div class="block">Waits for a table to be 'enabled'.</div>
 </td>
 </tr>
-<tr id="i228" class="altColor">
+<tr id="i229" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableEnabled-org.apache.hadoop.hbase.TableName-">waitTableEnabled</a></span>(org.apache.hadoop.hbase.TableName&nbsp;table)</code>
 <div class="block">Waits for a table to be 'enabled'.</div>
 </td>
 </tr>
-<tr id="i229" class="rowColor">
+<tr id="i230" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableEnabled-org.apache.hadoop.hbase.TableName-long-">waitTableEnabled</a></span>(org.apache.hadoop.hbase.TableName&nbsp;table,
                 long&nbsp;timeoutMillis)</code>&nbsp;</td>
 </tr>
-<tr id="i230" class="altColor">
+<tr id="i231" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilAllRegionsAssigned-org.apache.hadoop.hbase.TableName-">waitUntilAllRegionsAssigned</a></span>(org.apache.hadoop.hbase.TableName&nbsp;tableName)</code>
 <div class="block">Wait until all regions for a table in hbase:meta have a non-empty
@@ -1939,7 +1943,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
  server.</div>
 </td>
 </tr>
-<tr id="i231" class="rowColor">
+<tr id="i232" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilAllRegionsAssigned-org.apache.hadoop.hbase.TableName-long-">waitUntilAllRegionsAssigned</a></span>(org.apache.hadoop.hbase.TableName&nbsp;tableName,
                            long&nbsp;timeout)</code>
@@ -1947,19 +1951,19 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
  info:server, or until timeout.</div>
 </td>
 </tr>
-<tr id="i232" class="altColor">
+<tr id="i233" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilAllSystemRegionsAssigned--">waitUntilAllSystemRegionsAssigned</a></span>()</code>
 <div class="block">Waith until all system table's regions get assigned</div>
 </td>
 </tr>
-<tr id="i233" class="rowColor">
+<tr id="i234" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilNoRegionsInTransition--">waitUntilNoRegionsInTransition</a></span>()</code>
 <div class="block">Wait until no regions in transition.</div>
 </td>
 </tr>
-<tr id="i234" class="altColor">
+<tr id="i235" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilNoRegionsInTransition-long-">waitUntilNoRegionsInTransition</a></span>(long&nbsp;timeout)</code>
 <div class="block">Wait until no regions in transition.</div>
@@ -2329,7 +2333,7 @@ private static final&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java
 <ul class="blockList">
 <li class="blockList">
 <h4>hbaseAdmin</h4>
-<pre>private&nbsp;org.apache.hadoop.hbase.client.HBaseAdmin <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2888">hbaseAdmin</a></pre>
+<pre>private&nbsp;org.apache.hadoop.hbase.client.HBaseAdmin <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2903">hbaseAdmin</a></pre>
 </li>
 </ul>
 <a name="zooKeeperWatcher">
@@ -2338,7 +2342,7 @@ private static final&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java
 <ul class="blockList">
 <li class="blockList">
 <h4>zooKeeperWatcher</h4>
-<pre>private&nbsp;org.apache.hadoop.hbase.zookeeper.ZKWatcher <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2912">zooKeeperWatcher</a></pre>
+<pre>private&nbsp;org.apache.hadoop.hbase.zookeeper.ZKWatcher <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2927">zooKeeperWatcher</a></pre>
 </li>
 </ul>
 <a name="random">
@@ -2347,7 +2351,7 @@ private static final&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java
 <ul class="blockList">
 <li class="blockList">
 <h4>random</h4>
-<pre>private static&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/Random.html?is-external=true" title="class or interface in java.util">Random</a> <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.3687">random</a></pre>
+<pre>private static&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/Random.html?is-external=true" title="class or interface in java.util">Random</a> <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.3702">random</a></pre>
 </li>
 </ul>
 <a name="portAllocator">
@@ -2356,7 +2360,7 @@ private static final&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java
 <ul class="blockListLast">
 <li class="blockList">
 <h4>portAllocator</h4>
-<pre>private static final&nbsp;<a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility.PortAllocator</a> <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.3689">portAllocator</a></pre>
+<pre>private static final&nbsp;<a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility.PortAllocator</a> <a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.3704">portAllocator</a></pre>
 </li>
 </ul>
 </li>
@@ -5045,13 +5049,22 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 </dl>
 </li>
 </ul>
+<a name="getOtherRegionServer-org.apache.hadoop.hbase.regionserver.HRegionServer-">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>getOtherRegionServer</h4>
+<pre>public&nbsp;org.apache.hadoop.hbase.regionserver.HRegionServer&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2518">getOtherRegionServer</a>(org.apache.hadoop.hbase.regionserver.HRegionServer&nbsp;rs)</pre>
+</li>
+</ul>
 <a name="getRSForFirstRegionInTable-org.apache.hadoop.hbase.TableName-">
 <!--   -->
 </a>
 <ul class="blockList">
 <li class="blockList">
 <h4>getRSForFirstRegionInTable</h4>
-<pre>public&nbsp;org.apache.hadoop.hbase.regionserver.HRegionServer&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2524">getRSForFirstRegionInTable</a>(org.apache.hadoop.hbase.TableName&nbsp;tableName)
+<pre>public&nbsp;org.apache.hadoop.hbase.regionserver.HRegionServer&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2539">getRSForFirstRegionInTable</a>(org.apache.hadoop.hbase.TableName&nbsp;tableName)
                                                                               throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a>,
                                                                                      <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/InterruptedException.html?is-external=true" title="class or interface in java.lang">InterruptedException</a></pre>
 <div class="block">Tool to get the reference to the region server object that holds the
@@ -5076,7 +5089,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>startMiniMapReduceCluster</h4>
-<pre>public&nbsp;org.apache.hadoop.mapred.MiniMRCluster&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2556">startMiniMapReduceCluster</a>()
+<pre>public&nbsp;org.apache.hadoop.mapred.MiniMRCluster&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2571">startMiniMapReduceCluster</a>()
                                                                  throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Starts a <code>MiniMRCluster</code> with a default number of
  <code>TaskTracker</code>'s.</div>
@@ -5092,7 +5105,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>forceChangeTaskLogDir</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2569">forceChangeTaskLogDir</a>()</pre>
+<pre>private&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2584">forceChangeTaskLogDir</a>()</pre>
 <div class="block">Tasktracker has a bug where changing the hadoop.log.dir system property
  will not change its internal static LOG_DIR variable.</div>
 </li>
@@ -5103,7 +5116,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>startMiniMapReduceCluster</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2598">startMiniMapReduceCluster</a>(int&nbsp;servers)
+<pre>private&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2613">startMiniMapReduceCluster</a>(int&nbsp;servers)
                                 throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Starts a <code>MiniMRCluster</code>. Call <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setFileSystemURI-java.lang.String-"><code>setFileSystemURI(String)</code></a> to use a different
  filesystem.</div>
@@ -5121,7 +5134,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>shutdownMiniMapReduceCluster</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2667">shutdownMiniMapReduceCluster</a>()</pre>
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2682">shutdownMiniMapReduceCluster</a>()</pre>
 <div class="block">Stops the previously started <code>MiniMRCluster</code>.</div>
 </li>
 </ul>
@@ -5131,7 +5144,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>createMockRegionServerService</h4>
-<pre>public&nbsp;org.apache.hadoop.hbase.regionserver.RegionServerServices&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2681">createMockRegionServerService</a>()
+<pre>public&nbsp;org.apache.hadoop.hbase.regionserver.RegionServerServices&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2696">createMockRegionServerService</a>()
                                                                                         throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Create a stubbed out RegionServerService, mainly for getting FS.</div>
 <dl>
@@ -5146,7 +5159,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>createMockRegionServerService</h4>
-<pre>public&nbsp;org.apache.hadoop.hbase.regionserver.RegionServerServices&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2689">createMockRegionServerService</a>(org.apache.hadoop.hbase.ipc.RpcServerInterface&nbsp;rpc)
+<pre>public&nbsp;org.apache.hadoop.hbase.regionserver.RegionServerServices&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2704">createMockRegionServerService</a>(org.apache.hadoop.hbase.ipc.RpcServerInterface&nbsp;rpc)
                                                                                         throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Create a stubbed out RegionServerService, mainly for getting FS.
  This version is used by TestTokenAuthentication</div>
@@ -5162,7 +5175,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>createMockRegionServerService</h4>
-<pre>public&nbsp;org.apache.hadoop.hbase.regionserver.RegionServerServices&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2701">createMockRegionServerService</a>(org.apache.hadoop.hbase.ServerName&nbsp;name)
+<pre>public&nbsp;org.apache.hadoop.hbase.regionserver.RegionServerServices&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2716">createMockRegionServerService</a>(org.apache.hadoop.hbase.ServerName&nbsp;name)
                                                                                         throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Create a stubbed out RegionServerService, mainly for getting FS.
  This version is used by TestOpenRegionHandler</div>
@@ -5178,7 +5191,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>enableDebug</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2712">enableDebug</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Class.html?is-external=true" title="class or interface in java.lang">Class</a>&lt;?&gt;&nbsp;clazz)</pre>
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2727">enableDebug</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Class.html?is-external=true" title="class or interface in java.lang">Class</a>&lt;?&gt;&nbsp;clazz)</pre>
 <div class="block">Switches the logger for the given class to DEBUG level.</div>
 <dl>
 <dt><span class="paramLabel">Parameters:</span></dt>
@@ -5192,7 +5205,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>expireMasterSession</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2725">expireMasterSession</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2740">expireMasterSession</a>()
                          throws <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
 <div class="block">Expire the Master's session</div>
 <dl>
@@ -5207,7 +5220,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>expireRegionServerSession</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2735">expireRegionServerSession</a>(int&nbsp;index)
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2750">expireRegionServerSession</a>(int&nbsp;index)
                                throws <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
 <div class="block">Expire a region server's session</div>
 <dl>
@@ -5224,7 +5237,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>decrementMinRegionServerCount</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2741">decrementMinRegionServerCount</a>()</pre>
+<pre>private&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2756">decrementMinRegionServerCount</a>()</pre>
 </li>
 </ul>
 <a name="decrementMinRegionServerCount-org.apache.hadoop.conf.Configuration-">
@@ -5233,7 +5246,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>decrementMinRegionServerCount</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2752">decrementMinRegionServerCount</a>(org.apache.hadoop.conf.Configuration&nbsp;conf)</pre>
+<pre>private&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2767">decrementMinRegionServerCount</a>(org.apache.hadoop.conf.Configuration&nbsp;conf)</pre>
 </li>
 </ul>
 <a name="expireSession-org.apache.hadoop.hbase.zookeeper.ZKWatcher-">
@@ -5242,7 +5255,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>expireSession</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2761">expireSession</a>(org.apache.hadoop.hbase.zookeeper.ZKWatcher&nbsp;nodeZK)
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2776">expireSession</a>(org.apache.hadoop.hbase.zookeeper.ZKWatcher&nbsp;nodeZK)
                    throws <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
 <dl>
 <dt><span class="throwsLabel">Throws:</span></dt>
@@ -5256,7 +5269,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>expireSession</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2776">expireSession</a>(org.apache.hadoop.hbase.zookeeper.ZKWatcher&nbsp;nodeZK,
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2791">expireSession</a>(org.apache.hadoop.hbase.zookeeper.ZKWatcher&nbsp;nodeZK,
                           boolean&nbsp;checkStatus)
                    throws <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
 <div class="block">Expire a ZooKeeper session as recommended in ZooKeeper documentation
@@ -5280,7 +5293,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>getHBaseCluster</h4>
-<pre>public&nbsp;<a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2827">getHBaseCluster</a>()</pre>
+<pre>public&nbsp;<a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2842">getHBaseCluster</a>()</pre>
 <div class="block">Get the Mini HBase cluster.</div>
 <dl>
 <dt><span class="returnLabel">Returns:</span></dt>
@@ -5296,7 +5309,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>getHBaseClusterInterface</h4>
-<pre>public&nbsp;<a href="../../../../org/apache/hadoop/hbase/HBaseCluster.html" title="class in org.apache.hadoop.hbase">HBaseCluster</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2839">getHBaseClusterInterface</a>()</pre>
+<pre>public&nbsp;<a href="../../../../org/apache/hadoop/hbase/HBaseCluster.html" title="class in org.apache.hadoop.hbase">HBaseCluster</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2854">getHBaseClusterInterface</a>()</pre>
 <div class="block">Returns the HBaseCluster instance.
  <p>Returned object can be any of the subclasses of HBaseCluster, and the
  tests referring this should not assume that the cluster is a mini cluster or a
@@ -5311,7 +5324,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>getConnection</h4>
-<pre>public&nbsp;org.apache.hadoop.hbase.client.Connection&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2851">getConnection</a>()
+<pre>public&nbsp;org.apache.hadoop.hbase.client.Connection&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2866">getConnection</a>()
                                                         throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Get a Connection to the cluster.
  Not thread-safe (This class needs a lot of work to make it thread-safe).</div>
@@ -5330,7 +5343,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <li class="blockList">
 <h4>getHBaseAdmin</h4>
 <pre><a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Deprecated.html?is-external=true" title="class or interface in java.lang">@Deprecated</a>
-public&nbsp;org.apache.hadoop.hbase.client.HBaseAdmin&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2869">getHBaseAdmin</a>()
+public&nbsp;org.apache.hadoop.hbase.client.HBaseAdmin&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2884">getHBaseAdmin</a>()
                                                                     throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block"><span class="deprecatedLabel">Deprecated.</span>&nbsp;<span class="deprecationComment">Since 2.0. Will be removed in 3.0. Use <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getAdmin--"><code>getAdmin()</code></a> instead.</span></div>
 <div class="block">Returns a Admin instance.
@@ -5352,7 +5365,7 @@ public&nbsp;org.apache.hadoop.hbase.client.HBaseAdmin&nbsp;<a href="../../../../
 <ul class="blockList">
 <li class="blockList">
 <h4>getAdmin</h4>
-<pre>public&nbsp;org.apache.hadoop.hbase.client.Admin&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2881">getAdmin</a>()
+<pre>public&nbsp;org.apache.hadoop.hbase.client.Admin&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2896">getAdmin</a>()
                                               throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Returns an Admin instance which is shared between HBaseTestingUtility instance users.
  Closing it has no effect, it will be closed automatically when the cluster shutdowns</div>
@@ -5368,7 +5381,7 @@ public&nbsp;org.apache.hadoop.hbase.client.HBaseAdmin&nbsp;<a href="../../../../
 <ul class="blockList">
 <li class="blockList">
 <h4>getZooKeeperWatcher</h4>
-<pre>public&nbsp;org.apache.hadoop.hbase.zookeeper.ZKWatcher&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2899">getZooKeeperWatcher</a>()
+<pre>public&nbsp;org.apache.hadoop.hbase.zookeeper.ZKWatcher&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2914">getZooKeeperWatcher</a>()
                                                                 throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Returns a ZKWatcher instance.
  This instance is shared between HBaseTestingUtility instance users.
@@ -5388,7 +5401,7 @@ public&nbsp;org.apache.hadoop.hbase.client.HBaseAdmin&nbsp;<a href="../../../../
 <ul class="blockList">
 <li class="blockList">
 <h4>unassignRegion</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2921">unassignRegion</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;regionName)
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2936">unassignRegion</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;regionName)
                     throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Unassign the named region.</div>
 <dl>
@@ -5405,7 +5418,7 @@ public&nbsp;org.apache.hadoop.hbase.client.HBaseAdmin&nbsp;<a href="../../../../
 <ul class="blockList">
 <li class="blockList">
 <h4>unassignRegion</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2930">unassignRegion</a>(byte[]&nbsp;regionName)
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2945">unassignRegion</a>(byte[]&nbsp;regionName)
                     throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Unassign the named region.</div>
 <dl>
@@ -5422,7 +5435,7 @@ public&nbsp;org.apache.hadoop.hbase.client.HBaseAdmin&nbsp;<a href="../../../../
 <ul class="blockList">
 <li class="blockList">
 <h4>unassignRegionByRow</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2940">unassignRegionByRow</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;row,
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2955">unassignRegionByRow</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;row,
                                 org.apache.hadoop.hbase.client.RegionLocator&nbsp;table)
                          throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Closes the region containing the given row.</div>
@@ -5441,7 +5454,7 @@ public&nbsp;org.apache.hadoop.hbase.client.HBaseAdmin&nbsp;<a href="../../../../
 <ul class="blockList">
 <li class="blockList">
 <h4>unassignRegionByRow</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hado

<TRUNCATED>

[10/14] hbase-site git commit: Published site at .

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html
----------------------------------------------------------------------
diff --git a/testapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html b/testapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html
index 0cec549..06b92ba 100644
--- a/testapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html
+++ b/testapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html
@@ -2518,1796 +2518,1811 @@
 <span class="sourceLineNo">2510</span>    return rows;<a name="line.2510"></a>
 <span class="sourceLineNo">2511</span>  }<a name="line.2511"></a>
 <span class="sourceLineNo">2512</span><a name="line.2512"></a>
-<span class="sourceLineNo">2513</span>  /**<a name="line.2513"></a>
-<span class="sourceLineNo">2514</span>   * Tool to get the reference to the region server object that holds the<a name="line.2514"></a>
-<span class="sourceLineNo">2515</span>   * region of the specified user table.<a name="line.2515"></a>
-<span class="sourceLineNo">2516</span>   * It first searches for the meta rows that contain the region of the<a name="line.2516"></a>
-<span class="sourceLineNo">2517</span>   * specified table, then gets the index of that RS, and finally retrieves<a name="line.2517"></a>
-<span class="sourceLineNo">2518</span>   * the RS's reference.<a name="line.2518"></a>
-<span class="sourceLineNo">2519</span>   * @param tableName user table to lookup in hbase:meta<a name="line.2519"></a>
-<span class="sourceLineNo">2520</span>   * @return region server that holds it, null if the row doesn't exist<a name="line.2520"></a>
-<span class="sourceLineNo">2521</span>   * @throws IOException<a name="line.2521"></a>
-<span class="sourceLineNo">2522</span>   * @throws InterruptedException<a name="line.2522"></a>
-<span class="sourceLineNo">2523</span>   */<a name="line.2523"></a>
-<span class="sourceLineNo">2524</span>  public HRegionServer getRSForFirstRegionInTable(TableName tableName)<a name="line.2524"></a>
-<span class="sourceLineNo">2525</span>      throws IOException, InterruptedException {<a name="line.2525"></a>
-<span class="sourceLineNo">2526</span>    List&lt;byte[]&gt; metaRows = getMetaTableRows(tableName);<a name="line.2526"></a>
-<span class="sourceLineNo">2527</span>    if (metaRows == null || metaRows.isEmpty()) {<a name="line.2527"></a>
-<span class="sourceLineNo">2528</span>      return null;<a name="line.2528"></a>
-<span class="sourceLineNo">2529</span>    }<a name="line.2529"></a>
-<span class="sourceLineNo">2530</span>    LOG.debug("Found " + metaRows.size() + " rows for table " +<a name="line.2530"></a>
-<span class="sourceLineNo">2531</span>      tableName);<a name="line.2531"></a>
-<span class="sourceLineNo">2532</span>    byte [] firstrow = metaRows.get(0);<a name="line.2532"></a>
-<span class="sourceLineNo">2533</span>    LOG.debug("FirstRow=" + Bytes.toString(firstrow));<a name="line.2533"></a>
-<span class="sourceLineNo">2534</span>    long pause = getConfiguration().getLong(HConstants.HBASE_CLIENT_PAUSE,<a name="line.2534"></a>
-<span class="sourceLineNo">2535</span>      HConstants.DEFAULT_HBASE_CLIENT_PAUSE);<a name="line.2535"></a>
-<span class="sourceLineNo">2536</span>    int numRetries = getConfiguration().getInt(HConstants.HBASE_CLIENT_RETRIES_NUMBER,<a name="line.2536"></a>
-<span class="sourceLineNo">2537</span>      HConstants.DEFAULT_HBASE_CLIENT_RETRIES_NUMBER);<a name="line.2537"></a>
-<span class="sourceLineNo">2538</span>    RetryCounter retrier = new RetryCounter(numRetries+1, (int)pause, TimeUnit.MICROSECONDS);<a name="line.2538"></a>
-<span class="sourceLineNo">2539</span>    while(retrier.shouldRetry()) {<a name="line.2539"></a>
-<span class="sourceLineNo">2540</span>      int index = getMiniHBaseCluster().getServerWith(firstrow);<a name="line.2540"></a>
-<span class="sourceLineNo">2541</span>      if (index != -1) {<a name="line.2541"></a>
-<span class="sourceLineNo">2542</span>        return getMiniHBaseCluster().getRegionServerThreads().get(index).getRegionServer();<a name="line.2542"></a>
-<span class="sourceLineNo">2543</span>      }<a name="line.2543"></a>
-<span class="sourceLineNo">2544</span>      // Came back -1.  Region may not be online yet.  Sleep a while.<a name="line.2544"></a>
-<span class="sourceLineNo">2545</span>      retrier.sleepUntilNextRetry();<a name="line.2545"></a>
-<span class="sourceLineNo">2546</span>    }<a name="line.2546"></a>
-<span class="sourceLineNo">2547</span>    return null;<a name="line.2547"></a>
-<span class="sourceLineNo">2548</span>  }<a name="line.2548"></a>
-<span class="sourceLineNo">2549</span><a name="line.2549"></a>
-<span class="sourceLineNo">2550</span>  /**<a name="line.2550"></a>
-<span class="sourceLineNo">2551</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt; with a default number of<a name="line.2551"></a>
-<span class="sourceLineNo">2552</span>   * &lt;code&gt;TaskTracker&lt;/code&gt;'s.<a name="line.2552"></a>
-<span class="sourceLineNo">2553</span>   *<a name="line.2553"></a>
-<span class="sourceLineNo">2554</span>   * @throws IOException When starting the cluster fails.<a name="line.2554"></a>
-<span class="sourceLineNo">2555</span>   */<a name="line.2555"></a>
-<span class="sourceLineNo">2556</span>  public MiniMRCluster startMiniMapReduceCluster() throws IOException {<a name="line.2556"></a>
-<span class="sourceLineNo">2557</span>    // Set a very high max-disk-utilization percentage to avoid the NodeManagers from failing.<a name="line.2557"></a>
-<span class="sourceLineNo">2558</span>    conf.setIfUnset(<a name="line.2558"></a>
-<span class="sourceLineNo">2559</span>        "yarn.nodemanager.disk-health-checker.max-disk-utilization-per-disk-percentage",<a name="line.2559"></a>
-<span class="sourceLineNo">2560</span>        "99.0");<a name="line.2560"></a>
-<span class="sourceLineNo">2561</span>    startMiniMapReduceCluster(2);<a name="line.2561"></a>
-<span class="sourceLineNo">2562</span>    return mrCluster;<a name="line.2562"></a>
+<span class="sourceLineNo">2513</span>  /*<a name="line.2513"></a>
+<span class="sourceLineNo">2514</span>   * Find any other region server which is different from the one identified by parameter<a name="line.2514"></a>
+<span class="sourceLineNo">2515</span>   * @param rs<a name="line.2515"></a>
+<span class="sourceLineNo">2516</span>   * @return another region server<a name="line.2516"></a>
+<span class="sourceLineNo">2517</span>   */<a name="line.2517"></a>
+<span class="sourceLineNo">2518</span>  public HRegionServer getOtherRegionServer(HRegionServer rs) {<a name="line.2518"></a>
+<span class="sourceLineNo">2519</span>    for (JVMClusterUtil.RegionServerThread rst :<a name="line.2519"></a>
+<span class="sourceLineNo">2520</span>      getMiniHBaseCluster().getRegionServerThreads()) {<a name="line.2520"></a>
+<span class="sourceLineNo">2521</span>      if (!(rst.getRegionServer() == rs)) {<a name="line.2521"></a>
+<span class="sourceLineNo">2522</span>        return rst.getRegionServer();<a name="line.2522"></a>
+<span class="sourceLineNo">2523</span>      }<a name="line.2523"></a>
+<span class="sourceLineNo">2524</span>    }<a name="line.2524"></a>
+<span class="sourceLineNo">2525</span>    return null;<a name="line.2525"></a>
+<span class="sourceLineNo">2526</span>  }<a name="line.2526"></a>
+<span class="sourceLineNo">2527</span><a name="line.2527"></a>
+<span class="sourceLineNo">2528</span>  /**<a name="line.2528"></a>
+<span class="sourceLineNo">2529</span>   * Tool to get the reference to the region server object that holds the<a name="line.2529"></a>
+<span class="sourceLineNo">2530</span>   * region of the specified user table.<a name="line.2530"></a>
+<span class="sourceLineNo">2531</span>   * It first searches for the meta rows that contain the region of the<a name="line.2531"></a>
+<span class="sourceLineNo">2532</span>   * specified table, then gets the index of that RS, and finally retrieves<a name="line.2532"></a>
+<span class="sourceLineNo">2533</span>   * the RS's reference.<a name="line.2533"></a>
+<span class="sourceLineNo">2534</span>   * @param tableName user table to lookup in hbase:meta<a name="line.2534"></a>
+<span class="sourceLineNo">2535</span>   * @return region server that holds it, null if the row doesn't exist<a name="line.2535"></a>
+<span class="sourceLineNo">2536</span>   * @throws IOException<a name="line.2536"></a>
+<span class="sourceLineNo">2537</span>   * @throws InterruptedException<a name="line.2537"></a>
+<span class="sourceLineNo">2538</span>   */<a name="line.2538"></a>
+<span class="sourceLineNo">2539</span>  public HRegionServer getRSForFirstRegionInTable(TableName tableName)<a name="line.2539"></a>
+<span class="sourceLineNo">2540</span>      throws IOException, InterruptedException {<a name="line.2540"></a>
+<span class="sourceLineNo">2541</span>    List&lt;byte[]&gt; metaRows = getMetaTableRows(tableName);<a name="line.2541"></a>
+<span class="sourceLineNo">2542</span>    if (metaRows == null || metaRows.isEmpty()) {<a name="line.2542"></a>
+<span class="sourceLineNo">2543</span>      return null;<a name="line.2543"></a>
+<span class="sourceLineNo">2544</span>    }<a name="line.2544"></a>
+<span class="sourceLineNo">2545</span>    LOG.debug("Found " + metaRows.size() + " rows for table " +<a name="line.2545"></a>
+<span class="sourceLineNo">2546</span>      tableName);<a name="line.2546"></a>
+<span class="sourceLineNo">2547</span>    byte [] firstrow = metaRows.get(0);<a name="line.2547"></a>
+<span class="sourceLineNo">2548</span>    LOG.debug("FirstRow=" + Bytes.toString(firstrow));<a name="line.2548"></a>
+<span class="sourceLineNo">2549</span>    long pause = getConfiguration().getLong(HConstants.HBASE_CLIENT_PAUSE,<a name="line.2549"></a>
+<span class="sourceLineNo">2550</span>      HConstants.DEFAULT_HBASE_CLIENT_PAUSE);<a name="line.2550"></a>
+<span class="sourceLineNo">2551</span>    int numRetries = getConfiguration().getInt(HConstants.HBASE_CLIENT_RETRIES_NUMBER,<a name="line.2551"></a>
+<span class="sourceLineNo">2552</span>      HConstants.DEFAULT_HBASE_CLIENT_RETRIES_NUMBER);<a name="line.2552"></a>
+<span class="sourceLineNo">2553</span>    RetryCounter retrier = new RetryCounter(numRetries+1, (int)pause, TimeUnit.MICROSECONDS);<a name="line.2553"></a>
+<span class="sourceLineNo">2554</span>    while(retrier.shouldRetry()) {<a name="line.2554"></a>
+<span class="sourceLineNo">2555</span>      int index = getMiniHBaseCluster().getServerWith(firstrow);<a name="line.2555"></a>
+<span class="sourceLineNo">2556</span>      if (index != -1) {<a name="line.2556"></a>
+<span class="sourceLineNo">2557</span>        return getMiniHBaseCluster().getRegionServerThreads().get(index).getRegionServer();<a name="line.2557"></a>
+<span class="sourceLineNo">2558</span>      }<a name="line.2558"></a>
+<span class="sourceLineNo">2559</span>      // Came back -1.  Region may not be online yet.  Sleep a while.<a name="line.2559"></a>
+<span class="sourceLineNo">2560</span>      retrier.sleepUntilNextRetry();<a name="line.2560"></a>
+<span class="sourceLineNo">2561</span>    }<a name="line.2561"></a>
+<span class="sourceLineNo">2562</span>    return null;<a name="line.2562"></a>
 <span class="sourceLineNo">2563</span>  }<a name="line.2563"></a>
 <span class="sourceLineNo">2564</span><a name="line.2564"></a>
 <span class="sourceLineNo">2565</span>  /**<a name="line.2565"></a>
-<span class="sourceLineNo">2566</span>   * Tasktracker has a bug where changing the hadoop.log.dir system property<a name="line.2566"></a>
-<span class="sourceLineNo">2567</span>   * will not change its internal static LOG_DIR variable.<a name="line.2567"></a>
-<span class="sourceLineNo">2568</span>   */<a name="line.2568"></a>
-<span class="sourceLineNo">2569</span>  private void forceChangeTaskLogDir() {<a name="line.2569"></a>
-<span class="sourceLineNo">2570</span>    Field logDirField;<a name="line.2570"></a>
-<span class="sourceLineNo">2571</span>    try {<a name="line.2571"></a>
-<span class="sourceLineNo">2572</span>      logDirField = TaskLog.class.getDeclaredField("LOG_DIR");<a name="line.2572"></a>
-<span class="sourceLineNo">2573</span>      logDirField.setAccessible(true);<a name="line.2573"></a>
-<span class="sourceLineNo">2574</span><a name="line.2574"></a>
-<span class="sourceLineNo">2575</span>      Field modifiersField = Field.class.getDeclaredField("modifiers");<a name="line.2575"></a>
-<span class="sourceLineNo">2576</span>      modifiersField.setAccessible(true);<a name="line.2576"></a>
-<span class="sourceLineNo">2577</span>      modifiersField.setInt(logDirField, logDirField.getModifiers() &amp; ~Modifier.FINAL);<a name="line.2577"></a>
-<span class="sourceLineNo">2578</span><a name="line.2578"></a>
-<span class="sourceLineNo">2579</span>      logDirField.set(null, new File(hadoopLogDir, "userlogs"));<a name="line.2579"></a>
-<span class="sourceLineNo">2580</span>    } catch (SecurityException e) {<a name="line.2580"></a>
-<span class="sourceLineNo">2581</span>      throw new RuntimeException(e);<a name="line.2581"></a>
-<span class="sourceLineNo">2582</span>    } catch (NoSuchFieldException e) {<a name="line.2582"></a>
-<span class="sourceLineNo">2583</span>      // TODO Auto-generated catch block<a name="line.2583"></a>
-<span class="sourceLineNo">2584</span>      throw new RuntimeException(e);<a name="line.2584"></a>
-<span class="sourceLineNo">2585</span>    } catch (IllegalArgumentException e) {<a name="line.2585"></a>
-<span class="sourceLineNo">2586</span>      throw new RuntimeException(e);<a name="line.2586"></a>
-<span class="sourceLineNo">2587</span>    } catch (IllegalAccessException e) {<a name="line.2587"></a>
-<span class="sourceLineNo">2588</span>      throw new RuntimeException(e);<a name="line.2588"></a>
-<span class="sourceLineNo">2589</span>    }<a name="line.2589"></a>
-<span class="sourceLineNo">2590</span>  }<a name="line.2590"></a>
-<span class="sourceLineNo">2591</span><a name="line.2591"></a>
-<span class="sourceLineNo">2592</span>  /**<a name="line.2592"></a>
-<span class="sourceLineNo">2593</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt;. Call {@link #setFileSystemURI(String)} to use a different<a name="line.2593"></a>
-<span class="sourceLineNo">2594</span>   * filesystem.<a name="line.2594"></a>
-<span class="sourceLineNo">2595</span>   * @param servers  The number of &lt;code&gt;TaskTracker&lt;/code&gt;'s to start.<a name="line.2595"></a>
-<span class="sourceLineNo">2596</span>   * @throws IOException When starting the cluster fails.<a name="line.2596"></a>
-<span class="sourceLineNo">2597</span>   */<a name="line.2597"></a>
-<span class="sourceLineNo">2598</span>  private void startMiniMapReduceCluster(final int servers) throws IOException {<a name="line.2598"></a>
-<span class="sourceLineNo">2599</span>    if (mrCluster != null) {<a name="line.2599"></a>
-<span class="sourceLineNo">2600</span>      throw new IllegalStateException("MiniMRCluster is already running");<a name="line.2600"></a>
-<span class="sourceLineNo">2601</span>    }<a name="line.2601"></a>
-<span class="sourceLineNo">2602</span>    LOG.info("Starting mini mapreduce cluster...");<a name="line.2602"></a>
-<span class="sourceLineNo">2603</span>    setupClusterTestDir();<a name="line.2603"></a>
-<span class="sourceLineNo">2604</span>    createDirsAndSetProperties();<a name="line.2604"></a>
-<span class="sourceLineNo">2605</span><a name="line.2605"></a>
-<span class="sourceLineNo">2606</span>    forceChangeTaskLogDir();<a name="line.2606"></a>
-<span class="sourceLineNo">2607</span><a name="line.2607"></a>
-<span class="sourceLineNo">2608</span>    //// hadoop2 specific settings<a name="line.2608"></a>
-<span class="sourceLineNo">2609</span>    // Tests were failing because this process used 6GB of virtual memory and was getting killed.<a name="line.2609"></a>
-<span class="sourceLineNo">2610</span>    // we up the VM usable so that processes don't get killed.<a name="line.2610"></a>
-<span class="sourceLineNo">2611</span>    conf.setFloat("yarn.nodemanager.vmem-pmem-ratio", 8.0f);<a name="line.2611"></a>
-<span class="sourceLineNo">2612</span><a name="line.2612"></a>
-<span class="sourceLineNo">2613</span>    // Tests were failing due to MAPREDUCE-4880 / MAPREDUCE-4607 against hadoop 2.0.2-alpha and<a name="line.2613"></a>
-<span class="sourceLineNo">2614</span>    // this avoids the problem by disabling speculative task execution in tests.<a name="line.2614"></a>
-<span class="sourceLineNo">2615</span>    conf.setBoolean("mapreduce.map.speculative", false);<a name="line.2615"></a>
-<span class="sourceLineNo">2616</span>    conf.setBoolean("mapreduce.reduce.speculative", false);<a name="line.2616"></a>
-<span class="sourceLineNo">2617</span>    ////<a name="line.2617"></a>
-<span class="sourceLineNo">2618</span><a name="line.2618"></a>
-<span class="sourceLineNo">2619</span>    // Allow the user to override FS URI for this map-reduce cluster to use.<a name="line.2619"></a>
-<span class="sourceLineNo">2620</span>    mrCluster = new MiniMRCluster(servers,<a name="line.2620"></a>
-<span class="sourceLineNo">2621</span>      FS_URI != null ? FS_URI : FileSystem.get(conf).getUri().toString(), 1,<a name="line.2621"></a>
-<span class="sourceLineNo">2622</span>      null, null, new JobConf(this.conf));<a name="line.2622"></a>
-<span class="sourceLineNo">2623</span>    JobConf jobConf = MapreduceTestingShim.getJobConf(mrCluster);<a name="line.2623"></a>
-<span class="sourceLineNo">2624</span>    if (jobConf == null) {<a name="line.2624"></a>
-<span class="sourceLineNo">2625</span>      jobConf = mrCluster.createJobConf();<a name="line.2625"></a>
-<span class="sourceLineNo">2626</span>    }<a name="line.2626"></a>
+<span class="sourceLineNo">2566</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt; with a default number of<a name="line.2566"></a>
+<span class="sourceLineNo">2567</span>   * &lt;code&gt;TaskTracker&lt;/code&gt;'s.<a name="line.2567"></a>
+<span class="sourceLineNo">2568</span>   *<a name="line.2568"></a>
+<span class="sourceLineNo">2569</span>   * @throws IOException When starting the cluster fails.<a name="line.2569"></a>
+<span class="sourceLineNo">2570</span>   */<a name="line.2570"></a>
+<span class="sourceLineNo">2571</span>  public MiniMRCluster startMiniMapReduceCluster() throws IOException {<a name="line.2571"></a>
+<span class="sourceLineNo">2572</span>    // Set a very high max-disk-utilization percentage to avoid the NodeManagers from failing.<a name="line.2572"></a>
+<span class="sourceLineNo">2573</span>    conf.setIfUnset(<a name="line.2573"></a>
+<span class="sourceLineNo">2574</span>        "yarn.nodemanager.disk-health-checker.max-disk-utilization-per-disk-percentage",<a name="line.2574"></a>
+<span class="sourceLineNo">2575</span>        "99.0");<a name="line.2575"></a>
+<span class="sourceLineNo">2576</span>    startMiniMapReduceCluster(2);<a name="line.2576"></a>
+<span class="sourceLineNo">2577</span>    return mrCluster;<a name="line.2577"></a>
+<span class="sourceLineNo">2578</span>  }<a name="line.2578"></a>
+<span class="sourceLineNo">2579</span><a name="line.2579"></a>
+<span class="sourceLineNo">2580</span>  /**<a name="line.2580"></a>
+<span class="sourceLineNo">2581</span>   * Tasktracker has a bug where changing the hadoop.log.dir system property<a name="line.2581"></a>
+<span class="sourceLineNo">2582</span>   * will not change its internal static LOG_DIR variable.<a name="line.2582"></a>
+<span class="sourceLineNo">2583</span>   */<a name="line.2583"></a>
+<span class="sourceLineNo">2584</span>  private void forceChangeTaskLogDir() {<a name="line.2584"></a>
+<span class="sourceLineNo">2585</span>    Field logDirField;<a name="line.2585"></a>
+<span class="sourceLineNo">2586</span>    try {<a name="line.2586"></a>
+<span class="sourceLineNo">2587</span>      logDirField = TaskLog.class.getDeclaredField("LOG_DIR");<a name="line.2587"></a>
+<span class="sourceLineNo">2588</span>      logDirField.setAccessible(true);<a name="line.2588"></a>
+<span class="sourceLineNo">2589</span><a name="line.2589"></a>
+<span class="sourceLineNo">2590</span>      Field modifiersField = Field.class.getDeclaredField("modifiers");<a name="line.2590"></a>
+<span class="sourceLineNo">2591</span>      modifiersField.setAccessible(true);<a name="line.2591"></a>
+<span class="sourceLineNo">2592</span>      modifiersField.setInt(logDirField, logDirField.getModifiers() &amp; ~Modifier.FINAL);<a name="line.2592"></a>
+<span class="sourceLineNo">2593</span><a name="line.2593"></a>
+<span class="sourceLineNo">2594</span>      logDirField.set(null, new File(hadoopLogDir, "userlogs"));<a name="line.2594"></a>
+<span class="sourceLineNo">2595</span>    } catch (SecurityException e) {<a name="line.2595"></a>
+<span class="sourceLineNo">2596</span>      throw new RuntimeException(e);<a name="line.2596"></a>
+<span class="sourceLineNo">2597</span>    } catch (NoSuchFieldException e) {<a name="line.2597"></a>
+<span class="sourceLineNo">2598</span>      // TODO Auto-generated catch block<a name="line.2598"></a>
+<span class="sourceLineNo">2599</span>      throw new RuntimeException(e);<a name="line.2599"></a>
+<span class="sourceLineNo">2600</span>    } catch (IllegalArgumentException e) {<a name="line.2600"></a>
+<span class="sourceLineNo">2601</span>      throw new RuntimeException(e);<a name="line.2601"></a>
+<span class="sourceLineNo">2602</span>    } catch (IllegalAccessException e) {<a name="line.2602"></a>
+<span class="sourceLineNo">2603</span>      throw new RuntimeException(e);<a name="line.2603"></a>
+<span class="sourceLineNo">2604</span>    }<a name="line.2604"></a>
+<span class="sourceLineNo">2605</span>  }<a name="line.2605"></a>
+<span class="sourceLineNo">2606</span><a name="line.2606"></a>
+<span class="sourceLineNo">2607</span>  /**<a name="line.2607"></a>
+<span class="sourceLineNo">2608</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt;. Call {@link #setFileSystemURI(String)} to use a different<a name="line.2608"></a>
+<span class="sourceLineNo">2609</span>   * filesystem.<a name="line.2609"></a>
+<span class="sourceLineNo">2610</span>   * @param servers  The number of &lt;code&gt;TaskTracker&lt;/code&gt;'s to start.<a name="line.2610"></a>
+<span class="sourceLineNo">2611</span>   * @throws IOException When starting the cluster fails.<a name="line.2611"></a>
+<span class="sourceLineNo">2612</span>   */<a name="line.2612"></a>
+<span class="sourceLineNo">2613</span>  private void startMiniMapReduceCluster(final int servers) throws IOException {<a name="line.2613"></a>
+<span class="sourceLineNo">2614</span>    if (mrCluster != null) {<a name="line.2614"></a>
+<span class="sourceLineNo">2615</span>      throw new IllegalStateException("MiniMRCluster is already running");<a name="line.2615"></a>
+<span class="sourceLineNo">2616</span>    }<a name="line.2616"></a>
+<span class="sourceLineNo">2617</span>    LOG.info("Starting mini mapreduce cluster...");<a name="line.2617"></a>
+<span class="sourceLineNo">2618</span>    setupClusterTestDir();<a name="line.2618"></a>
+<span class="sourceLineNo">2619</span>    createDirsAndSetProperties();<a name="line.2619"></a>
+<span class="sourceLineNo">2620</span><a name="line.2620"></a>
+<span class="sourceLineNo">2621</span>    forceChangeTaskLogDir();<a name="line.2621"></a>
+<span class="sourceLineNo">2622</span><a name="line.2622"></a>
+<span class="sourceLineNo">2623</span>    //// hadoop2 specific settings<a name="line.2623"></a>
+<span class="sourceLineNo">2624</span>    // Tests were failing because this process used 6GB of virtual memory and was getting killed.<a name="line.2624"></a>
+<span class="sourceLineNo">2625</span>    // we up the VM usable so that processes don't get killed.<a name="line.2625"></a>
+<span class="sourceLineNo">2626</span>    conf.setFloat("yarn.nodemanager.vmem-pmem-ratio", 8.0f);<a name="line.2626"></a>
 <span class="sourceLineNo">2627</span><a name="line.2627"></a>
-<span class="sourceLineNo">2628</span>    jobConf.set("mapreduce.cluster.local.dir",<a name="line.2628"></a>
-<span class="sourceLineNo">2629</span>      conf.get("mapreduce.cluster.local.dir")); //Hadoop MiniMR overwrites this while it should not<a name="line.2629"></a>
-<span class="sourceLineNo">2630</span>    LOG.info("Mini mapreduce cluster started");<a name="line.2630"></a>
-<span class="sourceLineNo">2631</span><a name="line.2631"></a>
-<span class="sourceLineNo">2632</span>    // In hadoop2, YARN/MR2 starts a mini cluster with its own conf instance and updates settings.<a name="line.2632"></a>
-<span class="sourceLineNo">2633</span>    // Our HBase MR jobs need several of these settings in order to properly run.  So we copy the<a name="line.2633"></a>
-<span class="sourceLineNo">2634</span>    // necessary config properties here.  YARN-129 required adding a few properties.<a name="line.2634"></a>
-<span class="sourceLineNo">2635</span>    conf.set("mapreduce.jobtracker.address", jobConf.get("mapreduce.jobtracker.address"));<a name="line.2635"></a>
-<span class="sourceLineNo">2636</span>    // this for mrv2 support; mr1 ignores this<a name="line.2636"></a>
-<span class="sourceLineNo">2637</span>    conf.set("mapreduce.framework.name", "yarn");<a name="line.2637"></a>
-<span class="sourceLineNo">2638</span>    conf.setBoolean("yarn.is.minicluster", true);<a name="line.2638"></a>
-<span class="sourceLineNo">2639</span>    String rmAddress = jobConf.get("yarn.resourcemanager.address");<a name="line.2639"></a>
-<span class="sourceLineNo">2640</span>    if (rmAddress != null) {<a name="line.2640"></a>
-<span class="sourceLineNo">2641</span>      conf.set("yarn.resourcemanager.address", rmAddress);<a name="line.2641"></a>
-<span class="sourceLineNo">2642</span>    }<a name="line.2642"></a>
-<span class="sourceLineNo">2643</span>    String historyAddress = jobConf.get("mapreduce.jobhistory.address");<a name="line.2643"></a>
-<span class="sourceLineNo">2644</span>    if (historyAddress != null) {<a name="line.2644"></a>
-<span class="sourceLineNo">2645</span>      conf.set("mapreduce.jobhistory.address", historyAddress);<a name="line.2645"></a>
-<span class="sourceLineNo">2646</span>    }<a name="line.2646"></a>
-<span class="sourceLineNo">2647</span>    String schedulerAddress =<a name="line.2647"></a>
-<span class="sourceLineNo">2648</span>      jobConf.get("yarn.resourcemanager.scheduler.address");<a name="line.2648"></a>
-<span class="sourceLineNo">2649</span>    if (schedulerAddress != null) {<a name="line.2649"></a>
-<span class="sourceLineNo">2650</span>      conf.set("yarn.resourcemanager.scheduler.address", schedulerAddress);<a name="line.2650"></a>
-<span class="sourceLineNo">2651</span>    }<a name="line.2651"></a>
-<span class="sourceLineNo">2652</span>    String mrJobHistoryWebappAddress =<a name="line.2652"></a>
-<span class="sourceLineNo">2653</span>      jobConf.get("mapreduce.jobhistory.webapp.address");<a name="line.2653"></a>
-<span class="sourceLineNo">2654</span>    if (mrJobHistoryWebappAddress != null) {<a name="line.2654"></a>
-<span class="sourceLineNo">2655</span>      conf.set("mapreduce.jobhistory.webapp.address", mrJobHistoryWebappAddress);<a name="line.2655"></a>
-<span class="sourceLineNo">2656</span>    }<a name="line.2656"></a>
-<span class="sourceLineNo">2657</span>    String yarnRMWebappAddress =<a name="line.2657"></a>
-<span class="sourceLineNo">2658</span>      jobConf.get("yarn.resourcemanager.webapp.address");<a name="line.2658"></a>
-<span class="sourceLineNo">2659</span>    if (yarnRMWebappAddress != null) {<a name="line.2659"></a>
-<span class="sourceLineNo">2660</span>      conf.set("yarn.resourcemanager.webapp.address", yarnRMWebappAddress);<a name="line.2660"></a>
+<span class="sourceLineNo">2628</span>    // Tests were failing due to MAPREDUCE-4880 / MAPREDUCE-4607 against hadoop 2.0.2-alpha and<a name="line.2628"></a>
+<span class="sourceLineNo">2629</span>    // this avoids the problem by disabling speculative task execution in tests.<a name="line.2629"></a>
+<span class="sourceLineNo">2630</span>    conf.setBoolean("mapreduce.map.speculative", false);<a name="line.2630"></a>
+<span class="sourceLineNo">2631</span>    conf.setBoolean("mapreduce.reduce.speculative", false);<a name="line.2631"></a>
+<span class="sourceLineNo">2632</span>    ////<a name="line.2632"></a>
+<span class="sourceLineNo">2633</span><a name="line.2633"></a>
+<span class="sourceLineNo">2634</span>    // Allow the user to override FS URI for this map-reduce cluster to use.<a name="line.2634"></a>
+<span class="sourceLineNo">2635</span>    mrCluster = new MiniMRCluster(servers,<a name="line.2635"></a>
+<span class="sourceLineNo">2636</span>      FS_URI != null ? FS_URI : FileSystem.get(conf).getUri().toString(), 1,<a name="line.2636"></a>
+<span class="sourceLineNo">2637</span>      null, null, new JobConf(this.conf));<a name="line.2637"></a>
+<span class="sourceLineNo">2638</span>    JobConf jobConf = MapreduceTestingShim.getJobConf(mrCluster);<a name="line.2638"></a>
+<span class="sourceLineNo">2639</span>    if (jobConf == null) {<a name="line.2639"></a>
+<span class="sourceLineNo">2640</span>      jobConf = mrCluster.createJobConf();<a name="line.2640"></a>
+<span class="sourceLineNo">2641</span>    }<a name="line.2641"></a>
+<span class="sourceLineNo">2642</span><a name="line.2642"></a>
+<span class="sourceLineNo">2643</span>    jobConf.set("mapreduce.cluster.local.dir",<a name="line.2643"></a>
+<span class="sourceLineNo">2644</span>      conf.get("mapreduce.cluster.local.dir")); //Hadoop MiniMR overwrites this while it should not<a name="line.2644"></a>
+<span class="sourceLineNo">2645</span>    LOG.info("Mini mapreduce cluster started");<a name="line.2645"></a>
+<span class="sourceLineNo">2646</span><a name="line.2646"></a>
+<span class="sourceLineNo">2647</span>    // In hadoop2, YARN/MR2 starts a mini cluster with its own conf instance and updates settings.<a name="line.2647"></a>
+<span class="sourceLineNo">2648</span>    // Our HBase MR jobs need several of these settings in order to properly run.  So we copy the<a name="line.2648"></a>
+<span class="sourceLineNo">2649</span>    // necessary config properties here.  YARN-129 required adding a few properties.<a name="line.2649"></a>
+<span class="sourceLineNo">2650</span>    conf.set("mapreduce.jobtracker.address", jobConf.get("mapreduce.jobtracker.address"));<a name="line.2650"></a>
+<span class="sourceLineNo">2651</span>    // this for mrv2 support; mr1 ignores this<a name="line.2651"></a>
+<span class="sourceLineNo">2652</span>    conf.set("mapreduce.framework.name", "yarn");<a name="line.2652"></a>
+<span class="sourceLineNo">2653</span>    conf.setBoolean("yarn.is.minicluster", true);<a name="line.2653"></a>
+<span class="sourceLineNo">2654</span>    String rmAddress = jobConf.get("yarn.resourcemanager.address");<a name="line.2654"></a>
+<span class="sourceLineNo">2655</span>    if (rmAddress != null) {<a name="line.2655"></a>
+<span class="sourceLineNo">2656</span>      conf.set("yarn.resourcemanager.address", rmAddress);<a name="line.2656"></a>
+<span class="sourceLineNo">2657</span>    }<a name="line.2657"></a>
+<span class="sourceLineNo">2658</span>    String historyAddress = jobConf.get("mapreduce.jobhistory.address");<a name="line.2658"></a>
+<span class="sourceLineNo">2659</span>    if (historyAddress != null) {<a name="line.2659"></a>
+<span class="sourceLineNo">2660</span>      conf.set("mapreduce.jobhistory.address", historyAddress);<a name="line.2660"></a>
 <span class="sourceLineNo">2661</span>    }<a name="line.2661"></a>
-<span class="sourceLineNo">2662</span>  }<a name="line.2662"></a>
-<span class="sourceLineNo">2663</span><a name="line.2663"></a>
-<span class="sourceLineNo">2664</span>  /**<a name="line.2664"></a>
-<span class="sourceLineNo">2665</span>   * Stops the previously started &lt;code&gt;MiniMRCluster&lt;/code&gt;.<a name="line.2665"></a>
-<span class="sourceLineNo">2666</span>   */<a name="line.2666"></a>
-<span class="sourceLineNo">2667</span>  public void shutdownMiniMapReduceCluster() {<a name="line.2667"></a>
-<span class="sourceLineNo">2668</span>    if (mrCluster != null) {<a name="line.2668"></a>
-<span class="sourceLineNo">2669</span>      LOG.info("Stopping mini mapreduce cluster...");<a name="line.2669"></a>
-<span class="sourceLineNo">2670</span>      mrCluster.shutdown();<a name="line.2670"></a>
-<span class="sourceLineNo">2671</span>      mrCluster = null;<a name="line.2671"></a>
-<span class="sourceLineNo">2672</span>      LOG.info("Mini mapreduce cluster stopped");<a name="line.2672"></a>
-<span class="sourceLineNo">2673</span>    }<a name="line.2673"></a>
-<span class="sourceLineNo">2674</span>    // Restore configuration to point to local jobtracker<a name="line.2674"></a>
-<span class="sourceLineNo">2675</span>    conf.set("mapreduce.jobtracker.address", "local");<a name="line.2675"></a>
-<span class="sourceLineNo">2676</span>  }<a name="line.2676"></a>
-<span class="sourceLineNo">2677</span><a name="line.2677"></a>
-<span class="sourceLineNo">2678</span>  /**<a name="line.2678"></a>
-<span class="sourceLineNo">2679</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2679"></a>
-<span class="sourceLineNo">2680</span>   */<a name="line.2680"></a>
-<span class="sourceLineNo">2681</span>  public RegionServerServices createMockRegionServerService() throws IOException {<a name="line.2681"></a>
-<span class="sourceLineNo">2682</span>    return createMockRegionServerService((ServerName)null);<a name="line.2682"></a>
-<span class="sourceLineNo">2683</span>  }<a name="line.2683"></a>
-<span class="sourceLineNo">2684</span><a name="line.2684"></a>
-<span class="sourceLineNo">2685</span>  /**<a name="line.2685"></a>
-<span class="sourceLineNo">2686</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2686"></a>
-<span class="sourceLineNo">2687</span>   * This version is used by TestTokenAuthentication<a name="line.2687"></a>
-<span class="sourceLineNo">2688</span>   */<a name="line.2688"></a>
-<span class="sourceLineNo">2689</span>  public RegionServerServices createMockRegionServerService(RpcServerInterface rpc) throws<a name="line.2689"></a>
-<span class="sourceLineNo">2690</span>      IOException {<a name="line.2690"></a>
-<span class="sourceLineNo">2691</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher());<a name="line.2691"></a>
-<span class="sourceLineNo">2692</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2692"></a>
-<span class="sourceLineNo">2693</span>    rss.setRpcServer(rpc);<a name="line.2693"></a>
-<span class="sourceLineNo">2694</span>    return rss;<a name="line.2694"></a>
-<span class="sourceLineNo">2695</span>  }<a name="line.2695"></a>
-<span class="sourceLineNo">2696</span><a name="line.2696"></a>
-<span class="sourceLineNo">2697</span>  /**<a name="line.2697"></a>
-<span class="sourceLineNo">2698</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2698"></a>
-<span class="sourceLineNo">2699</span>   * This version is used by TestOpenRegionHandler<a name="line.2699"></a>
-<span class="sourceLineNo">2700</span>   */<a name="line.2700"></a>
-<span class="sourceLineNo">2701</span>  public RegionServerServices createMockRegionServerService(ServerName name) throws IOException {<a name="line.2701"></a>
-<span class="sourceLineNo">2702</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher(), name);<a name="line.2702"></a>
-<span class="sourceLineNo">2703</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2703"></a>
-<span class="sourceLineNo">2704</span>    return rss;<a name="line.2704"></a>
-<span class="sourceLineNo">2705</span>  }<a name="line.2705"></a>
-<span class="sourceLineNo">2706</span><a name="line.2706"></a>
-<span class="sourceLineNo">2707</span>  /**<a name="line.2707"></a>
-<span class="sourceLineNo">2708</span>   * Switches the logger for the given class to DEBUG level.<a name="line.2708"></a>
-<span class="sourceLineNo">2709</span>   *<a name="line.2709"></a>
-<span class="sourceLineNo">2710</span>   * @param clazz  The class for which to switch to debug logging.<a name="line.2710"></a>
-<span class="sourceLineNo">2711</span>   */<a name="line.2711"></a>
-<span class="sourceLineNo">2712</span>  public void enableDebug(Class&lt;?&gt; clazz) {<a name="line.2712"></a>
-<span class="sourceLineNo">2713</span>    Log l = LogFactory.getLog(clazz);<a name="line.2713"></a>
-<span class="sourceLineNo">2714</span>    if (l instanceof Log4JLogger) {<a name="line.2714"></a>
-<span class="sourceLineNo">2715</span>      ((Log4JLogger) l).getLogger().setLevel(org.apache.log4j.Level.DEBUG);<a name="line.2715"></a>
-<span class="sourceLineNo">2716</span>    } else if (l instanceof Jdk14Logger) {<a name="line.2716"></a>
-<span class="sourceLineNo">2717</span>      ((Jdk14Logger) l).getLogger().setLevel(java.util.logging.Level.ALL);<a name="line.2717"></a>
-<span class="sourceLineNo">2718</span>    }<a name="line.2718"></a>
-<span class="sourceLineNo">2719</span>  }<a name="line.2719"></a>
-<span class="sourceLineNo">2720</span><a name="line.2720"></a>
-<span class="sourceLineNo">2721</span>  /**<a name="line.2721"></a>
-<span class="sourceLineNo">2722</span>   * Expire the Master's session<a name="line.2722"></a>
-<span class="sourceLineNo">2723</span>   * @throws Exception<a name="line.2723"></a>
-<span class="sourceLineNo">2724</span>   */<a name="line.2724"></a>
-<span class="sourceLineNo">2725</span>  public void expireMasterSession() throws Exception {<a name="line.2725"></a>
-<span class="sourceLineNo">2726</span>    HMaster master = getMiniHBaseCluster().getMaster();<a name="line.2726"></a>
-<span class="sourceLineNo">2727</span>    expireSession(master.getZooKeeper(), false);<a name="line.2727"></a>
-<span class="sourceLineNo">2728</span>  }<a name="line.2728"></a>
-<span class="sourceLineNo">2729</span><a name="line.2729"></a>
-<span class="sourceLineNo">2730</span>  /**<a name="line.2730"></a>
-<span class="sourceLineNo">2731</span>   * Expire a region server's session<a name="line.2731"></a>
-<span class="sourceLineNo">2732</span>   * @param index which RS<a name="line.2732"></a>
-<span class="sourceLineNo">2733</span>   * @throws Exception<a name="line.2733"></a>
-<span class="sourceLineNo">2734</span>   */<a name="line.2734"></a>
-<span class="sourceLineNo">2735</span>  public void expireRegionServerSession(int index) throws Exception {<a name="line.2735"></a>
-<span class="sourceLineNo">2736</span>    HRegionServer rs = getMiniHBaseCluster().getRegionServer(index);<a name="line.2736"></a>
-<span class="sourceLineNo">2737</span>    expireSession(rs.getZooKeeper(), false);<a name="line.2737"></a>
-<span class="sourceLineNo">2738</span>    decrementMinRegionServerCount();<a name="line.2738"></a>
-<span class="sourceLineNo">2739</span>  }<a name="line.2739"></a>
-<span class="sourceLineNo">2740</span><a name="line.2740"></a>
-<span class="sourceLineNo">2741</span>  private void decrementMinRegionServerCount() {<a name="line.2741"></a>
-<span class="sourceLineNo">2742</span>    // decrement the count for this.conf, for newly spwaned master<a name="line.2742"></a>
-<span class="sourceLineNo">2743</span>    // this.hbaseCluster shares this configuration too<a name="line.2743"></a>
-<span class="sourceLineNo">2744</span>    decrementMinRegionServerCount(getConfiguration());<a name="line.2744"></a>
-<span class="sourceLineNo">2745</span><a name="line.2745"></a>
-<span class="sourceLineNo">2746</span>    // each master thread keeps a copy of configuration<a name="line.2746"></a>
-<span class="sourceLineNo">2747</span>    for (MasterThread master : getHBaseCluster().getMasterThreads()) {<a name="line.2747"></a>
-<span class="sourceLineNo">2748</span>      decrementMinRegionServerCount(master.getMaster().getConfiguration());<a name="line.2748"></a>
-<span class="sourceLineNo">2749</span>    }<a name="line.2749"></a>
-<span class="sourceLineNo">2750</span>  }<a name="line.2750"></a>
-<span class="sourceLineNo">2751</span><a name="line.2751"></a>
-<span class="sourceLineNo">2752</span>  private void decrementMinRegionServerCount(Configuration conf) {<a name="line.2752"></a>
-<span class="sourceLineNo">2753</span>    int currentCount = conf.getInt(<a name="line.2753"></a>
-<span class="sourceLineNo">2754</span>        ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART, -1);<a name="line.2754"></a>
-<span class="sourceLineNo">2755</span>    if (currentCount != -1) {<a name="line.2755"></a>
-<span class="sourceLineNo">2756</span>      conf.setInt(ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART,<a name="line.2756"></a>
-<span class="sourceLineNo">2757</span>          Math.max(currentCount - 1, 1));<a name="line.2757"></a>
-<span class="sourceLineNo">2758</span>    }<a name="line.2758"></a>
-<span class="sourceLineNo">2759</span>  }<a name="line.2759"></a>
+<span class="sourceLineNo">2662</span>    String schedulerAddress =<a name="line.2662"></a>
+<span class="sourceLineNo">2663</span>      jobConf.get("yarn.resourcemanager.scheduler.address");<a name="line.2663"></a>
+<span class="sourceLineNo">2664</span>    if (schedulerAddress != null) {<a name="line.2664"></a>
+<span class="sourceLineNo">2665</span>      conf.set("yarn.resourcemanager.scheduler.address", schedulerAddress);<a name="line.2665"></a>
+<span class="sourceLineNo">2666</span>    }<a name="line.2666"></a>
+<span class="sourceLineNo">2667</span>    String mrJobHistoryWebappAddress =<a name="line.2667"></a>
+<span class="sourceLineNo">2668</span>      jobConf.get("mapreduce.jobhistory.webapp.address");<a name="line.2668"></a>
+<span class="sourceLineNo">2669</span>    if (mrJobHistoryWebappAddress != null) {<a name="line.2669"></a>
+<span class="sourceLineNo">2670</span>      conf.set("mapreduce.jobhistory.webapp.address", mrJobHistoryWebappAddress);<a name="line.2670"></a>
+<span class="sourceLineNo">2671</span>    }<a name="line.2671"></a>
+<span class="sourceLineNo">2672</span>    String yarnRMWebappAddress =<a name="line.2672"></a>
+<span class="sourceLineNo">2673</span>      jobConf.get("yarn.resourcemanager.webapp.address");<a name="line.2673"></a>
+<span class="sourceLineNo">2674</span>    if (yarnRMWebappAddress != null) {<a name="line.2674"></a>
+<span class="sourceLineNo">2675</span>      conf.set("yarn.resourcemanager.webapp.address", yarnRMWebappAddress);<a name="line.2675"></a>
+<span class="sourceLineNo">2676</span>    }<a name="line.2676"></a>
+<span class="sourceLineNo">2677</span>  }<a name="line.2677"></a>
+<span class="sourceLineNo">2678</span><a name="line.2678"></a>
+<span class="sourceLineNo">2679</span>  /**<a name="line.2679"></a>
+<span class="sourceLineNo">2680</span>   * Stops the previously started &lt;code&gt;MiniMRCluster&lt;/code&gt;.<a name="line.2680"></a>
+<span class="sourceLineNo">2681</span>   */<a name="line.2681"></a>
+<span class="sourceLineNo">2682</span>  public void shutdownMiniMapReduceCluster() {<a name="line.2682"></a>
+<span class="sourceLineNo">2683</span>    if (mrCluster != null) {<a name="line.2683"></a>
+<span class="sourceLineNo">2684</span>      LOG.info("Stopping mini mapreduce cluster...");<a name="line.2684"></a>
+<span class="sourceLineNo">2685</span>      mrCluster.shutdown();<a name="line.2685"></a>
+<span class="sourceLineNo">2686</span>      mrCluster = null;<a name="line.2686"></a>
+<span class="sourceLineNo">2687</span>      LOG.info("Mini mapreduce cluster stopped");<a name="line.2687"></a>
+<span class="sourceLineNo">2688</span>    }<a name="line.2688"></a>
+<span class="sourceLineNo">2689</span>    // Restore configuration to point to local jobtracker<a name="line.2689"></a>
+<span class="sourceLineNo">2690</span>    conf.set("mapreduce.jobtracker.address", "local");<a name="line.2690"></a>
+<span class="sourceLineNo">2691</span>  }<a name="line.2691"></a>
+<span class="sourceLineNo">2692</span><a name="line.2692"></a>
+<span class="sourceLineNo">2693</span>  /**<a name="line.2693"></a>
+<span class="sourceLineNo">2694</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2694"></a>
+<span class="sourceLineNo">2695</span>   */<a name="line.2695"></a>
+<span class="sourceLineNo">2696</span>  public RegionServerServices createMockRegionServerService() throws IOException {<a name="line.2696"></a>
+<span class="sourceLineNo">2697</span>    return createMockRegionServerService((ServerName)null);<a name="line.2697"></a>
+<span class="sourceLineNo">2698</span>  }<a name="line.2698"></a>
+<span class="sourceLineNo">2699</span><a name="line.2699"></a>
+<span class="sourceLineNo">2700</span>  /**<a name="line.2700"></a>
+<span class="sourceLineNo">2701</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2701"></a>
+<span class="sourceLineNo">2702</span>   * This version is used by TestTokenAuthentication<a name="line.2702"></a>
+<span class="sourceLineNo">2703</span>   */<a name="line.2703"></a>
+<span class="sourceLineNo">2704</span>  public RegionServerServices createMockRegionServerService(RpcServerInterface rpc) throws<a name="line.2704"></a>
+<span class="sourceLineNo">2705</span>      IOException {<a name="line.2705"></a>
+<span class="sourceLineNo">2706</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher());<a name="line.2706"></a>
+<span class="sourceLineNo">2707</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2707"></a>
+<span class="sourceLineNo">2708</span>    rss.setRpcServer(rpc);<a name="line.2708"></a>
+<span class="sourceLineNo">2709</span>    return rss;<a name="line.2709"></a>
+<span class="sourceLineNo">2710</span>  }<a name="line.2710"></a>
+<span class="sourceLineNo">2711</span><a name="line.2711"></a>
+<span class="sourceLineNo">2712</span>  /**<a name="line.2712"></a>
+<span class="sourceLineNo">2713</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2713"></a>
+<span class="sourceLineNo">2714</span>   * This version is used by TestOpenRegionHandler<a name="line.2714"></a>
+<span class="sourceLineNo">2715</span>   */<a name="line.2715"></a>
+<span class="sourceLineNo">2716</span>  public RegionServerServices createMockRegionServerService(ServerName name) throws IOException {<a name="line.2716"></a>
+<span class="sourceLineNo">2717</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher(), name);<a name="line.2717"></a>
+<span class="sourceLineNo">2718</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2718"></a>
+<span class="sourceLineNo">2719</span>    return rss;<a name="line.2719"></a>
+<span class="sourceLineNo">2720</span>  }<a name="line.2720"></a>
+<span class="sourceLineNo">2721</span><a name="line.2721"></a>
+<span class="sourceLineNo">2722</span>  /**<a name="line.2722"></a>
+<span class="sourceLineNo">2723</span>   * Switches the logger for the given class to DEBUG level.<a name="line.2723"></a>
+<span class="sourceLineNo">2724</span>   *<a name="line.2724"></a>
+<span class="sourceLineNo">2725</span>   * @param clazz  The class for which to switch to debug logging.<a name="line.2725"></a>
+<span class="sourceLineNo">2726</span>   */<a name="line.2726"></a>
+<span class="sourceLineNo">2727</span>  public void enableDebug(Class&lt;?&gt; clazz) {<a name="line.2727"></a>
+<span class="sourceLineNo">2728</span>    Log l = LogFactory.getLog(clazz);<a name="line.2728"></a>
+<span class="sourceLineNo">2729</span>    if (l instanceof Log4JLogger) {<a name="line.2729"></a>
+<span class="sourceLineNo">2730</span>      ((Log4JLogger) l).getLogger().setLevel(org.apache.log4j.Level.DEBUG);<a name="line.2730"></a>
+<span class="sourceLineNo">2731</span>    } else if (l instanceof Jdk14Logger) {<a name="line.2731"></a>
+<span class="sourceLineNo">2732</span>      ((Jdk14Logger) l).getLogger().setLevel(java.util.logging.Level.ALL);<a name="line.2732"></a>
+<span class="sourceLineNo">2733</span>    }<a name="line.2733"></a>
+<span class="sourceLineNo">2734</span>  }<a name="line.2734"></a>
+<span class="sourceLineNo">2735</span><a name="line.2735"></a>
+<span class="sourceLineNo">2736</span>  /**<a name="line.2736"></a>
+<span class="sourceLineNo">2737</span>   * Expire the Master's session<a name="line.2737"></a>
+<span class="sourceLineNo">2738</span>   * @throws Exception<a name="line.2738"></a>
+<span class="sourceLineNo">2739</span>   */<a name="line.2739"></a>
+<span class="sourceLineNo">2740</span>  public void expireMasterSession() throws Exception {<a name="line.2740"></a>
+<span class="sourceLineNo">2741</span>    HMaster master = getMiniHBaseCluster().getMaster();<a name="line.2741"></a>
+<span class="sourceLineNo">2742</span>    expireSession(master.getZooKeeper(), false);<a name="line.2742"></a>
+<span class="sourceLineNo">2743</span>  }<a name="line.2743"></a>
+<span class="sourceLineNo">2744</span><a name="line.2744"></a>
+<span class="sourceLineNo">2745</span>  /**<a name="line.2745"></a>
+<span class="sourceLineNo">2746</span>   * Expire a region server's session<a name="line.2746"></a>
+<span class="sourceLineNo">2747</span>   * @param index which RS<a name="line.2747"></a>
+<span class="sourceLineNo">2748</span>   * @throws Exception<a name="line.2748"></a>
+<span class="sourceLineNo">2749</span>   */<a name="line.2749"></a>
+<span class="sourceLineNo">2750</span>  public void expireRegionServerSession(int index) throws Exception {<a name="line.2750"></a>
+<span class="sourceLineNo">2751</span>    HRegionServer rs = getMiniHBaseCluster().getRegionServer(index);<a name="line.2751"></a>
+<span class="sourceLineNo">2752</span>    expireSession(rs.getZooKeeper(), false);<a name="line.2752"></a>
+<span class="sourceLineNo">2753</span>    decrementMinRegionServerCount();<a name="line.2753"></a>
+<span class="sourceLineNo">2754</span>  }<a name="line.2754"></a>
+<span class="sourceLineNo">2755</span><a name="line.2755"></a>
+<span class="sourceLineNo">2756</span>  private void decrementMinRegionServerCount() {<a name="line.2756"></a>
+<span class="sourceLineNo">2757</span>    // decrement the count for this.conf, for newly spwaned master<a name="line.2757"></a>
+<span class="sourceLineNo">2758</span>    // this.hbaseCluster shares this configuration too<a name="line.2758"></a>
+<span class="sourceLineNo">2759</span>    decrementMinRegionServerCount(getConfiguration());<a name="line.2759"></a>
 <span class="sourceLineNo">2760</span><a name="line.2760"></a>
-<span class="sourceLineNo">2761</span>  public void expireSession(ZKWatcher nodeZK) throws Exception {<a name="line.2761"></a>
-<span class="sourceLineNo">2762</span>   expireSession(nodeZK, false);<a name="line.2762"></a>
-<span class="sourceLineNo">2763</span>  }<a name="line.2763"></a>
-<span class="sourceLineNo">2764</span><a name="line.2764"></a>
-<span class="sourceLineNo">2765</span>  /**<a name="line.2765"></a>
-<span class="sourceLineNo">2766</span>   * Expire a ZooKeeper session as recommended in ZooKeeper documentation<a name="line.2766"></a>
-<span class="sourceLineNo">2767</span>   * http://hbase.apache.org/book.html#trouble.zookeeper<a name="line.2767"></a>
-<span class="sourceLineNo">2768</span>   * There are issues when doing this:<a name="line.2768"></a>
-<span class="sourceLineNo">2769</span>   * [1] http://www.mail-archive.com/dev@zookeeper.apache.org/msg01942.html<a name="line.2769"></a>
-<span class="sourceLineNo">2770</span>   * [2] https://issues.apache.org/jira/browse/ZOOKEEPER-1105<a name="line.2770"></a>
-<span class="sourceLineNo">2771</span>   *<a name="line.2771"></a>
-<span class="sourceLineNo">2772</span>   * @param nodeZK - the ZK watcher to expire<a name="line.2772"></a>
-<span class="sourceLineNo">2773</span>   * @param checkStatus - true to check if we can create a Table with the<a name="line.2773"></a>
-<span class="sourceLineNo">2774</span>   *                    current configuration.<a name="line.2774"></a>
-<span class="sourceLineNo">2775</span>   */<a name="line.2775"></a>
-<span class="sourceLineNo">2776</span>  public void expireSession(ZKWatcher nodeZK, boolean checkStatus)<a name="line.2776"></a>
-<span class="sourceLineNo">2777</span>    throws Exception {<a name="line.2777"></a>
-<span class="sourceLineNo">2778</span>    Configuration c = new Configuration(this.conf);<a name="line.2778"></a>
-<span class="sourceLineNo">2779</span>    String quorumServers = ZKConfig.getZKQuorumServersString(c);<a name="line.2779"></a>
-<span class="sourceLineNo">2780</span>    ZooKeeper zk = nodeZK.getRecoverableZooKeeper().getZooKeeper();<a name="line.2780"></a>
-<span class="sourceLineNo">2781</span>    byte[] password = zk.getSessionPasswd();<a name="line.2781"></a>
-<span class="sourceLineNo">2782</span>    long sessionID = zk.getSessionId();<a name="line.2782"></a>
-<span class="sourceLineNo">2783</span><a name="line.2783"></a>
-<span class="sourceLineNo">2784</span>    // Expiry seems to be asynchronous (see comment from P. Hunt in [1]),<a name="line.2784"></a>
-<span class="sourceLineNo">2785</span>    //  so we create a first watcher to be sure that the<a name="line.2785"></a>
-<span class="sourceLineNo">2786</span>    //  event was sent. We expect that if our watcher receives the event<a name="line.2786"></a>
-<span class="sourceLineNo">2787</span>    //  other watchers on the same machine will get is as well.<a name="line.2787"></a>
-<span class="sourceLineNo">2788</span>    // When we ask to close the connection, ZK does not close it before<a name="line.2788"></a>
-<span class="sourceLineNo">2789</span>    //  we receive all the events, so don't have to capture the event, just<a name="line.2789"></a>
-<span class="sourceLineNo">2790</span>    //  closing the connection should be enough.<a name="line.2790"></a>
-<span class="sourceLineNo">2791</span>    ZooKeeper monitor = new ZooKeeper(quorumServers,<a name="line.2791"></a>
-<span class="sourceLineNo">2792</span>      1000, new org.apache.zookeeper.Watcher(){<a name="line.2792"></a>
-<span class="sourceLineNo">2793</span>      @Override<a name="line.2793"></a>
-<span class="sourceLineNo">2794</span>      public void process(WatchedEvent watchedEvent) {<a name="line.2794"></a>
-<span class="sourceLineNo">2795</span>        LOG.info("Monitor ZKW received event="+watchedEvent);<a name="line.2795"></a>
-<span class="sourceLineNo">2796</span>      }<a name="line.2796"></a>
-<span class="sourceLineNo">2797</span>    } , sessionID, password);<a name="line.2797"></a>
+<span class="sourceLineNo">2761</span>    // each master thread keeps a copy of configuration<a name="line.2761"></a>
+<span class="sourceLineNo">2762</span>    for (MasterThread master : getHBaseCluster().getMasterThreads()) {<a name="line.2762"></a>
+<span class="sourceLineNo">2763</span>      decrementMinRegionServerCount(master.getMaster().getConfiguration());<a name="line.2763"></a>
+<span class="sourceLineNo">2764</span>    }<a name="line.2764"></a>
+<span class="sourceLineNo">2765</span>  }<a name="line.2765"></a>
+<span class="sourceLineNo">2766</span><a name="line.2766"></a>
+<span class="sourceLineNo">2767</span>  private void decrementMinRegionServerCount(Configuration conf) {<a name="line.2767"></a>
+<span class="sourceLineNo">2768</span>    int currentCount = conf.getInt(<a name="line.2768"></a>
+<span class="sourceLineNo">2769</span>        ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART, -1);<a name="line.2769"></a>
+<span class="sourceLineNo">2770</span>    if (currentCount != -1) {<a name="line.2770"></a>
+<span class="sourceLineNo">2771</span>      conf.setInt(ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART,<a name="line.2771"></a>
+<span class="sourceLineNo">2772</span>          Math.max(currentCount - 1, 1));<a name="line.2772"></a>
+<span class="sourceLineNo">2773</span>    }<a name="line.2773"></a>
+<span class="sourceLineNo">2774</span>  }<a name="line.2774"></a>
+<span class="sourceLineNo">2775</span><a name="line.2775"></a>
+<span class="sourceLineNo">2776</span>  public void expireSession(ZKWatcher nodeZK) throws Exception {<a name="line.2776"></a>
+<span class="sourceLineNo">2777</span>   expireSession(nodeZK, false);<a name="line.2777"></a>
+<span class="sourceLineNo">2778</span>  }<a name="line.2778"></a>
+<span class="sourceLineNo">2779</span><a name="line.2779"></a>
+<span class="sourceLineNo">2780</span>  /**<a name="line.2780"></a>
+<span class="sourceLineNo">2781</span>   * Expire a ZooKeeper session as recommended in ZooKeeper documentation<a name="line.2781"></a>
+<span class="sourceLineNo">2782</span>   * http://hbase.apache.org/book.html#trouble.zookeeper<a name="line.2782"></a>
+<span class="sourceLineNo">2783</span>   * There are issues when doing this:<a name="line.2783"></a>
+<span class="sourceLineNo">2784</span>   * [1] http://www.mail-archive.com/dev@zookeeper.apache.org/msg01942.html<a name="line.2784"></a>
+<span class="sourceLineNo">2785</span>   * [2] https://issues.apache.org/jira/browse/ZOOKEEPER-1105<a name="line.2785"></a>
+<span class="sourceLineNo">2786</span>   *<a name="line.2786"></a>
+<span class="sourceLineNo">2787</span>   * @param nodeZK - the ZK watcher to expire<a name="line.2787"></a>
+<span class="sourceLineNo">2788</span>   * @param checkStatus - true to check if we can create a Table with the<a name="line.2788"></a>
+<span class="sourceLineNo">2789</span>   *                    current configuration.<a name="line.2789"></a>
+<span class="sourceLineNo">2790</span>   */<a name="line.2790"></a>
+<span class="sourceLineNo">2791</span>  public void expireSession(ZKWatcher nodeZK, boolean checkStatus)<a name="line.2791"></a>
+<span class="sourceLineNo">2792</span>    throws Exception {<a name="line.2792"></a>
+<span class="sourceLineNo">2793</span>    Configuration c = new Configuration(this.conf);<a name="line.2793"></a>
+<span class="sourceLineNo">2794</span>    String quorumServers = ZKConfig.getZKQuorumServersString(c);<a name="line.2794"></a>
+<span class="sourceLineNo">2795</span>    ZooKeeper zk = nodeZK.getRecoverableZooKeeper().getZooKeeper();<a name="line.2795"></a>
+<span class="sourceLineNo">2796</span>    byte[] password = zk.getSessionPasswd();<a name="line.2796"></a>
+<span class="sourceLineNo">2797</span>    long sessionID = zk.getSessionId();<a name="line.2797"></a>
 <span class="sourceLineNo">2798</span><a name="line.2798"></a>
-<span class="sourceLineNo">2799</span>    // Making it expire<a name="line.2799"></a>
-<span class="sourceLineNo">2800</span>    ZooKeeper newZK = new ZooKeeper(quorumServers,<a name="line.2800"></a>
-<span class="sourceLineNo">2801</span>        1000, EmptyWatcher.instance, sessionID, password);<a name="line.2801"></a>
-<span class="sourceLineNo">2802</span><a name="line.2802"></a>
-<span class="sourceLineNo">2803</span>    //ensure that we have connection to the server before closing down, otherwise<a name="line.2803"></a>
-<span class="sourceLineNo">2804</span>    //the close session event will be eaten out before we start CONNECTING state<a name="line.2804"></a>
-<span class="sourceLineNo">2805</span>    long start = System.currentTimeMillis();<a name="line.2805"></a>
-<span class="sourceLineNo">2806</span>    while (newZK.getState() != States.CONNECTED<a name="line.2806"></a>
-<span class="sourceLineNo">2807</span>         &amp;&amp; System.currentTimeMillis() - start &lt; 1000) {<a name="line.2807"></a>
-<span class="sourceLineNo">2808</span>       Thread.sleep(1);<a name="line.2808"></a>
-<span class="sourceLineNo">2809</span>    }<a name="line.2809"></a>
-<span class="sourceLineNo">2810</span>    newZK.close();<a name="line.2810"></a>
-<span class="sourceLineNo">2811</span>    LOG.info("ZK Closed Session 0x" + Long.toHexString(sessionID));<a name="line.2811"></a>
-<span class="sourceLineNo">2812</span><a name="line.2812"></a>
-<span class="sourceLineNo">2813</span>    // Now closing &amp; waiting to be sure that the clients get it.<a name="line.2813"></a>
-<span class="sourceLineNo">2814</span>    monitor.close();<a name="line.2814"></a>
-<span class="sourceLineNo">2815</span><a name="line.2815"></a>
-<span class="sourceLineNo">2816</span>    if (checkStatus) {<a name="line.2816"></a>
-<span class="sourceLineNo">2817</span>      getConnection().getTable(TableName.META_TABLE_NAME).close();<a name="line.2817"></a>
-<span class="sourceLineNo">2818</span>    }<a name="line.2818"></a>
-<span class="sourceLineNo">2819</span>  }<a name="line.2819"></a>
-<span class="sourceLineNo">2820</span><a name="line.2820"></a>
-<span class="sourceLineNo">2821</span>  /**<a name="line.2821"></a>
-<span class="sourceLineNo">2822</span>   * Get the Mini HBase cluster.<a name="line.2822"></a>
-<span class="sourceLineNo">2823</span>   *<a name="line.2823"></a>
-<span class="sourceLineNo">2824</span>   * @return hbase cluster<a name="line.2824"></a>
-<span class="sourceLineNo">2825</span>   * @see #getHBaseClusterInterface()<a name="line.2825"></a>
-<span class="sourceLineNo">2826</span>   */<a name="line.2826"></a>
-<span class="sourceLineNo">2827</span>  public MiniHBaseCluster getHBaseCluster() {<a name="line.2827"></a>
-<span class="sourceLineNo">2828</span>    return getMiniHBaseCluster();<a name="line.2828"></a>
-<span class="sourceLineNo">2829</span>  }<a name="line.2829"></a>
+<span class="sourceLineNo">2799</span>    // Expiry seems to be asynchronous (see comment from P. Hunt in [1]),<a name="line.2799"></a>
+<span class="sourceLineNo">2800</span>    //  so we create a first watcher to be sure that the<a name="line.2800"></a>
+<span class="sourceLineNo">2801</span>    //  event was sent. We expect that if our watcher receives the event<a name="line.2801"></a>
+<span class="sourceLineNo">2802</span>    //  other watchers on the same machine will get is as well.<a name="line.2802"></a>
+<span class="sourceLineNo">2803</span>    // When we ask to close the connection, ZK does not close it before<a name="line.2803"></a>
+<span class="sourceLineNo">2804</span>    //  we receive all the events, so don't have to capture the event, just<a name="line.2804"></a>
+<span class="sourceLineNo">2805</span>    //  closing the connection should be enough.<a name="line.2805"></a>
+<span class="sourceLineNo">2806</span>    ZooKeeper monitor = new ZooKeeper(quorumServers,<a name="line.2806"></a>
+<span class="sourceLineNo">2807</span>      1000, new org.apache.zookeeper.Watcher(){<a name="line.2807"></a>
+<span class="sourceLineNo">2808</span>      @Override<a name="line.2808"></a>
+<span class="sourceLineNo">2809</span>      public void process(WatchedEvent watchedEvent) {<a name="line.2809"></a>
+<span class="sourceLineNo">2810</span>        LOG.info("Monitor ZKW received event="+watchedEvent);<a name="line.2810"></a>
+<span class="sourceLineNo">2811</span>      }<a name="line.2811"></a>
+<span class="sourceLineNo">2812</span>    } , sessionID, password);<a name="line.2812"></a>
+<span class="sourceLineNo">2813</span><a name="line.2813"></a>
+<span class="sourceLineNo">2814</span>    // Making it expire<a name="line.2814"></a>
+<span class="sourceLineNo">2815</span>    ZooKeeper newZK = new ZooKeeper(quorumServers,<a name="line.2815"></a>
+<span class="sourceLineNo">2816</span>        1000, EmptyWatcher.instance, sessionID, password);<a name="line.2816"></a>
+<span class="sourceLineNo">2817</span><a name="line.2817"></a>
+<span class="sourceLineNo">2818</span>    //ensure that we have connection to the server before closing down, otherwise<a name="line.2818"></a>
+<span class="sourceLineNo">2819</span>    //the close session event will be eaten out before we start CONNECTING state<a name="line.2819"></a>
+<span class="sourceLineNo">2820</span>    long start = System.currentTimeMillis();<a name="line.2820"></a>
+<span class="sourceLineNo">2821</span>    while (newZK.getState() != States.CONNECTED<a name="line.2821"></a>
+<span class="sourceLineNo">2822</span>         &amp;&amp; System.currentTimeMillis() - start &lt; 1000) {<a name="line.2822"></a>
+<span class="sourceLineNo">2823</span>       Thread.sleep(1);<a name="line.2823"></a>
+<span class="sourceLineNo">2824</span>    }<a name="line.2824"></a>
+<span class="sourceLineNo">2825</span>    newZK.close();<a name="line.2825"></a>
+<span class="sourceLineNo">2826</span>    LOG.info("ZK Closed Session 0x" + Long.toHexString(sessionID));<a name="line.2826"></a>
+<span class="sourceLineNo">2827</span><a name="line.2827"></a>
+<span class="sourceLineNo">2828</span>    // Now closing &amp; waiting to be sure that the clients get it.<a name="line.2828"></a>
+<span class="sourceLineNo">2829</span>    monitor.close();<a name="line.2829"></a>
 <span class="sourceLineNo">2830</span><a name="line.2830"></a>
-<span class="sourceLineNo">2831</span>  /**<a name="line.2831"></a>
-<span class="sourceLineNo">2832</span>   * Returns the HBaseCluster instance.<a name="line.2832"></a>
-<span class="sourceLineNo">2833</span>   * &lt;p&gt;Returned object can be any of the subclasses of HBaseCluster, and the<a name="line.2833"></a>
-<span class="sourceLineNo">2834</span>   * tests referring this should not assume that the cluster is a mini cluster or a<a name="line.2834"></a>
-<span class="sourceLineNo">2835</span>   * distributed one. If the test only works on a mini cluster, then specific<a name="line.2835"></a>
-<span class="sourceLineNo">2836</span>   * method {@link #getMiniHBaseCluster()} can be used instead w/o the<a name="line.2836"></a>
-<span class="sourceLineNo">2837</span>   * need to type-cast.<a name="line.2837"></a>
-<span class="sourceLineNo">2838</span>   */<a name="line.2838"></a>
-<span class="sourceLineNo">2839</span>  public HBaseCluster getHBaseClusterInterface() {<a name="line.2839"></a>
-<span class="sourceLineNo">2840</span>    //implementation note: we should rename this method as #getHBaseCluster(),<a name="line.2840"></a>
-<span class="sourceLineNo">2841</span>    //but this would require refactoring 90+ calls.<a name="line.2841"></a>
-<span class="sourceLineNo">2842</span>    return hbaseCluster;<a name="line.2842"></a>
-<span class="sourceLineNo">2843</span>  }<a name="line.2843"></a>
-<span class="sourceLineNo">2844</span><a name="line.2844"></a>
-<span class="sourceLineNo">2845</span>  /**<a name="line.2845"></a>
-<span class="sourceLineNo">2846</span>   * Get a Connection to the cluster.<a name="line.2846"></a>
-<span class="sourceLineNo">2847</span>   * Not thread-safe (This class needs a lot of work to make it thread-safe).<a name="line.2847"></a>
-<span class="sourceLineNo">2848</span>   * @return A Connection that can be shared. Don't close. Will be closed on shutdown of cluster.<a name="line.2848"></a>
-<span class="sourceLineNo">2849</span>   * @throws IOException<a name="line.2849"></a>
-<span class="sourceLineNo">2850</span>   */<a name="line.2850"></a>
-<span class="sourceLineNo">2851</span>  public Connection getConnection() throws IOException {<a name="line.2851"></a>
-<span class="sourceLineNo">2852</span>    if (this.connection == null) {<a name="line.2852"></a>
-<span class="sourceLineNo">2853</span>      this.connection = ConnectionFactory.createConnection(this.conf);<a name="line.2853"></a>
-<span class="sourceLineNo">2854</span>    }<a name="line.2854"></a>
-<span class="sourceLineNo">2855</span>    return this.connection;<a name="line.2855"></a>
-<span class="sourceLineNo">2856</span>  }<a name="line.2856"></a>
-<span class="sourceLineNo">2857</span><a name="line.2857"></a>
-<span class="sourceLineNo">2858</span>  /**<a name="line.2858"></a>
-<span class="sourceLineNo">2859</span>   * Returns a Admin instance.<a name="line.2859"></a>
-<span class="sourceLineNo">2860</span>   * This instance is shared between HBaseTestingUtility instance users. Closing it has no effect,<a name="line.2860"></a>
-<span class="sourceLineNo">2861</span>   * it will be closed automatically when the cluster shutdowns<a name="line.2861"></a>
-<span class="sourceLineNo">2862</span>   *<a name="line.2862"></a>
-<span class="sourceLineNo">2863</span>   * @return HBaseAdmin instance which is guaranteed to support only {@link Admin} interface.<a name="line.2863"></a>
-<span class="sourceLineNo">2864</span>   *   Functions in HBaseAdmin not provided by {@link Admin} interface can be changed/deleted<a name="line.2864"></a>
-<span class="sourceLineNo">2865</span>   *   anytime.<a name="line.2865"></a>
-<span class="sourceLineNo">2866</span>   * @deprecated Since 2.0. Will be removed in 3.0. Use {@link #getAdmin()} instead.<a name="line.2866"></a>
-<span class="sourceLineNo">2867</span>   */<a name="line.2867"></a>
-<span class="sourceLineNo">2868</span>  @Deprecated<a name="line.2868"></a>
-<span class="sourceLineNo">2869</span>  public synchronized HBaseAdmin getHBaseAdmin()<a name="line.2869"></a>
-<span class="sourceLineNo">2870</span>  throws IOException {<a name="line.2870"></a>
-<span class="sourceLineNo">2871</span>    if (hbaseAdmin == null){<a name="line.2871"></a>
-<span class="sourceLineNo">2872</span>      this.hbaseAdmin = (HBaseAdmin) getConnection().getAdmin();<a name="line.2872"></a>
-<span class="sourceLineNo">2873</span>    }<a name="line.2873"></a>
-<span class="sourceLineNo">2874</span>    return hbaseAdmin;<a name="line.2874"></a>
-<span class="sourceLineNo">2875</span>  }<a name="line.2875"></a>
-<span class="sourceLineNo">2876</span><a name="line.2876"></a>
-<span class="sourceLineNo">2877</span>  /**<a name="line.2877"></a>
-<span class="sourceLineNo">2878</span>   * Returns an Admin instance which is shared between HBaseTestingUtility instance users.<a name="line.2878"></a>
-<span class="sourceLineNo">2879</span>   * Closing it has no effect, it will be closed automatically when the cluster shutdowns<a name="line.2879"></a>
-<span class="sourceLineNo">2880</span>   */<a name="line.2880"></a>
-<span class="sourceLineNo">2881</span>  public synchronized Admin getAdmin() throws IOException {<a name="line.2881"></a>
-<span class="sourceLineNo">2882</span>    if (hbaseAdmin == null){<a name="line.2882"></a>
-<span class="sourceLineNo">2883</span>      this.hbaseAdmin = (HBaseAdmin) getConnection().getAdmin();<a name="line.2883"></a>
-<span class="sourceLineNo">2884</span>    }<a name="line.2884"></a>
-<span class="sourceLineNo">2885</span>    return hbaseAdmin;<a name="line.2885"></a>
-<span class="sourceLineNo">2886</span>  }<a name="line.2886"></a>
-<span class="sourceLineNo">2887</span><a name="line.2887"></a>
-<span class="sourceLineNo">2888</span>  private HBaseAdmin hbaseAdmin = null;<a name="line.2888"></a>
-<span class="sourceLineNo">2889</span><a name="line.2889"></a>
-<span class="sourceLineNo">2890</span>  /**<a name="line.2890"></a>
-<span class="sourceLineNo">2891</span>   * Returns a ZKWatcher instance.<a name="line.2891"></a>
-<span class="sourceLineNo">2892</span>   * This instance is shared between HBaseTestingUtility instance users.<a name="line.2892"></a>
-<span class="sourceLineNo">2893</span>   * Don't close it, it will be closed automatically when the<a name="line.2893"></a>
-<span class="sourceLineNo">2894</span>   * cluster shutdowns<a name="line.2894"></a>
-<span class="sourceLineNo">2895</span>   *<a name="line.2895"></a>
-<span class="sourceLineNo">2896</span>   * @return The ZKWatcher instance.<a name="line.2896"></a>
-<span class="sourceLineNo">2897</span>   * @throws IOException<a name="line.2897"></a>
-<span class="sourceLineNo">2898</span>   */<a name="line.2898"></a>
-<span class="sourceLineNo">2899</span>  public synchronized ZKWatcher getZooKeeperWatcher()<a name="line.2899"></a>
-<span class="sourceLineNo">2900</span>    throws IOException {<a name="line.2900"></a>
-<span class="sourceLineNo">2901</span>    if (zooKeeperWatcher == null) {<a name="line.2901"></a>
-<span class="sourceLineNo">2902</span>      zooKeeperWatcher = new ZKWatcher(conf, "testing utility",<a name="line.2902"></a>
-<span class="sourceLineNo">2903</span>        new Abortable() {<a name="line.2903"></a>
-<span class="sourceLineNo">2904</span>        @Override public void abort(String why, Throwable e) {<a name="line.2904"></a>
-<span class="sourceLineNo">2905</span>          throw new RuntimeException("Unexpected abort in HBaseTestingUtility:"+why, e);<a name="line.2905"></a>
-<span class="sourceLineNo">2906</span>        }<a name="line.2906"></a>
-<span class="sourceLineNo">2907</span>        @Override public boolean isAborted() {return false;}<a name="line.2907"></a>
-<span class="sourceLineNo">2908</span>      });<a name="line.2908"></a>
-<span class="sourceLineNo">2909</span>    }<a name="line.2909"></a>
-<span class="sourceLineNo">2910</span>    return zooKeeperWatcher;<a name="line.2910"></a>
-<span class="sourceLineNo">2911</span>  }<a name="line.2911"></a>
-<span class="sourceLineNo">2912</span>  private ZKWatcher zooKeeperWatcher;<a name="line.2912"></a>
-<span class="sourceLineNo">2913</span><a name="line.2913"></a>
-<span class="sourceLineNo">2914</span><a name="line.2914"></a>
-<span class="sourceLineNo">2915</span><a name="line.2915"></a>
-<span class="sourceLineNo">2916</span>  /**<a name="line.2916"></a>
-<span class="sourceLineNo">2917</span>   * Unassign the named region.<a name="line.2917"></a>
-<span class="sourceLineNo">2918</span>   *<a name="line.2918"></a>
-<span class="sourceLineNo">2919</span>   * @param regionName  The region to unassign.<a name="line.2919"></a>
-<span class="sourceLineNo">2920</span>   */<a name="line.2920"></a>
-<span class="sourceLineNo">2921</span>  public void unassignRegion(String regionName) throws IOException {<a name="line.2921"></a>
-<span class="sourceLineNo">2922</span>    unassignRegion(Bytes.toBytes(regionName));<a name="line.2922"></a>
-<span class="sourceLineNo">2923</span>  }<a name="line.2923"></a>
-<span class="sourceLineNo">2924</span><a name="line.2924"></a>
-<span class="sourceLineNo">2925</span>  /**<a name="line.2925"></a>
-<span class="sourceLineNo">2926</span>   * Unassign the named region.<a name="line.2926"></a>
-<span class="sourceLineNo">2927</span>   *<a name="line.2927"></a>
-<span class="sourceLineNo">2928</span>   * @param regionName  The region to unassign.<a name="line.2928"></a>
-<span class="sourceLineNo">2929</span>   */<a name="line.2929"></a>
-<span class="sourceLineNo">2930</span>  public void unassignRegion(byte[] regionName) throws IOException {<a name="line.2930"></a>
-<span class="sourceLineNo">2931</span>    getAdmin().unassign(regionName, true);<a name="line.2931"></a>
-<span class="sourceLineNo">2932</span>  }<a name="line.2932"></a>
-<span class="sourceLineNo">2933</span><a name="line.2933"></a>
-<span class="sourceLineNo">2934</span>  /**<a name="line.2934"></a>
-<span class="sourceLineNo">2935</span>   * Closes the region containing the given row.<a name="line.2935"></a>
-<span class="sourceLineNo">2936</span>   *<a name="line.2936"></a>
-<span class="sourceLineNo">2937</span>   * @param row  The row to find the containing region.<a name="line.2937"></a>
-<span class="sourceLineNo">2938</span>   * @param table  The table to find the region.<a name="line.2938"></a>
-<span class="sourceLineNo">2939</span>   */<a name="line.2939"></a>
-<span class="sourceLineNo">2940</span>  public void unassignRegionByRow(String row, RegionLocator table) throws IOException {<a name="line.2940"></a>
-<span class="sourceLineNo">2941</span>    unassignRegionByRow(Bytes.toBytes(row), table);<a name="line.2941"></a>
-<span class="sourceLineNo">2942</span>  }<a name="line.2942"></a>
-<span class="sourceLineNo">2943</span><a name="line.2943"></a>
-<span class="sourceLineNo">2944</span>  /**<a name="line.2944"></a>
-<span class="sourceLineNo">2945</span>   * Closes the region containing the given row.<a name="line.2945"></a>
-<span class="sourceLineNo">2946</span>   *<a name="line.2946"></a>
-<span class="sourceLineNo">2947</span>   * @param row  The row to find the containing region.<a name="line.2947"></a>
-<span class="sourceLineNo">2948</span>   * @param table  The table to find the region.<a name="line.2948"></a>
-<span class="sourceLineNo">2949</span>   * @throws IOException<a name="line.2949"></a>
-<span class="sourceLineNo">2950</span>   */<a name="line.2950"></a>
-<span class="sourceLineNo">2951</span>  public void unassignRegionByRow(byte[] row, RegionLocator table) throws IOException {<a name="line.2951"></a>
-<span class="sourceLineNo">2952</span>    HRegionLocation hrl = table.getRegionLocation(row);<a name="line.2952"></a>
-<span class="sourceLineNo">2953</span>    unassignRegion(hrl.getRegionInfo().getRegionName());<a name="line.2953"></a>
-<span class="sourceLineNo">2954</span>  }<a name="line.2954"></a>
-<span class="sourceLineNo">2955</span><a name="line.2955"></a>
-<span class="sourceLineNo">2956</span>  /*<a name="line.2956"></a>
-<span class="sourceLineNo">2957</span>   * Retrieves a splittable region randomly from tableName<a name="line.2957"></a>
-<span class="sourceLineNo">2958</span>   *<a name="line.2958"></a>
-<span class="sourceLineNo">2959</span>   * @param tableName name of table<a name="line.2959"></a>
-<span class="sourceLineNo">2960</span>   * @param maxAttempts maximum number of attempts, unlimited for value of -1<a name="line.2960"></a>
-<span class="sourceLineNo">2961</span>   * @return the HRegion chosen, null if none was found within limit of maxAttempts<a name="line.2961"></a>
-<span class="sourceLineNo">2962</span>   */<a name="line.2962"></a>
-<span class="sourceLineNo">2963</span>  public HRegion getSplittableRegion(TableName tableName, int maxAttempts) {<a name="line.2963"></a>
-<span class="sourceLineNo">2964</span>    List&lt;HRegion&gt; regions = getHBaseCluster().getRegions(tableName);<a name="line.2964"></a>
-<span class="sourceLineNo">2965</span>    int regCount = regions.size();<a name="line.2965"></a>
-<span class="sourceLineNo">2966</span>    Set&lt;Integer&gt; attempted = new HashSet&lt;&gt;();<a name="line.2966"></a>
-<span class="sourceLineNo">2967</span>    int idx;<a name="line.2967"></a>
-<span class="sourceLineNo">2968</span>    int attempts = 0;<a name="line.2968"></a>
-<span class="sourceLineNo">2969</span>    do {<a name="line.2969"></a>
-<span class="sourceLineNo">2970</span>      regions = getHBaseCluster().getRegions(tableName);<a name="line.2970"></a>
-<span class="sourceLineNo">2971</span>      if (regCount != regions.size()) {<a name="line.2971"></a>
-<span class="sourceLineNo">2972</span>        // if there was region movement, clear attempted Set<a name="line.2972"></a>
-<span class="sourceLineNo">2973</span>        attempted.clear();<a name="line.2973"></a>
-<span class="sourceLineNo">2974</span>      }<a name="line.2974"></a>
-<span class="sourceLineNo">2975</span>      regCount = regions.size();<a name="line.2975"></a>
-<span class="sourceLineNo">2976</span>      // There are chances that before we get the region for the table from an RS the region may<a name="line.2976"></a>
-<span class="sourceLineNo">2977</span>      // be going for CLOSE.  This may be because online schema change is enabled<a name="line.2977"></a>
-<span class="sourceLineNo">2978</span>      if (regCount &gt; 0) {<a name="line.2978"></a>
-<span class="sourceLineNo">2979</span>        idx = random.nextInt(regCount);<a name="line.2979"></a>
-<span class="sourceLineNo">2980</span>        // if we have just tried this region, there is no need to try again<a name="line.2980"></a>
-<span class="sourceLineNo">2981</span>        if (attempted.contains(idx))<a name="line.2981"></a>
-<span class="sourceLineNo">2982</span>          continue;<a name="line.2982"></a>
-<span class="sourceLineNo">2983</span>        try {<a name="line.2983"></a>
-<span class="sourceLineNo">2984</span>          regions.get(idx).checkSplit();<a name="line.2984"></a>
-<span class="sourceLineNo">2985</span>          return regions.get(idx);<a name="line.2985"></a>
-<span class="sourceLineNo">2986</span>        } catch (Exception ex) {<a name="line.2986"></a>
-<span class="sourceLineNo">2987</span>          LOG.warn("Caught exception", ex);<a name="line.2987"></a>
-<span class="sourceLineNo">2988</span>          attempted.add(idx);<a name="line.2988"></a>
-<span class="sourceLineNo">2989</span>        }<a name="line.2989"></a>
-<span class="sourceLineNo">2990</span>      }<a name="line.2990"></a>
-<span class="sourceLineNo">2991</span>      attempts++;<a name="line.2991"></a>
-<span class="sourceLineNo">2992</span>    } while (maxAttempts == -1 || attempts &lt; maxAttempts);<a name="line.2992"></a>
-<span class="sourceLineNo">2993</span>    return null;<a name="line.2993"></a>
-<span class="sourceLineNo">2994</span>  }<a name="line.2994"></a>
-<span class="sourceLineNo">2995</span><a name="line.2995"></a>
-<span class="sourceLineNo">2996</span>  public MiniZooKeeperCluster getZkCluster() {<a name="line.2996"></a>
-<span class="sourceLineNo">2997</span>    return zkCluster;<a name="line.2997"></a>
-<span class="sourceLineNo">2998</span>  }<a name="line.2998"></a>
-<span class="sourceLineNo">2999</span><a name="line.2999"></a>
-<span class="sourceLineNo">3000</span>  public void setZkCluster(MiniZooKeeperCluster zkCluster) {<a name="line.3000"></a>
-<span class="sourceLineNo">3001</span>    this.passedZkCluster = true;<a name="line.3001"></a>
-<span class="sourceLineNo">3002</span>    this.zkCluster = zkCluster;<a name="line.3002"></a>
-<span class="sourceLineNo">3003</span>    conf.setInt(HConstants.ZOOKEEPER_CLIENT_PORT, zkCluster.getClientPort());<a name="line.3003"></a>
-<span class="sourceLineNo">3004</span>  }<a name="line.3004"></a>
-<span class="sourceLineNo">3005</span><a name="line.3005"></a>
-<span class="sourceLineNo">3006</span>  public MiniDFSCluster getDFSCluster() {<a name="line.3006"></a>
-<span class="sourceLineNo">3007</span>    return dfsCluster;<a name="line.3007"></a>
-<span class="sourceLineNo">3008</span>  }<a name="line.3008"></a>
-<span class="sourceLineNo">3009</span><a name="line.3009"></a>
-<span class="sourceLineNo">3010</span>  public void setDFSCluster(MiniDFSCluster cluster) throws IllegalStateException, IOException {<a name="line.3010"></a>
-<span class="sourceLineNo">3011</span>    setDFSCluster(cluster, true);<a name="line.3011"></a>
-<span class="sourceLineNo">3012</span>  }<a name="line.3012"></a>
-<span class="sourceLineNo">3013</span><a name="line.3013"></a>
-<span class="sourceLineNo">3014</span>  /**<a name="line.3014"></a>
-<span class="sourceLineNo">3015</span>   * Set the MiniDFSCluster<a name="line.3015"></a>
-<span class="sourceLineNo">3016</span>   * @param cluster cluster to use<a name="line.3016"></a>
-<span class="sourceLineNo">3017</span>   * @param requireDown require the that cluster not be "up" (MiniDFSCluster#isClusterUp) before<a name="line.3017"></a>
-<span class="sourceLineNo">3018</span>   * it is set.<a name="line.3018"></a>
-<span class="sourceLineNo">3019</span>   * @throws IllegalStateException if the passed cluster is up when it is required to be down<a name="line.3019"></a>
-<span class="sourceLineNo">3020</span>   * @throws IOException if the FileSystem could not be set from the passed dfs cluster<a name="line.3020"></a>
-<span class="sourceLineNo">3021</span>   */<a name="line.3021"></a>
-<span class="sourceLineNo">3022</span>  public void setDFSCluster(MiniDFSCluster cluster, boolean requireDown)<a name="line.3022"></a>
-<span class="sourceLineNo">3023</span>      throws IllegalStateException, IOException {<a name="line.3023"></a>
-<span class="sourceLineNo">3024</span>    if (dfsCluster != null &amp;&amp; requireDown &amp;&amp; dfsCluster.isClusterUp()) {<a name="line.3024"></a>
-<span class="sourceLineNo">3025</span>      throw new IllegalStateException("DFSCluster is already running! Shut it down first.");<a name="line.3025"></a>
-<span class="sourceLineNo">3026</span>    }<a name="line.3026"></a>
-<span class="sourceLineNo">3027</span>    this.dfsCluster = cluster;<a name="line.3027"></a>
-<span class="sourceLineNo">3028</span>    this.setFs();<a name="line.3028"></a>
-<span class="sourceLineNo">3029</span>  }<a name="line.3029"></a>
-<span class="sourceLineNo">3030</span><a name="line.3030"></a>
-<span class="sourceLineNo">3031</span>  public FileSystem getTestFileSystem() throws IOException {<a name="line.3031"></a>
-<span class="sourceLineNo">3032</span>    return HFileSystem.get(conf);<a name="line.3032"></a>
-<span class="sourceLineNo">3033</span>  }<a name="line.3033"></a>
-<span class="sourceLineNo">3034</span><a name="line.3034"></a>
-<span class="sourceLineNo">3035</span>  /**<a name="line.3035"></a>
-<span class="sourceLineNo">3036</span>   * Wait until all regions in a table have been assigned.  Waits default timeout before giving up<a name="line.3036"></a>
-<span class="sourceLineNo">3037</span>   * (30 seconds).<a name="line.3037"></a>
-<span class="sourceLineNo">3038</span>   * @param table Table to wait on.<a name="line.3038"></a>
-<span class="sourceLineNo">3039</span>   * @throws InterruptedException<a name="line.3039"></a>
-<span class="sourceLineNo">3040</span>   * @throws IOException<a name="line.3040"></a>
-<span class="sourceLineNo">3041</span>   */<a name="line.3041"></a>
-<span class="sourceLineNo">3042</span>  public void waitTableAvailable(TableName table)<a name="line.3042"></a>
-<span class="sourceLineNo">3043</span>      throws InterruptedException, IOException {<a name="line.3043"></a>
-<span class="sourceLineNo">3044</span>    waitTableAvailable(table.getName(), 30000);<a name="line.3044"></a>
-<span class="sourceLineNo">3045</span>  }<a name="line.3045"></a>
-<span class="sourceLineNo">3046</span><a name="line.3046"></a>
-<span class="sourceLineNo">3047</span>  public void waitTableAvailable(TableName table, long timeoutMillis)<a name="line.3047"></a>
-<span class="sourceLineNo">3048</span>      throws InterruptedException, IOException {<a name="line.3048"></a>
-<span class="sourceLineNo">3049</span>    waitFor(timeoutMillis, predicateTableAvailable(table));<a name="line.3049"></a>
-<span class="sourceLineNo">3050</span>  }<a name="line.3050"></a>
-<span class="sourceLineNo">3051</span><a name="line.3051"></a>
-<span class="sourceLineNo">3052</span>  /**<a name="line.3052"></a>
-<span class="sourceLineNo">3053</span>   * Wait until all regions in a table have been assigned<a name="line.3053"></a>
-<span class="sourceLineNo">3054</span>   * @param table Table to wait on.<a name="line.3054"></a>
-<span class="sourceLineNo">3055</span>   * @param timeoutMillis Timeout.<a name="line.3055"></a>
-<span class="sourceLineNo">3056</span>   * @throws InterruptedException<a name="line.3056"></a>
-<span class="sourceLineNo">3057</span>   * @throws IOException<a name="line.3057"></a>
-<span class="sourceLineNo">3058</span>   */<a name="line.3058"></a>
-<span class="sourceLineNo">3059</span>  public void waitTableAvailable(byte[] table, long timeoutMillis)<a name="line.3059"></a>
-<span class="sourceLineNo">3060</span>  throws InterruptedException, IOException {<a name="line.3060"></a>
-<span class="sourceLineNo">3061</span>    waitFor(timeoutMillis, predicateTableAvailable(TableName.valueOf(table)));<a name="line.3061"></a>
-<span class="sourceLineNo">3062</span>  }<a name="line.3062"></a>
-<span class="sourceLineNo">3063</span><a name="line.3063"></a>
-<span class="sourceLineNo">3064</span>  public String explainTableAvailability(TableName tableName) throws IOException {<a name="line.3064"></a>
-<span class="sourceLineNo">3065</span>    String msg = explainTableState(tableName, TableState.State.ENABLED) + ", ";<a name="line.3065"></a>
-<span class="sourceLineNo">3066</span>    if (getHBaseCluster().getMaster().isAlive()) {<a name="line.3066"></a>
-<span class="sourceLineNo">3067</span>      Map&lt;RegionInfo, ServerName&gt; assignments =<a name="line.3067"></a>
-<span class="sourceLineNo">3068</span>          getHBaseCluster().getMaster().getAssignmentManager().getRegionStates()<a name="line.3068"></a>
-<span class="sourceLineNo">3069</span>              .getRegionAssignments();<a name="line.3069"></a>
-<span class="sourceLineNo">3070</span>      final List&lt;Pair&lt;RegionInfo, ServerName&gt;&gt; metaLocations =<a name="line.3070"></a>
-<span class="sourceLineNo">3071</span>          MetaTableAccessor.getTableRegionsAndLocations(connection, tableName);<a name="line.3071"></a>
-<span class="sourceLineNo">3072</span>      for (Pair&lt;RegionInfo, ServerName&gt; metaLocation : metaLocations) {<a name="line.3072"></a>
-<span class="sourceLineNo">3073</span>        RegionInfo hri = metaLocation.getFirst();<a name="line.3073"></a>
-<span class="sourceLineNo">3074</span>        ServerName sn = metaLocation.getSecond();<a name="line.3074"></a>
-<span class="sourceLineNo">3075</span>        if (!assignments.containsKey(hri)) {<a name="line.3075"></a>
-<span class="sourceLineNo">3076</span>          msg += ", region " + hri<a name="line.3076"></a>
-<span class="sourceLineNo">3077</span>              + " not assigned, but found i

<TRUNCATED>

[11/14] hbase-site git commit: Published site at .

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.html
----------------------------------------------------------------------
diff --git a/testapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.html b/testapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.html
index cd1cae9..d9df6ad 100644
--- a/testapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.html
+++ b/testapidocs/org/apache/hadoop/hbase/HBaseTestingUtility.html
@@ -18,7 +18,7 @@
     catch(err) {
     }
 //-->
-var methods = {"i0":9,"i1":10,"i2":10,"i3":10,"i4":9,"i5":10,"i6":10,"i7":10,"i8":10,"i9":9,"i10":9,"i11":10,"i12":10,"i13":10,"i14":10,"i15":10,"i16":10,"i17":10,"i18":10,"i19":10,"i20":42,"i21":10,"i22":10,"i23":10,"i24":10,"i25":10,"i26":9,"i27":9,"i28":10,"i29":10,"i30":10,"i31":42,"i32":10,"i33":10,"i34":10,"i35":10,"i36":10,"i37":9,"i38":9,"i39":9,"i40":9,"i41":9,"i42":9,"i43":9,"i44":10,"i45":9,"i46":9,"i47":10,"i48":10,"i49":10,"i50":10,"i51":10,"i52":10,"i53":10,"i54":10,"i55":10,"i56":10,"i57":10,"i58":10,"i59":10,"i60":10,"i61":10,"i62":10,"i63":10,"i64":10,"i65":10,"i66":42,"i67":42,"i68":10,"i69":10,"i70":10,"i71":10,"i72":10,"i73":9,"i74":10,"i75":10,"i76":10,"i77":10,"i78":10,"i79":10,"i80":10,"i81":10,"i82":10,"i83":10,"i84":10,"i85":10,"i86":10,"i87":10,"i88":10,"i89":10,"i90":10,"i91":9,"i92":9,"i93":10,"i94":9,"i95":10,"i96":10,"i97":10,"i98":10,"i99":10,"i100":10,"i101":10,"i102":10,"i103":10,"i104":9,"i105":9,"i106":9,"i107":42,"i108":10,"i109":10,"i110":9,"i111
 ":42,"i112":10,"i113":10,"i114":10,"i115":10,"i116":10,"i117":10,"i118":10,"i119":10,"i120":10,"i121":9,"i122":10,"i123":10,"i124":10,"i125":9,"i126":10,"i127":10,"i128":10,"i129":10,"i130":10,"i131":10,"i132":10,"i133":10,"i134":10,"i135":10,"i136":10,"i137":9,"i138":9,"i139":10,"i140":10,"i141":10,"i142":10,"i143":10,"i144":9,"i145":9,"i146":10,"i147":9,"i148":10,"i149":10,"i150":10,"i151":10,"i152":9,"i153":9,"i154":10,"i155":10,"i156":10,"i157":10,"i158":10,"i159":10,"i160":10,"i161":10,"i162":10,"i163":10,"i164":10,"i165":10,"i166":10,"i167":10,"i168":10,"i169":10,"i170":10,"i171":10,"i172":10,"i173":10,"i174":10,"i175":10,"i176":10,"i177":10,"i178":10,"i179":10,"i180":10,"i181":10,"i182":10,"i183":10,"i184":10,"i185":10,"i186":10,"i187":10,"i188":10,"i189":10,"i190":10,"i191":10,"i192":10,"i193":10,"i194":10,"i195":10,"i196":10,"i197":10,"i198":10,"i199":9,"i200":10,"i201":10,"i202":10,"i203":10,"i204":10,"i205":10,"i206":10,"i207":10,"i208":10,"i209":10,"i210":10,"i211":10,"i
 212":10,"i213":10,"i214":10};
+var methods = {"i0":9,"i1":10,"i2":10,"i3":10,"i4":9,"i5":10,"i6":10,"i7":10,"i8":10,"i9":9,"i10":9,"i11":10,"i12":10,"i13":10,"i14":10,"i15":10,"i16":10,"i17":10,"i18":10,"i19":10,"i20":42,"i21":10,"i22":10,"i23":10,"i24":10,"i25":10,"i26":9,"i27":9,"i28":10,"i29":10,"i30":10,"i31":42,"i32":10,"i33":10,"i34":10,"i35":10,"i36":10,"i37":9,"i38":9,"i39":9,"i40":9,"i41":9,"i42":9,"i43":9,"i44":10,"i45":9,"i46":9,"i47":10,"i48":10,"i49":10,"i50":10,"i51":10,"i52":10,"i53":10,"i54":10,"i55":10,"i56":10,"i57":10,"i58":10,"i59":10,"i60":10,"i61":10,"i62":10,"i63":10,"i64":10,"i65":10,"i66":42,"i67":42,"i68":10,"i69":10,"i70":10,"i71":10,"i72":10,"i73":9,"i74":10,"i75":10,"i76":10,"i77":10,"i78":10,"i79":10,"i80":10,"i81":10,"i82":10,"i83":10,"i84":10,"i85":10,"i86":10,"i87":10,"i88":10,"i89":10,"i90":10,"i91":9,"i92":9,"i93":10,"i94":9,"i95":10,"i96":10,"i97":10,"i98":10,"i99":10,"i100":10,"i101":10,"i102":10,"i103":10,"i104":9,"i105":9,"i106":9,"i107":42,"i108":10,"i109":10,"i110":9,"i111
 ":42,"i112":10,"i113":10,"i114":10,"i115":10,"i116":10,"i117":10,"i118":10,"i119":10,"i120":10,"i121":10,"i122":9,"i123":10,"i124":10,"i125":10,"i126":9,"i127":10,"i128":10,"i129":10,"i130":10,"i131":10,"i132":10,"i133":10,"i134":10,"i135":10,"i136":10,"i137":10,"i138":9,"i139":9,"i140":10,"i141":10,"i142":10,"i143":10,"i144":10,"i145":9,"i146":9,"i147":10,"i148":9,"i149":10,"i150":10,"i151":10,"i152":10,"i153":9,"i154":9,"i155":10,"i156":10,"i157":10,"i158":10,"i159":10,"i160":10,"i161":10,"i162":10,"i163":10,"i164":10,"i165":10,"i166":10,"i167":10,"i168":10,"i169":10,"i170":10,"i171":10,"i172":10,"i173":10,"i174":10,"i175":10,"i176":10,"i177":10,"i178":10,"i179":10,"i180":10,"i181":10,"i182":10,"i183":10,"i184":10,"i185":10,"i186":10,"i187":10,"i188":10,"i189":10,"i190":10,"i191":10,"i192":10,"i193":10,"i194":10,"i195":10,"i196":10,"i197":10,"i198":10,"i199":10,"i200":9,"i201":10,"i202":10,"i203":10,"i204":10,"i205":10,"i206":10,"i207":10,"i208":10,"i209":10,"i210":10,"i211":10,"i
 212":10,"i213":10,"i214":10,"i215":10};
 var tabs = {65535:["t0","All Methods"],1:["t1","Static Methods"],2:["t2","Instance Methods"],8:["t4","Concrete Methods"],32:["t6","Deprecated Methods"]};
 var altColor = "altColor";
 var rowColor = "rowColor";
@@ -1102,6 +1102,10 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
                  byte[]&nbsp;family)</code>&nbsp;</td>
 </tr>
 <tr id="i118" class="altColor">
+<td class="colFirst"><code><a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/HRegionServer.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">HRegionServer</a></code></td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getOtherRegionServer-org.apache.hadoop.hbase.regionserver.HRegionServer-">getOtherRegionServer</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/HRegionServer.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">HRegionServer</a>&nbsp;rs)</code>&nbsp;</td>
+</tr>
+<tr id="i119" class="rowColor">
 <td class="colFirst"><code>byte[][]</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getRegionSplitStartKeys-byte:A-byte:A-int-">getRegionSplitStartKeys</a></span>(byte[]&nbsp;startKey,
                        byte[]&nbsp;endKey,
@@ -1109,70 +1113,70 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Create region split keys between startkey and endKey</div>
 </td>
 </tr>
-<tr id="i119" class="rowColor">
+<tr id="i120" class="altColor">
 <td class="colFirst"><code><a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/HRegionServer.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">HRegionServer</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getRSForFirstRegionInTable-org.apache.hadoop.hbase.TableName-">getRSForFirstRegionInTable</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;tableName)</code>
 <div class="block">Tool to get the reference to the region server object that holds the
  region of the specified user table.</div>
 </td>
 </tr>
-<tr id="i120" class="altColor">
+<tr id="i121" class="rowColor">
 <td class="colFirst"><code><a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/HRegion.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">HRegion</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getSplittableRegion-org.apache.hadoop.hbase.TableName-int-">getSplittableRegion</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;tableName,
                    int&nbsp;maxAttempts)</code>&nbsp;</td>
 </tr>
-<tr id="i121" class="rowColor">
+<tr id="i122" class="altColor">
 <td class="colFirst"><code>static <a href="../../../../../apidocs/org/apache/hadoop/hbase/io/compress.Compression.Algorithm.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.io">org.apache.hadoop.hbase.io.compress.Compression.Algorithm</a>[]</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getSupportedCompressionAlgorithms--">getSupportedCompressionAlgorithms</a></span>()</code>
 <div class="block">Get supported compression algorithms.</div>
 </td>
 </tr>
-<tr id="i122" class="altColor">
+<tr id="i123" class="rowColor">
 <td class="colFirst"><code>org.apache.hadoop.fs.FileSystem</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getTestFileSystem--">getTestFileSystem</a></span>()</code>&nbsp;</td>
 </tr>
-<tr id="i123" class="rowColor">
+<tr id="i124" class="altColor">
 <td class="colFirst"><code><a href="../../../../../apidocs/org/apache/hadoop/hbase/zookeeper/MiniZooKeeperCluster.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.zookeeper">MiniZooKeeperCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getZkCluster--">getZkCluster</a></span>()</code>&nbsp;</td>
 </tr>
-<tr id="i124" class="altColor">
+<tr id="i125" class="rowColor">
 <td class="colFirst"><code><a href="../../../../../apidocs/org/apache/hadoop/hbase/zookeeper/ZKWatcher.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.zookeeper">ZKWatcher</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getZooKeeperWatcher--">getZooKeeperWatcher</a></span>()</code>
 <div class="block">Returns a ZKWatcher instance.</div>
 </td>
 </tr>
-<tr id="i125" class="rowColor">
+<tr id="i126" class="altColor">
 <td class="colFirst"><code>static <a href="../../../../../apidocs/org/apache/hadoop/hbase/zookeeper/ZKWatcher.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.zookeeper">ZKWatcher</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getZooKeeperWatcher-org.apache.hadoop.hbase.HBaseTestingUtility-">getZooKeeperWatcher</a></span>(<a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility</a>&nbsp;TEST_UTIL)</code>
 <div class="block">Gets a ZKWatcher.</div>
 </td>
 </tr>
-<tr id="i126" class="altColor">
+<tr id="i127" class="rowColor">
 <td class="colFirst"><code>boolean</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#isReadShortCircuitOn--">isReadShortCircuitOn</a></span>()</code>
 <div class="block">Get the HBase setting for dfs.client.read.shortcircuit from the conf or a system property.</div>
 </td>
 </tr>
-<tr id="i127" class="rowColor">
+<tr id="i128" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadNumericRows-org.apache.hadoop.hbase.client.Table-byte:A-int-int-">loadNumericRows</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/Table.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">Table</a>&nbsp;t,
                byte[]&nbsp;f,
                int&nbsp;startRow,
                int&nbsp;endRow)</code>&nbsp;</td>
 </tr>
-<tr id="i128" class="altColor">
+<tr id="i129" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadRandomRows-org.apache.hadoop.hbase.client.Table-byte:A-int-int-">loadRandomRows</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/Table.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">Table</a>&nbsp;t,
               byte[]&nbsp;f,
               int&nbsp;rowSize,
               int&nbsp;totalRows)</code>&nbsp;</td>
 </tr>
-<tr id="i129" class="rowColor">
+<tr id="i130" class="altColor">
 <td class="colFirst"><code>int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadRegion-org.apache.hadoop.hbase.regionserver.HRegion-byte:A-">loadRegion</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/HRegion.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">HRegion</a>&nbsp;r,
           byte[]&nbsp;f)</code>&nbsp;</td>
 </tr>
-<tr id="i130" class="altColor">
+<tr id="i131" class="rowColor">
 <td class="colFirst"><code>int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadRegion-org.apache.hadoop.hbase.regionserver.HRegion-byte:A-boolean-">loadRegion</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/HRegion.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">HRegion</a>&nbsp;r,
           byte[]&nbsp;f,
@@ -1180,26 +1184,26 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Load region with rows from 'aaa' to 'zzz'.</div>
 </td>
 </tr>
-<tr id="i131" class="rowColor">
+<tr id="i132" class="altColor">
 <td class="colFirst"><code>int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadRegion-org.apache.hadoop.hbase.regionserver.Region-byte:A-">loadRegion</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/Region.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">Region</a>&nbsp;r,
           byte[]&nbsp;f)</code>&nbsp;</td>
 </tr>
-<tr id="i132" class="altColor">
+<tr id="i133" class="rowColor">
 <td class="colFirst"><code>int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A-">loadTable</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/Table.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">Table</a>&nbsp;t,
          byte[]&nbsp;f)</code>
 <div class="block">Load table with rows from 'aaa' to 'zzz'.</div>
 </td>
 </tr>
-<tr id="i133" class="rowColor">
+<tr id="i134" class="altColor">
 <td class="colFirst"><code>int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A:A-">loadTable</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/Table.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">Table</a>&nbsp;t,
          byte[][]&nbsp;f)</code>
 <div class="block">Load table of multiple column families with rows from 'aaa' to 'zzz'.</div>
 </td>
 </tr>
-<tr id="i134" class="altColor">
+<tr id="i135" class="rowColor">
 <td class="colFirst"><code>int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A:A-byte:A-">loadTable</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/Table.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">Table</a>&nbsp;t,
          byte[][]&nbsp;f,
@@ -1207,7 +1211,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Load table of multiple column families with rows from 'aaa' to 'zzz'.</div>
 </td>
 </tr>
-<tr id="i135" class="rowColor">
+<tr id="i136" class="altColor">
 <td class="colFirst"><code>int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A:A-byte:A-boolean-">loadTable</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/Table.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">Table</a>&nbsp;t,
          byte[][]&nbsp;f,
@@ -1216,7 +1220,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Load table of multiple column families with rows from 'aaa' to 'zzz'.</div>
 </td>
 </tr>
-<tr id="i136" class="altColor">
+<tr id="i137" class="rowColor">
 <td class="colFirst"><code>int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#loadTable-org.apache.hadoop.hbase.client.Table-byte:A-boolean-">loadTable</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/Table.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">Table</a>&nbsp;t,
          byte[]&nbsp;f,
@@ -1224,95 +1228,95 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Load table with rows from 'aaa' to 'zzz'.</div>
 </td>
 </tr>
-<tr id="i137" class="rowColor">
+<tr id="i138" class="altColor">
 <td class="colFirst"><code>static <a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true" title="class or interface in java.lang">Object</a>[]&gt;</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#memStoreTSTagsAndOffheapCombination--">memStoreTSTagsAndOffheapCombination</a></span>()</code>&nbsp;</td>
 </tr>
-<tr id="i138" class="altColor">
+<tr id="i139" class="rowColor">
 <td class="colFirst"><code>static void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#modifyTableSync-org.apache.hadoop.hbase.client.Admin-org.apache.hadoop.hbase.client.TableDescriptor-">modifyTableSync</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/Admin.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">Admin</a>&nbsp;admin,
                <a href="../../../../../apidocs/org/apache/hadoop/hbase/client/TableDescriptor.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">TableDescriptor</a>&nbsp;desc)</code>
 <div class="block">Modify a table, synchronous.</div>
 </td>
 </tr>
-<tr id="i139" class="rowColor">
+<tr id="i140" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#moveRegionAndWait-org.apache.hadoop.hbase.client.RegionInfo-org.apache.hadoop.hbase.ServerName-">moveRegionAndWait</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/RegionInfo.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">RegionInfo</a>&nbsp;destRegion,
                  <a href="../../../../../apidocs/org/apache/hadoop/hbase/ServerName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">ServerName</a>&nbsp;destServer)</code>
 <div class="block">Move region to destination server and wait till region is completely moved and online</div>
 </td>
 </tr>
-<tr id="i140" class="altColor">
+<tr id="i141" class="rowColor">
 <td class="colFirst"><code><a href="../../../../../apidocs/org/apache/hadoop/hbase/Waiter.ExplainingPredicate.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">Waiter.ExplainingPredicate</a>&lt;<a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a>&gt;</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#predicateNoRegionsInTransition--">predicateNoRegionsInTransition</a></span>()</code>
 <div class="block">Returns a <a href="../../../../../apidocs/org/apache/hadoop/hbase/Waiter.Predicate.html?is-external=true" title="class or interface in org.apache.hadoop.hbase"><code>Waiter.Predicate</code></a> for checking that there are no regions in transition in master</div>
 </td>
 </tr>
-<tr id="i141" class="rowColor">
+<tr id="i142" class="altColor">
 <td class="colFirst"><code><a href="../../../../../apidocs/org/apache/hadoop/hbase/Waiter.Predicate.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">Waiter.Predicate</a>&lt;<a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a>&gt;</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#predicateTableAvailable-org.apache.hadoop.hbase.TableName-">predicateTableAvailable</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;tableName)</code>
 <div class="block">Returns a <a href="../../../../../apidocs/org/apache/hadoop/hbase/Waiter.Predicate.html?is-external=true" title="class or interface in org.apache.hadoop.hbase"><code>Waiter.Predicate</code></a> for checking that table is enabled</div>
 </td>
 </tr>
-<tr id="i142" class="altColor">
+<tr id="i143" class="rowColor">
 <td class="colFirst"><code><a href="../../../../../apidocs/org/apache/hadoop/hbase/Waiter.Predicate.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">Waiter.Predicate</a>&lt;<a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a>&gt;</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#predicateTableDisabled-org.apache.hadoop.hbase.TableName-">predicateTableDisabled</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;tableName)</code>
 <div class="block">Returns a <a href="../../../../../apidocs/org/apache/hadoop/hbase/Waiter.Predicate.html?is-external=true" title="class or interface in org.apache.hadoop.hbase"><code>Waiter.Predicate</code></a> for checking that table is enabled</div>
 </td>
 </tr>
-<tr id="i143" class="rowColor">
+<tr id="i144" class="altColor">
 <td class="colFirst"><code><a href="../../../../../apidocs/org/apache/hadoop/hbase/Waiter.Predicate.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">Waiter.Predicate</a>&lt;<a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a>&gt;</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#predicateTableEnabled-org.apache.hadoop.hbase.TableName-">predicateTableEnabled</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;tableName)</code>
 <div class="block">Returns a <a href="../../../../../apidocs/org/apache/hadoop/hbase/Waiter.Predicate.html?is-external=true" title="class or interface in org.apache.hadoop.hbase"><code>Waiter.Predicate</code></a> for checking that table is enabled</div>
 </td>
 </tr>
-<tr id="i144" class="altColor">
+<tr id="i145" class="rowColor">
 <td class="colFirst"><code>static int</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#randomFreePort--">randomFreePort</a></span>()</code>&nbsp;</td>
 </tr>
-<tr id="i145" class="rowColor">
+<tr id="i146" class="altColor">
 <td class="colFirst"><code>static <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#randomMultiCastAddress--">randomMultiCastAddress</a></span>()</code>&nbsp;</td>
 </tr>
-<tr id="i146" class="altColor">
+<tr id="i147" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#restartHBaseCluster-int-">restartHBaseCluster</a></span>(int&nbsp;servers)</code>
 <div class="block">Starts the hbase cluster up again after shutting it down previously in a
  test.</div>
 </td>
 </tr>
-<tr id="i147" class="rowColor">
+<tr id="i148" class="altColor">
 <td class="colFirst"><code>static &lt;T&gt;&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#safeGetAsStr-java.util.List-int-">safeGetAsStr</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;T&gt;&nbsp;lst,
             int&nbsp;i)</code>&nbsp;</td>
 </tr>
-<tr id="i148" class="altColor">
+<tr id="i149" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setDFSCluster-org.apache.hadoop.hdfs.MiniDFSCluster-">setDFSCluster</a></span>(org.apache.hadoop.hdfs.MiniDFSCluster&nbsp;cluster)</code>&nbsp;</td>
 </tr>
-<tr id="i149" class="rowColor">
+<tr id="i150" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setDFSCluster-org.apache.hadoop.hdfs.MiniDFSCluster-boolean-">setDFSCluster</a></span>(org.apache.hadoop.hdfs.MiniDFSCluster&nbsp;cluster,
              boolean&nbsp;requireDown)</code>
 <div class="block">Set the MiniDFSCluster</div>
 </td>
 </tr>
-<tr id="i150" class="altColor">
+<tr id="i151" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setFileSystemURI-java.lang.String-">setFileSystemURI</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;fsURI)</code>&nbsp;</td>
 </tr>
-<tr id="i151" class="rowColor">
+<tr id="i152" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setHBaseCluster-org.apache.hadoop.hbase.HBaseCluster-">setHBaseCluster</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/HBaseCluster.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">HBaseCluster</a>&nbsp;hbaseCluster)</code>&nbsp;</td>
 </tr>
-<tr id="i152" class="altColor">
+<tr id="i153" class="rowColor">
 <td class="colFirst"><code>static void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setMaxRecoveryErrorCount-java.io.OutputStream-int-">setMaxRecoveryErrorCount</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/io/OutputStream.html?is-external=true" title="class or interface in java.io">OutputStream</a>&nbsp;stream,
                         int&nbsp;max)</code>
 <div class="block">Set maxRecoveryErrorCount in DFSClient.</div>
 </td>
 </tr>
-<tr id="i153" class="rowColor">
+<tr id="i154" class="altColor">
 <td class="colFirst"><code>static void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setReplicas-org.apache.hadoop.hbase.client.Admin-org.apache.hadoop.hbase.TableName-int-">setReplicas</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/Admin.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">Admin</a>&nbsp;admin,
            <a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;table,
@@ -1320,93 +1324,93 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Set the number of Region replicas.</div>
 </td>
 </tr>
-<tr id="i154" class="altColor">
+<tr id="i155" class="rowColor">
 <td class="colFirst"><code>protected org.apache.hadoop.fs.Path</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setupDataTestDir--">setupDataTestDir</a></span>()</code>
 <div class="block">Home our data in a dir under <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.html#DEFAULT_BASE_TEST_DIRECTORY"><code>HBaseCommonTestingUtility.DEFAULT_BASE_TEST_DIRECTORY</code></a>.</div>
 </td>
 </tr>
-<tr id="i155" class="rowColor">
+<tr id="i156" class="altColor">
 <td class="colFirst"><code>org.apache.hadoop.minikdc.MiniKdc</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setupMiniKdc-java.io.File-">setupMiniKdc</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/io/File.html?is-external=true" title="class or interface in java.io">File</a>&nbsp;keytabFile)</code>
 <div class="block">Sets up <code>MiniKdc</code> for testing security.</div>
 </td>
 </tr>
-<tr id="i156" class="altColor">
+<tr id="i157" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#setZkCluster-org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster-">setZkCluster</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/zookeeper/MiniZooKeeperCluster.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.zookeeper">MiniZooKeeperCluster</a>&nbsp;zkCluster)</code>&nbsp;</td>
 </tr>
-<tr id="i157" class="rowColor">
+<tr id="i158" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniCluster--">shutdownMiniCluster</a></span>()</code>
 <div class="block">Stops mini hbase, zk, and hdfs clusters.</div>
 </td>
 </tr>
-<tr id="i158" class="altColor">
+<tr id="i159" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniDFSCluster--">shutdownMiniDFSCluster</a></span>()</code>
 <div class="block">Shuts down instance created by call to <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-int-"><code>startMiniDFSCluster(int)</code></a>
  or does nothing.</div>
 </td>
 </tr>
-<tr id="i159" class="rowColor">
+<tr id="i160" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniHBaseCluster--">shutdownMiniHBaseCluster</a></span>()</code>
 <div class="block">Shutdown HBase mini cluster.</div>
 </td>
 </tr>
-<tr id="i160" class="altColor">
+<tr id="i161" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniMapReduceCluster--">shutdownMiniMapReduceCluster</a></span>()</code>
 <div class="block">Stops the previously started <code>MiniMRCluster</code>.</div>
 </td>
 </tr>
-<tr id="i161" class="rowColor">
+<tr id="i162" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#shutdownMiniZKCluster--">shutdownMiniZKCluster</a></span>()</code>
 <div class="block">Shuts down zk cluster created by call to <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniZKCluster-java.io.File-"><code>startMiniZKCluster(File)</code></a>
  or does nothing.</div>
 </td>
 </tr>
-<tr id="i162" class="altColor">
+<tr id="i163" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster--">startMiniCluster</a></span>()</code>
 <div class="block">Start up a minicluster of hbase, dfs, and zookeeper.</div>
 </td>
 </tr>
-<tr id="i163" class="rowColor">
+<tr id="i164" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-boolean-">startMiniCluster</a></span>(boolean&nbsp;withWALDir)</code>
 <div class="block">Start up a minicluster of hbase, dfs, and zookeeper where WAL's walDir is created separately.</div>
 </td>
 </tr>
-<tr id="i164" class="altColor">
+<tr id="i165" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-">startMiniCluster</a></span>(int&nbsp;numSlaves)</code>
 <div class="block">Start up a minicluster of hbase, optionally dfs, and zookeeper.</div>
 </td>
 </tr>
-<tr id="i165" class="rowColor">
+<tr id="i166" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-boolean-">startMiniCluster</a></span>(int&nbsp;numSlaves,
                 boolean&nbsp;create)</code>
 <div class="block">Start up a minicluster of hbase, dfs, and zookeeper.</div>
 </td>
 </tr>
-<tr id="i166" class="altColor">
+<tr id="i167" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-boolean-boolean-">startMiniCluster</a></span>(int&nbsp;numSlaves,
                 boolean&nbsp;create,
                 boolean&nbsp;withWALDir)</code>&nbsp;</td>
 </tr>
-<tr id="i167" class="rowColor">
+<tr id="i168" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-">startMiniCluster</a></span>(int&nbsp;numMasters,
                 int&nbsp;numSlaves)</code>
 <div class="block">start minicluster</div>
 </td>
 </tr>
-<tr id="i168" class="altColor">
+<tr id="i169" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-boolean-">startMiniCluster</a></span>(int&nbsp;numMasters,
                 int&nbsp;numSlaves,
@@ -1414,7 +1418,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Start minicluster.</div>
 </td>
 </tr>
-<tr id="i169" class="rowColor">
+<tr id="i170" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-int-">startMiniCluster</a></span>(int&nbsp;numMasters,
                 int&nbsp;numSlaves,
@@ -1422,7 +1426,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Same as <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-"><code>startMiniCluster(int, int)</code></a>, but with custom number of datanodes.</div>
 </td>
 </tr>
-<tr id="i170" class="altColor">
+<tr id="i171" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-int-java.lang.String:A-java.lang.Class-java.lang.Class-">startMiniCluster</a></span>(int&nbsp;numMasters,
                 int&nbsp;numSlaves,
@@ -1431,7 +1435,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
                 <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Class.html?is-external=true" title="class or interface in java.lang">Class</a>&lt;? extends <a href="../../../../../apidocs/org/apache/hadoop/hbase/master/HMaster.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.master">HMaster</a>&gt;&nbsp;masterClass,
                 <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Class.html?is-external=true" title="class or interface in java.lang">Class</a>&lt;? extends <a href="../../../../../apidocs/org/apache/hadoop/hbase/MiniHBaseCluster.MiniHBaseClusterRegionServer.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">MiniHBaseCluster.MiniHBaseClusterRegionServer</a>&gt;&nbsp;regionserverClass)</code>&nbsp;</td>
 </tr>
-<tr id="i171" class="rowColor">
+<tr id="i172" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-int-java.lang.String:A-java.lang.Class-java.lang.Class-boolean-boolean-">startMiniCluster</a></span>(int&nbsp;numMasters,
                 int&nbsp;numSlaves,
@@ -1445,7 +1449,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
  number of datanodes.</div>
 </td>
 </tr>
-<tr id="i172" class="altColor">
+<tr id="i173" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-java.lang.String:A-">startMiniCluster</a></span>(int&nbsp;numMasters,
                 int&nbsp;numSlaves,
@@ -1453,14 +1457,14 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Start up a minicluster of hbase, optionally dfs, and zookeeper.</div>
 </td>
 </tr>
-<tr id="i173" class="rowColor">
+<tr id="i174" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-java.lang.String:A-boolean-">startMiniCluster</a></span>(int&nbsp;numMasters,
                 int&nbsp;numSlaves,
                 <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>[]&nbsp;dataNodeHosts,
                 boolean&nbsp;create)</code>&nbsp;</td>
 </tr>
-<tr id="i174" class="altColor">
+<tr id="i175" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniCluster-int-int-java.lang.String:A-java.lang.Class-java.lang.Class-">startMiniCluster</a></span>(int&nbsp;numMasters,
                 int&nbsp;numSlaves,
@@ -1470,41 +1474,41 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Start up a minicluster of hbase, optionally dfs, and zookeeper.</div>
 </td>
 </tr>
-<tr id="i175" class="rowColor">
+<tr id="i176" class="altColor">
 <td class="colFirst"><code>org.apache.hadoop.hdfs.MiniDFSCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-int-">startMiniDFSCluster</a></span>(int&nbsp;servers)</code>
 <div class="block">Start a minidfscluster.</div>
 </td>
 </tr>
-<tr id="i176" class="altColor">
+<tr id="i177" class="rowColor">
 <td class="colFirst"><code>org.apache.hadoop.hdfs.MiniDFSCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-int-java.lang.String:A-">startMiniDFSCluster</a></span>(int&nbsp;servers,
                    <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>[]&nbsp;hosts)</code>
 <div class="block">Start a minidfscluster.</div>
 </td>
 </tr>
-<tr id="i177" class="rowColor">
+<tr id="i178" class="altColor">
 <td class="colFirst"><code>org.apache.hadoop.hdfs.MiniDFSCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-int-java.lang.String:A-java.lang.String:A-">startMiniDFSCluster</a></span>(int&nbsp;servers,
                    <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>[]&nbsp;racks,
                    <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>[]&nbsp;hosts)</code>&nbsp;</td>
 </tr>
-<tr id="i178" class="altColor">
+<tr id="i179" class="rowColor">
 <td class="colFirst"><code>org.apache.hadoop.hdfs.MiniDFSCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSCluster-java.lang.String:A-">startMiniDFSCluster</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>[]&nbsp;hosts)</code>
 <div class="block">Start a minidfscluster.</div>
 </td>
 </tr>
-<tr id="i179" class="rowColor">
+<tr id="i180" class="altColor">
 <td class="colFirst"><code>org.apache.hadoop.hdfs.MiniDFSCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniDFSClusterForTestWAL-int-">startMiniDFSClusterForTestWAL</a></span>(int&nbsp;namenodePort)</code>&nbsp;</td>
 </tr>
-<tr id="i180" class="altColor">
+<tr id="i181" class="rowColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniHBaseCluster-int-int-">startMiniHBaseCluster</a></span>(int&nbsp;numMasters,
                      int&nbsp;numSlaves)</code>&nbsp;</td>
 </tr>
-<tr id="i181" class="rowColor">
+<tr id="i182" class="altColor">
 <td class="colFirst"><code><a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniHBaseCluster-int-int-java.lang.Class-java.lang.Class-boolean-boolean-">startMiniHBaseCluster</a></span>(int&nbsp;numMasters,
                      int&nbsp;numSlaves,
@@ -1515,73 +1519,73 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Starts up mini hbase cluster.</div>
 </td>
 </tr>
-<tr id="i182" class="altColor">
+<tr id="i183" class="rowColor">
 <td class="colFirst"><code>org.apache.hadoop.mapred.MiniMRCluster</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniMapReduceCluster--">startMiniMapReduceCluster</a></span>()</code>
 <div class="block">Starts a <code>MiniMRCluster</code> with a default number of
  <code>TaskTracker</code>'s.</div>
 </td>
 </tr>
-<tr id="i183" class="rowColor">
+<tr id="i184" class="altColor">
 <td class="colFirst"><code><a href="../../../../../apidocs/org/apache/hadoop/hbase/zookeeper/MiniZooKeeperCluster.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.zookeeper">MiniZooKeeperCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniZKCluster--">startMiniZKCluster</a></span>()</code>
 <div class="block">Call this if you only want a zk cluster.</div>
 </td>
 </tr>
-<tr id="i184" class="altColor">
+<tr id="i185" class="rowColor">
 <td class="colFirst"><code><a href="../../../../../apidocs/org/apache/hadoop/hbase/zookeeper/MiniZooKeeperCluster.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.zookeeper">MiniZooKeeperCluster</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#startMiniZKCluster-int-int...-">startMiniZKCluster</a></span>(int&nbsp;zooKeeperServerNum,
                   int...&nbsp;clientPortList)</code>
 <div class="block">Call this if you only want a zk cluster.</div>
 </td>
 </tr>
-<tr id="i185" class="rowColor">
+<tr id="i186" class="altColor">
 <td class="colFirst"><code><a href="../../../../../apidocs/org/apache/hadoop/hbase/client/Table.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">Table</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#truncateTable-org.apache.hadoop.hbase.TableName-">truncateTable</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;tableName)</code>
 <div class="block">Truncate a table using the admin command.</div>
 </td>
 </tr>
-<tr id="i186" class="altColor">
+<tr id="i187" class="rowColor">
 <td class="colFirst"><code><a href="../../../../../apidocs/org/apache/hadoop/hbase/client/Table.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">Table</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#truncateTable-org.apache.hadoop.hbase.TableName-boolean-">truncateTable</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;tableName,
              boolean&nbsp;preserveRegions)</code>
 <div class="block">Truncate a table using the admin command.</div>
 </td>
 </tr>
-<tr id="i187" class="rowColor">
+<tr id="i188" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#unassignRegion-byte:A-">unassignRegion</a></span>(byte[]&nbsp;regionName)</code>
 <div class="block">Unassign the named region.</div>
 </td>
 </tr>
-<tr id="i188" class="altColor">
+<tr id="i189" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#unassignRegion-java.lang.String-">unassignRegion</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;regionName)</code>
 <div class="block">Unassign the named region.</div>
 </td>
 </tr>
-<tr id="i189" class="rowColor">
+<tr id="i190" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#unassignRegionByRow-byte:A-org.apache.hadoop.hbase.client.RegionLocator-">unassignRegionByRow</a></span>(byte[]&nbsp;row,
                    <a href="../../../../../apidocs/org/apache/hadoop/hbase/client/RegionLocator.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">RegionLocator</a>&nbsp;table)</code>
 <div class="block">Closes the region containing the given row.</div>
 </td>
 </tr>
-<tr id="i190" class="altColor">
+<tr id="i191" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#unassignRegionByRow-java.lang.String-org.apache.hadoop.hbase.client.RegionLocator-">unassignRegionByRow</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;row,
                    <a href="../../../../../apidocs/org/apache/hadoop/hbase/client/RegionLocator.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">RegionLocator</a>&nbsp;table)</code>
 <div class="block">Closes the region containing the given row.</div>
 </td>
 </tr>
-<tr id="i191" class="rowColor">
+<tr id="i192" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.regionserver.HRegion-byte:A-int-int-">verifyNumericRows</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/HRegion.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">HRegion</a>&nbsp;region,
                  byte[]&nbsp;f,
                  int&nbsp;startRow,
                  int&nbsp;endRow)</code>&nbsp;</td>
 </tr>
-<tr id="i192" class="altColor">
+<tr id="i193" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.regionserver.HRegion-byte:A-int-int-boolean-">verifyNumericRows</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/HRegion.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">HRegion</a>&nbsp;region,
                  byte[]&nbsp;f,
@@ -1589,14 +1593,14 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
                  int&nbsp;endRow,
                  boolean&nbsp;present)</code>&nbsp;</td>
 </tr>
-<tr id="i193" class="rowColor">
+<tr id="i194" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.regionserver.Region-byte:A-int-int-">verifyNumericRows</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/Region.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">Region</a>&nbsp;region,
                  byte[]&nbsp;f,
                  int&nbsp;startRow,
                  int&nbsp;endRow)</code>&nbsp;</td>
 </tr>
-<tr id="i194" class="altColor">
+<tr id="i195" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.regionserver.Region-byte:A-int-int-boolean-">verifyNumericRows</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/Region.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">Region</a>&nbsp;region,
                  byte[]&nbsp;f,
@@ -1604,7 +1608,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
                  int&nbsp;endRow,
                  boolean&nbsp;present)</code>&nbsp;</td>
 </tr>
-<tr id="i195" class="rowColor">
+<tr id="i196" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#verifyNumericRows-org.apache.hadoop.hbase.client.Table-byte:A-int-int-int-">verifyNumericRows</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/Table.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">Table</a>&nbsp;table,
                  byte[]&nbsp;f,
@@ -1612,7 +1616,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
                  int&nbsp;endRow,
                  int&nbsp;replicaId)</code>&nbsp;</td>
 </tr>
-<tr id="i196" class="altColor">
+<tr id="i197" class="rowColor">
 <td class="colFirst"><code>&lt;E extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a>&gt;<br>long</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitFor-long-long-boolean-org.apache.hadoop.hbase.Waiter.Predicate-">waitFor</a></span>(long&nbsp;timeout,
        long&nbsp;interval,
@@ -1621,7 +1625,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Wrapper method for <a href="../../../../../apidocs/org/apache/hadoop/hbase/Waiter.html?is-external=true#waitFor-org.apache.hadoop.conf.Configuration-long-long-boolean-org.apache.hadoop.hbase.Waiter.Predicate-" title="class or interface in org.apache.hadoop.hbase"><code>Waiter.waitFor(Configuration, long, long, boolean, Predicate)</code></a>.</div>
 </td>
 </tr>
-<tr id="i197" class="rowColor">
+<tr id="i198" class="altColor">
 <td class="colFirst"><code>&lt;E extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a>&gt;<br>long</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitFor-long-long-org.apache.hadoop.hbase.Waiter.Predicate-">waitFor</a></span>(long&nbsp;timeout,
        long&nbsp;interval,
@@ -1629,80 +1633,80 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
 <div class="block">Wrapper method for <a href="../../../../../apidocs/org/apache/hadoop/hbase/Waiter.html?is-external=true#waitFor-org.apache.hadoop.conf.Configuration-long-long-org.apache.hadoop.hbase.Waiter.Predicate-" title="class or interface in org.apache.hadoop.hbase"><code>Waiter.waitFor(Configuration, long, long, Predicate)</code></a>.</div>
 </td>
 </tr>
-<tr id="i198" class="altColor">
+<tr id="i199" class="rowColor">
 <td class="colFirst"><code>&lt;E extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a>&gt;<br>long</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitFor-long-org.apache.hadoop.hbase.Waiter.Predicate-">waitFor</a></span>(long&nbsp;timeout,
        <a href="../../../../../apidocs/org/apache/hadoop/hbase/Waiter.Predicate.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">Waiter.Predicate</a>&lt;E&gt;&nbsp;predicate)</code>
 <div class="block">Wrapper method for <a href="../../../../../apidocs/org/apache/hadoop/hbase/Waiter.html?is-external=true#waitFor-org.apache.hadoop.conf.Configuration-long-org.apache.hadoop.hbase.Waiter.Predicate-" title="class or interface in org.apache.hadoop.hbase"><code>Waiter.waitFor(Configuration, long, Predicate)</code></a>.</div>
 </td>
 </tr>
-<tr id="i199" class="rowColor">
+<tr id="i200" class="altColor">
 <td class="colFirst"><code>static void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitForHostPort-java.lang.String-int-">waitForHostPort</a></span>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;host,
                int&nbsp;port)</code>&nbsp;</td>
 </tr>
-<tr id="i200" class="altColor">
+<tr id="i201" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitLabelAvailable-long-java.lang.String...-">waitLabelAvailable</a></span>(long&nbsp;timeoutMillis,
                   <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>...&nbsp;labels)</code>
 <div class="block">Wait until labels is ready in VisibilityLabelsCache.</div>
 </td>
 </tr>
-<tr id="i201" class="rowColor">
+<tr id="i202" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableAvailable-byte:A-long-">waitTableAvailable</a></span>(byte[]&nbsp;table,
                   long&nbsp;timeoutMillis)</code>
 <div class="block">Wait until all regions in a table have been assigned</div>
 </td>
 </tr>
-<tr id="i202" class="altColor">
+<tr id="i203" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableAvailable-org.apache.hadoop.hbase.TableName-">waitTableAvailable</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;table)</code>
 <div class="block">Wait until all regions in a table have been assigned.</div>
 </td>
 </tr>
-<tr id="i203" class="rowColor">
+<tr id="i204" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableAvailable-org.apache.hadoop.hbase.TableName-long-">waitTableAvailable</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;table,
                   long&nbsp;timeoutMillis)</code>&nbsp;</td>
 </tr>
-<tr id="i204" class="altColor">
+<tr id="i205" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableDisabled-byte:A-">waitTableDisabled</a></span>(byte[]&nbsp;table)</code>
 <div class="block">Waits for a table to be 'disabled'.</div>
 </td>
 </tr>
-<tr id="i205" class="rowColor">
+<tr id="i206" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableDisabled-byte:A-long-">waitTableDisabled</a></span>(byte[]&nbsp;table,
                  long&nbsp;timeoutMillis)</code>
 <div class="block">Waits for a table to be 'disabled'.</div>
 </td>
 </tr>
-<tr id="i206" class="altColor">
+<tr id="i207" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableDisabled-org.apache.hadoop.hbase.TableName-long-">waitTableDisabled</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;table,
                  long&nbsp;millisTimeout)</code>&nbsp;</td>
 </tr>
-<tr id="i207" class="rowColor">
+<tr id="i208" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableEnabled-byte:A-long-">waitTableEnabled</a></span>(byte[]&nbsp;table,
                 long&nbsp;timeoutMillis)</code>
 <div class="block">Waits for a table to be 'enabled'.</div>
 </td>
 </tr>
-<tr id="i208" class="altColor">
+<tr id="i209" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableEnabled-org.apache.hadoop.hbase.TableName-">waitTableEnabled</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;table)</code>
 <div class="block">Waits for a table to be 'enabled'.</div>
 </td>
 </tr>
-<tr id="i209" class="rowColor">
+<tr id="i210" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitTableEnabled-org.apache.hadoop.hbase.TableName-long-">waitTableEnabled</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;table,
                 long&nbsp;timeoutMillis)</code>&nbsp;</td>
 </tr>
-<tr id="i210" class="altColor">
+<tr id="i211" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilAllRegionsAssigned-org.apache.hadoop.hbase.TableName-">waitUntilAllRegionsAssigned</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;tableName)</code>
 <div class="block">Wait until all regions for a table in hbase:meta have a non-empty
@@ -1712,7 +1716,7 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
  server.</div>
 </td>
 </tr>
-<tr id="i211" class="rowColor">
+<tr id="i212" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilAllRegionsAssigned-org.apache.hadoop.hbase.TableName-long-">waitUntilAllRegionsAssigned</a></span>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;tableName,
                            long&nbsp;timeout)</code>
@@ -1720,19 +1724,19 @@ extends <a href="../../../../org/apache/hadoop/hbase/HBaseCommonTestingUtility.h
  info:server, or until timeout.</div>
 </td>
 </tr>
-<tr id="i212" class="altColor">
+<tr id="i213" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilAllSystemRegionsAssigned--">waitUntilAllSystemRegionsAssigned</a></span>()</code>
 <div class="block">Waith until all system table's regions get assigned</div>
 </td>
 </tr>
-<tr id="i213" class="rowColor">
+<tr id="i214" class="altColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilNoRegionsInTransition--">waitUntilNoRegionsInTransition</a></span>()</code>
 <div class="block">Wait until no regions in transition.</div>
 </td>
 </tr>
-<tr id="i214" class="altColor">
+<tr id="i215" class="rowColor">
 <td class="colFirst"><code>void</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#waitUntilNoRegionsInTransition-long-">waitUntilNoRegionsInTransition</a></span>(long&nbsp;timeout)</code>
 <div class="block">Wait until no regions in transition.</div>
@@ -4429,13 +4433,22 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 </dl>
 </li>
 </ul>
+<a name="getOtherRegionServer-org.apache.hadoop.hbase.regionserver.HRegionServer-">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>getOtherRegionServer</h4>
+<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/HRegionServer.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">HRegionServer</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2518">getOtherRegionServer</a>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/HRegionServer.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">HRegionServer</a>&nbsp;rs)</pre>
+</li>
+</ul>
 <a name="getRSForFirstRegionInTable-org.apache.hadoop.hbase.TableName-">
 <!--   -->
 </a>
 <ul class="blockList">
 <li class="blockList">
 <h4>getRSForFirstRegionInTable</h4>
-<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/HRegionServer.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">HRegionServer</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2524">getRSForFirstRegionInTable</a>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;tableName)
+<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/HRegionServer.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">HRegionServer</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2539">getRSForFirstRegionInTable</a>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/TableName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">TableName</a>&nbsp;tableName)
                                          throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a>,
                                                 <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/InterruptedException.html?is-external=true" title="class or interface in java.lang">InterruptedException</a></pre>
 <div class="block">Tool to get the reference to the region server object that holds the
@@ -4460,7 +4473,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>startMiniMapReduceCluster</h4>
-<pre>public&nbsp;org.apache.hadoop.mapred.MiniMRCluster&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2556">startMiniMapReduceCluster</a>()
+<pre>public&nbsp;org.apache.hadoop.mapred.MiniMRCluster&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2571">startMiniMapReduceCluster</a>()
                                                                  throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Starts a <code>MiniMRCluster</code> with a default number of
  <code>TaskTracker</code>'s.</div>
@@ -4476,7 +4489,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>shutdownMiniMapReduceCluster</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2667">shutdownMiniMapReduceCluster</a>()</pre>
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2682">shutdownMiniMapReduceCluster</a>()</pre>
 <div class="block">Stops the previously started <code>MiniMRCluster</code>.</div>
 </li>
 </ul>
@@ -4486,7 +4499,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>createMockRegionServerService</h4>
-<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/RegionServerServices.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">RegionServerServices</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2681">createMockRegionServerService</a>()
+<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/RegionServerServices.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">RegionServerServices</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2696">createMockRegionServerService</a>()
                                                    throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Create a stubbed out RegionServerService, mainly for getting FS.</div>
 <dl>
@@ -4501,7 +4514,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>createMockRegionServerService</h4>
-<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/RegionServerServices.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">RegionServerServices</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2689">createMockRegionServerService</a>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/ipc/RpcServerInterface.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.ipc">RpcServerInterface</a>&nbsp;rpc)
+<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/RegionServerServices.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">RegionServerServices</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2704">createMockRegionServerService</a>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/ipc/RpcServerInterface.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.ipc">RpcServerInterface</a>&nbsp;rpc)
                                                    throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Create a stubbed out RegionServerService, mainly for getting FS.
  This version is used by TestTokenAuthentication</div>
@@ -4517,7 +4530,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>createMockRegionServerService</h4>
-<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/RegionServerServices.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">RegionServerServices</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2701">createMockRegionServerService</a>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/ServerName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">ServerName</a>&nbsp;name)
+<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/regionserver/RegionServerServices.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.regionserver">RegionServerServices</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2716">createMockRegionServerService</a>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/ServerName.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">ServerName</a>&nbsp;name)
                                                    throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Create a stubbed out RegionServerService, mainly for getting FS.
  This version is used by TestOpenRegionHandler</div>
@@ -4533,7 +4546,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>enableDebug</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2712">enableDebug</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Class.html?is-external=true" title="class or interface in java.lang">Class</a>&lt;?&gt;&nbsp;clazz)</pre>
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2727">enableDebug</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Class.html?is-external=true" title="class or interface in java.lang">Class</a>&lt;?&gt;&nbsp;clazz)</pre>
 <div class="block">Switches the logger for the given class to DEBUG level.</div>
 <dl>
 <dt><span class="paramLabel">Parameters:</span></dt>
@@ -4547,7 +4560,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>expireMasterSession</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2725">expireMasterSession</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2740">expireMasterSession</a>()
                          throws <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
 <div class="block">Expire the Master's session</div>
 <dl>
@@ -4562,7 +4575,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>expireRegionServerSession</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2735">expireRegionServerSession</a>(int&nbsp;index)
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2750">expireRegionServerSession</a>(int&nbsp;index)
                                throws <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
 <div class="block">Expire a region server's session</div>
 <dl>
@@ -4579,7 +4592,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>expireSession</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2761">expireSession</a>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/zookeeper/ZKWatcher.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.zookeeper">ZKWatcher</a>&nbsp;nodeZK)
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2776">expireSession</a>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/zookeeper/ZKWatcher.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.zookeeper">ZKWatcher</a>&nbsp;nodeZK)
                    throws <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
 <dl>
 <dt><span class="throwsLabel">Throws:</span></dt>
@@ -4593,7 +4606,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>expireSession</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2776">expireSession</a>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/zookeeper/ZKWatcher.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.zookeeper">ZKWatcher</a>&nbsp;nodeZK,
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2791">expireSession</a>(<a href="../../../../../apidocs/org/apache/hadoop/hbase/zookeeper/ZKWatcher.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.zookeeper">ZKWatcher</a>&nbsp;nodeZK,
                           boolean&nbsp;checkStatus)
                    throws <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
 <div class="block">Expire a ZooKeeper session as recommended in ZooKeeper documentation
@@ -4617,7 +4630,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>getHBaseCluster</h4>
-<pre>public&nbsp;<a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2827">getHBaseCluster</a>()</pre>
+<pre>public&nbsp;<a href="../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2842">getHBaseCluster</a>()</pre>
 <div class="block">Get the Mini HBase cluster.</div>
 <dl>
 <dt><span class="returnLabel">Returns:</span></dt>
@@ -4633,7 +4646,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>getHBaseClusterInterface</h4>
-<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/HBaseCluster.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">HBaseCluster</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2839">getHBaseClusterInterface</a>()</pre>
+<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/HBaseCluster.html?is-external=true" title="class or interface in org.apache.hadoop.hbase">HBaseCluster</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2854">getHBaseClusterInterface</a>()</pre>
 <div class="block">Returns the HBaseCluster instance.
  <p>Returned object can be any of the subclasses of HBaseCluster, and the
  tests referring this should not assume that the cluster is a mini cluster or a
@@ -4648,7 +4661,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <ul class="blockList">
 <li class="blockList">
 <h4>getConnection</h4>
-<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/Connection.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">Connection</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2851">getConnection</a>()
+<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/Connection.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">Connection</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2866">getConnection</a>()
                          throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Get a Connection to the cluster.
  Not thread-safe (This class needs a lot of work to make it thread-safe).</div>
@@ -4667,7 +4680,7 @@ public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.htm
 <li class="blockList">
 <h4>getHBaseAdmin</h4>
 <pre><a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Deprecated.html?is-external=true" title="class or interface in java.lang">@Deprecated</a>
-public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/HBaseAdmin.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">HBaseAdmin</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2869">getHBaseAdmin</a>()
+public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/HBaseAdmin.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">HBaseAdmin</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2884">getHBaseAdmin</a>()
                                      throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block"><span class="deprecatedLabel">Deprecated.</span>&nbsp;<span class="deprecationComment">Since 2.0. Will be removed in 3.0. Use <a href="../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html#getAdmin--"><code>getAdmin()</code></a> instead.</span></div>
 <div class="block">Returns a Admin instance.
@@ -4689,7 +4702,7 @@ public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/HBase
 <ul class="blockList">
 <li class="blockList">
 <h4>getAdmin</h4>
-<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/Admin.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">Admin</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2881">getAdmin</a>()
+<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/Admin.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.client">Admin</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2896">getAdmin</a>()
                throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Returns an Admin instance which is shared between HBaseTestingUtility instance users.
  Closing it has no effect, it will be closed automatically when the cluster shutdowns</div>
@@ -4705,7 +4718,7 @@ public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/HBase
 <ul class="blockList">
 <li class="blockList">
 <h4>getZooKeeperWatcher</h4>
-<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/zookeeper/ZKWatcher.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.zookeeper">ZKWatcher</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2899">getZooKeeperWatcher</a>()
+<pre>public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/zookeeper/ZKWatcher.html?is-external=true" title="class or interface in org.apache.hadoop.hbase.zookeeper">ZKWatcher</a>&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2914">getZooKeeperWatcher</a>()
                               throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Returns a ZKWatcher instance.
  This instance is shared between HBaseTestingUtility instance users.
@@ -4725,7 +4738,7 @@ public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/HBase
 <ul class="blockList">
 <li class="blockList">
 <h4>unassignRegion</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2921">unassignRegion</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;regionName)
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2936">unassignRegion</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;regionName)
                     throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Unassign the named region.</div>
 <dl>
@@ -4742,7 +4755,7 @@ public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/HBase
 <ul class="blockList">
 <li class="blockList">
 <h4>unassignRegion</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2930">unassignRegion</a>(byte[]&nbsp;regionName)
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2945">unassignRegion</a>(byte[]&nbsp;regionName)
                     throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <div class="block">Unassign the named region.</div>
 <dl>
@@ -4759,7 +4772,7 @@ public&nbsp;<a href="../../../../../apidocs/org/apache/hadoop/hbase/client/HBase
 <ul class="blockList">
 <li class="blockList">
 <h4>unassignRegionByRow</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2940">unassignRegionByRow</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;row,
+<pre>public&nbsp;void&nbsp;<a href="../../../../src-html/org/apache/hadoop/hbase/HBaseTestingUtility.html#line.2955">unassignRegionByRow</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>&nbsp;row,

<TRUNCATED>

[06/14] hbase-site git commit: Published site at .

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html b/testdevapidocs/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html
index 6757859..1f078fc 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html
@@ -109,7 +109,7 @@ var activeTableTab = "activeTableTab";
 <li class="blockList">
 <hr>
 <br>
-<pre>public class <a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.61">TestCompactionInDeadRegionServer</a>
+<pre>public class <a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.63">TestCompactionInDeadRegionServer</a>
 extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true" title="class or interface in java.lang">Object</a></pre>
 <div class="block">This testcase is used to ensure that the compaction marker will fail a compaction if the RS is
  already dead. It can not eliminate FNFE when scanning but it does reduce the possibility a lot.</div>
@@ -159,14 +159,18 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#CQ">CQ</a></span></code>&nbsp;</td>
 </tr>
 <tr class="altColor">
+<td class="colFirst"><code>private static org.apache.commons.logging.Log</code></td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#LOG">LOG</a></span></code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
 <td class="colFirst"><code>private static org.apache.hadoop.hbase.TableName</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#TABLE_NAME">TABLE_NAME</a></span></code>&nbsp;</td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code>private static <a href="../../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility</a></code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#UTIL">UTIL</a></span></code>&nbsp;</td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code><a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Class.html?is-external=true" title="class or interface in java.lang">Class</a>&lt;? extends org.apache.hadoop.hbase.wal.WALProvider&gt;</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#walProvider">walProvider</a></span></code>&nbsp;</td>
 </tr>
@@ -240,13 +244,22 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <!--   -->
 </a>
 <h3>Field Detail</h3>
+<a name="LOG">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>LOG</h4>
+<pre>private static final&nbsp;org.apache.commons.logging.Log <a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.64">LOG</a></pre>
+</li>
+</ul>
 <a name="UTIL">
 <!--   -->
 </a>
 <ul class="blockList">
 <li class="blockList">
 <h4>UTIL</h4>
-<pre>private static final&nbsp;<a href="../../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility</a> <a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.63">UTIL</a></pre>
+<pre>private static final&nbsp;<a href="../../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility</a> <a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.66">UTIL</a></pre>
 </li>
 </ul>
 <a name="TABLE_NAME">
@@ -255,7 +268,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>TABLE_NAME</h4>
-<pre>private static final&nbsp;org.apache.hadoop.hbase.TableName <a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.65">TABLE_NAME</a></pre>
+<pre>private static final&nbsp;org.apache.hadoop.hbase.TableName <a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.68">TABLE_NAME</a></pre>
 </li>
 </ul>
 <a name="CF">
@@ -264,7 +277,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>CF</h4>
-<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.67">CF</a></pre>
+<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.70">CF</a></pre>
 </li>
 </ul>
 <a name="CQ">
@@ -273,7 +286,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>CQ</h4>
-<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.69">CQ</a></pre>
+<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.72">CQ</a></pre>
 </li>
 </ul>
 <a name="walProvider">
@@ -282,7 +295,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>walProvider</h4>
-<pre>public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Class.html?is-external=true" title="class or interface in java.lang">Class</a>&lt;? extends org.apache.hadoop.hbase.wal.WALProvider&gt; <a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.89">walProvider</a></pre>
+<pre>public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Class.html?is-external=true" title="class or interface in java.lang">Class</a>&lt;? extends org.apache.hadoop.hbase.wal.WALProvider&gt; <a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.92">walProvider</a></pre>
 </li>
 </ul>
 </li>
@@ -299,7 +312,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>TestCompactionInDeadRegionServer</h4>
-<pre>public&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.61">TestCompactionInDeadRegionServer</a>()</pre>
+<pre>public&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.63">TestCompactionInDeadRegionServer</a>()</pre>
 </li>
 </ul>
 </li>
@@ -316,7 +329,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>params</h4>
-<pre>public static&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true" title="class or interface in java.lang">Object</a>[]&gt;&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.92">params</a>()</pre>
+<pre>public static&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true" title="class or interface in java.lang">Object</a>[]&gt;&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.95">params</a>()</pre>
 </li>
 </ul>
 <a name="setUp--">
@@ -325,7 +338,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>setUp</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.98">setUp</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.101">setUp</a>()
            throws <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
 <dl>
 <dt><span class="throwsLabel">Throws:</span></dt>
@@ -339,7 +352,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>tearDown</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.116">tearDown</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.119">tearDown</a>()
               throws <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
 <dl>
 <dt><span class="throwsLabel">Throws:</span></dt>
@@ -353,7 +366,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>test</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.121">test</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/regionserver/TestCompactionInDeadRegionServer.html#line.124">test</a>()
           throws <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
 <dl>
 <dt><span class="throwsLabel">Throws:</span></dt>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html b/testdevapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html
index 187e77f..87861d2 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html
@@ -627,11 +627,11 @@
 <ul>
 <li type="circle">java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Enum.html?is-external=true" title="class or interface in java.lang"><span class="typeNameLink">Enum</span></a>&lt;E&gt; (implements java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Comparable.html?is-external=true" title="class or interface in java.lang">Comparable</a>&lt;T&gt;, java.io.<a href="http://docs.oracle.com/javase/8/docs/api/java/io/Serializable.html?is-external=true" title="class or interface in java.io">Serializable</a>)
 <ul>
+<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/TestRegionServerReadRequestMetrics.Metric.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">TestRegionServerReadRequestMetrics.Metric</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/DataBlockEncodingTool.Manipulation.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">DataBlockEncodingTool.Manipulation</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/TestAtomicOperation.TestStep.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">TestAtomicOperation.TestStep</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/TestCacheOnWriteInSchema.CacheOnWriteType.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">TestCacheOnWriteInSchema.CacheOnWriteType</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/TestMultiLogThreshold.ActionType.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">TestMultiLogThreshold.ActionType</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/TestAtomicOperation.TestStep.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">TestAtomicOperation.TestStep</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/TestRegionServerReadRequestMetrics.Metric.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">TestRegionServerReadRequestMetrics.Metric</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/org/apache/hadoop/hbase/test/package-tree.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/test/package-tree.html b/testdevapidocs/org/apache/hadoop/hbase/test/package-tree.html
index 5103624..2691c4e 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/test/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/test/package-tree.html
@@ -253,10 +253,10 @@
 <ul>
 <li type="circle">java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Enum.html?is-external=true" title="class or interface in java.lang"><span class="typeNameLink">Enum</span></a>&lt;E&gt; (implements java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Comparable.html?is-external=true" title="class or interface in java.lang">Comparable</a>&lt;T&gt;, java.io.<a href="http://docs.oracle.com/javase/8/docs/api/java/io/Serializable.html?is-external=true" title="class or interface in java.io">Serializable</a>)
 <ul>
-<li type="circle">org.apache.hadoop.hbase.test.<a href="../../../../../org/apache/hadoop/hbase/test/IntegrationTestBigLinkedList.Generator.Counts.html" title="enum in org.apache.hadoop.hbase.test"><span class="typeNameLink">IntegrationTestBigLinkedList.Generator.Counts</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.test.<a href="../../../../../org/apache/hadoop/hbase/test/IntegrationTestLoadAndVerify.Counters.html" title="enum in org.apache.hadoop.hbase.test"><span class="typeNameLink">IntegrationTestLoadAndVerify.Counters</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.test.<a href="../../../../../org/apache/hadoop/hbase/test/IntegrationTestBigLinkedList.Verify.Counts.html" title="enum in org.apache.hadoop.hbase.test"><span class="typeNameLink">IntegrationTestBigLinkedList.Verify.Counts</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.test.<a href="../../../../../org/apache/hadoop/hbase/test/IntegrationTestWithCellVisibilityLoadAndVerify.Counters.html" title="enum in org.apache.hadoop.hbase.test"><span class="typeNameLink">IntegrationTestWithCellVisibilityLoadAndVerify.Counters</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.test.<a href="../../../../../org/apache/hadoop/hbase/test/IntegrationTestBigLinkedList.Generator.Counts.html" title="enum in org.apache.hadoop.hbase.test"><span class="typeNameLink">IntegrationTestBigLinkedList.Generator.Counts</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/org/apache/hadoop/hbase/wal/package-tree.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/wal/package-tree.html b/testdevapidocs/org/apache/hadoop/hbase/wal/package-tree.html
index d46147b..644d9f7 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/wal/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/wal/package-tree.html
@@ -137,8 +137,8 @@
 <li type="circle">java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Enum.html?is-external=true" title="class or interface in java.lang"><span class="typeNameLink">Enum</span></a>&lt;E&gt; (implements java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Comparable.html?is-external=true" title="class or interface in java.lang">Comparable</a>&lt;T&gt;, java.io.<a href="http://docs.oracle.com/javase/8/docs/api/java/io/Serializable.html?is-external=true" title="class or interface in java.io">Serializable</a>)
 <ul>
 <li type="circle">org.apache.hadoop.hbase.wal.<a href="../../../../../org/apache/hadoop/hbase/wal/FaultyFSLog.FailureType.html" title="enum in org.apache.hadoop.hbase.wal"><span class="typeNameLink">FaultyFSLog.FailureType</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.wal.<a href="../../../../../org/apache/hadoop/hbase/wal/TestWALSplit.Corruptions.html" title="enum in org.apache.hadoop.hbase.wal"><span class="typeNameLink">TestWALSplit.Corruptions</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.wal.<a href="../../../../../org/apache/hadoop/hbase/wal/IOTestProvider.AllowedOperations.html" title="enum in org.apache.hadoop.hbase.wal"><span class="typeNameLink">IOTestProvider.AllowedOperations</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.wal.<a href="../../../../../org/apache/hadoop/hbase/wal/TestWALSplit.Corruptions.html" title="enum in org.apache.hadoop.hbase.wal"><span class="typeNameLink">TestWALSplit.Corruptions</span></a></li>
 </ul>
 </li>
 </ul>


[13/14] hbase-site git commit: Published site at .

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugin-management.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugin-management.html
index 09bf341..076929b 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugin-management.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugin-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Project Plugin Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -271,7 +271,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugins.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugins.html
index f83eab1..f3b3a4e 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugins.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/plugins.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Project Plugins</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -218,7 +218,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/project-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/project-info.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/project-info.html
index 06fc86d..69387df 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/project-info.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/project-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Project Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -167,7 +167,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/project-summary.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/project-summary.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/project-summary.html
index 180a1dc..a7f58d9 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/project-summary.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/project-summary.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Project Summary</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -163,7 +163,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/source-repository.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/source-repository.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/source-repository.html
index b44bafc..70a1d1a 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/source-repository.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/source-repository.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Source Code Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -134,7 +134,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/team-list.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/team-list.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/team-list.html
index e717af7..0235607 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/team-list.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/team-list.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Project Team</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -547,7 +547,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/checkstyle.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/checkstyle.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/checkstyle.html
index 0ba5a84..dbc1f7e 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/checkstyle.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/checkstyle.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; Checkstyle Results</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -244,7 +244,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependencies.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependencies.html
index 7971bf8..5f3d1b9 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependencies.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependencies.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -4144,7 +4144,7 @@ The following provides more details on the included cryptographic software:
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependency-convergence.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependency-convergence.html
index 49165b9..5c660be 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependency-convergence.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependency-convergence.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; Reactor Dependency Convergence</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -838,7 +838,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependency-info.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependency-info.html
index 7967170..c80e7d1 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependency-info.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependency-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; Dependency Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -147,7 +147,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependency-management.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependency-management.html
index 96200f6..cf34cae 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependency-management.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/dependency-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; Project Dependency Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -804,7 +804,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/index.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/index.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/index.html
index a1ef62d..c7044c4 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/index.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/index.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; About</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -119,7 +119,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/integration.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/integration.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/integration.html
index ee849b7..6ecaebf 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/integration.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/integration.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; CI Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -126,7 +126,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/issue-tracking.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/issue-tracking.html
index e75f8b1..2671c46 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/issue-tracking.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/issue-tracking.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; Issue Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -123,7 +123,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/license.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/license.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/license.html
index 8344654..53a11ff 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/license.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/license.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; Project Licenses</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -326,7 +326,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/mail-lists.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/mail-lists.html
index ec3a91a..25f4eaa 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/mail-lists.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/mail-lists.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; Project Mailing Lists</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -176,7 +176,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/plugin-management.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/plugin-management.html
index bea329e..5cdcea5 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/plugin-management.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/plugin-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; Project Plugin Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -271,7 +271,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/plugins.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/plugins.html
index 374e080..1baa84b 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/plugins.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/plugins.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; Project Plugins</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -226,7 +226,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/project-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/project-info.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/project-info.html
index 19b1cd2..df578d0 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/project-info.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/project-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; Project Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -167,7 +167,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/project-reports.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/project-reports.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/project-reports.html
index 9622920..69affdc 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/project-reports.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/project-reports.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; Generated Reports</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -128,7 +128,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/project-summary.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/project-summary.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/project-summary.html
index 30c6c85..dd2075a 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/project-summary.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/project-summary.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; Project Summary</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -166,7 +166,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/source-repository.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/source-repository.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/source-repository.html
index 6819e88..f4178f3 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/source-repository.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/source-repository.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; Source Code Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -134,7 +134,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-client-project/team-list.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-client-project/team-list.html b/hbase-build-configuration/hbase-archetypes/hbase-client-project/team-list.html
index 5d33210..e298a4f 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-client-project/team-list.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-client-project/team-list.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; Project Team</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -547,7 +547,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/checkstyle.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/checkstyle.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/checkstyle.html
index 37a6f2d..3aeb21a 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/checkstyle.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/checkstyle.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; Checkstyle Results</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -244,7 +244,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependencies.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependencies.html
index 49740f6..3f3399d 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependencies.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependencies.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -4169,7 +4169,7 @@ built on Jackson JSON processor</p>
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependency-convergence.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependency-convergence.html
index 238f6d6..dbc1fe9 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependency-convergence.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependency-convergence.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; Reactor Dependency Convergence</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -838,7 +838,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependency-info.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependency-info.html
index d188ea3..764601f 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependency-info.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependency-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; Dependency Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -147,7 +147,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependency-management.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependency-management.html
index 41779ab..058d244 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependency-management.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/dependency-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; Project Dependency Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -804,7 +804,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/index.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/index.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/index.html
index e9a84e4..0613107 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/index.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/index.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; About</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -119,7 +119,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/integration.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/integration.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/integration.html
index 2906ba6..7b93d56 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/integration.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/integration.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; CI Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -126,7 +126,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/issue-tracking.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/issue-tracking.html
index 9deef92..4f1f79b 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/issue-tracking.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/issue-tracking.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; Issue Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -123,7 +123,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/license.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/license.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/license.html
index d9f5493..6c3072b 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/license.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/license.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; Project Licenses</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -326,7 +326,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/mail-lists.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/mail-lists.html
index 7aa71aa..6da74d3 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/mail-lists.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/mail-lists.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; Project Mailing Lists</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -176,7 +176,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/plugin-management.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/plugin-management.html
index 0f7ca82..f47b585 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/plugin-management.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/plugin-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; Project Plugin Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -271,7 +271,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/plugins.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/plugins.html
index e78bb51..c9e21cd 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/plugins.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/plugins.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; Project Plugins</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -226,7 +226,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/project-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/project-info.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/project-info.html
index 9cf4937..7dbfbf0 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/project-info.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/project-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; Project Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -167,7 +167,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/project-reports.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/project-reports.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/project-reports.html
index 68968a7..95afff2 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/project-reports.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/project-reports.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; Generated Reports</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -128,7 +128,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/project-summary.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/project-summary.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/project-summary.html
index 5284eee..5e5b01c 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/project-summary.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/project-summary.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; Project Summary</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -166,7 +166,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/source-repository.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/source-repository.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/source-repository.html
index c79cc34..20b9915 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/source-repository.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/source-repository.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; Source Code Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -134,7 +134,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/team-list.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/team-list.html b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/team-list.html
index f796cd1..ac8f641 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/team-list.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-shaded-client-project/team-list.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; Project Team</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -547,7 +547,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/index.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/index.html b/hbase-build-configuration/hbase-archetypes/index.html
index e9a5453..41d17b0 100644
--- a/hbase-build-configuration/hbase-archetypes/index.html
+++ b/hbase-build-configuration/hbase-archetypes/index.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; About</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -135,7 +135,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/integration.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/integration.html b/hbase-build-configuration/hbase-archetypes/integration.html
index cc17bdf..66a2545 100644
--- a/hbase-build-configuration/hbase-archetypes/integration.html
+++ b/hbase-build-configuration/hbase-archetypes/integration.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; CI Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -126,7 +126,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/issue-tracking.html b/hbase-build-configuration/hbase-archetypes/issue-tracking.html
index 3e22107..0437b70 100644
--- a/hbase-build-configuration/hbase-archetypes/issue-tracking.html
+++ b/hbase-build-configuration/hbase-archetypes/issue-tracking.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Issue Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -123,7 +123,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/license.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/license.html b/hbase-build-configuration/hbase-archetypes/license.html
index acddf75..f0b2331 100644
--- a/hbase-build-configuration/hbase-archetypes/license.html
+++ b/hbase-build-configuration/hbase-archetypes/license.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Project Licenses</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -326,7 +326,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/mail-lists.html b/hbase-build-configuration/hbase-archetypes/mail-lists.html
index 8ed4780..b7db3e0 100644
--- a/hbase-build-configuration/hbase-archetypes/mail-lists.html
+++ b/hbase-build-configuration/hbase-archetypes/mail-lists.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Project Mailing Lists</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -176,7 +176,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/plugin-management.html b/hbase-build-configuration/hbase-archetypes/plugin-management.html
index a1e05a4..8e51508 100644
--- a/hbase-build-configuration/hbase-archetypes/plugin-management.html
+++ b/hbase-build-configuration/hbase-archetypes/plugin-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Project Plugin Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -271,7 +271,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/plugins.html b/hbase-build-configuration/hbase-archetypes/plugins.html
index 844ed55..1a67a7f 100644
--- a/hbase-build-configuration/hbase-archetypes/plugins.html
+++ b/hbase-build-configuration/hbase-archetypes/plugins.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Project Plugins</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -214,7 +214,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/project-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/project-info.html b/hbase-build-configuration/hbase-archetypes/project-info.html
index ef00cd3..a10284c 100644
--- a/hbase-build-configuration/hbase-archetypes/project-info.html
+++ b/hbase-build-configuration/hbase-archetypes/project-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Project Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -167,7 +167,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/project-summary.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/project-summary.html b/hbase-build-configuration/hbase-archetypes/project-summary.html
index a1c1f5a..5deb074 100644
--- a/hbase-build-configuration/hbase-archetypes/project-summary.html
+++ b/hbase-build-configuration/hbase-archetypes/project-summary.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Project Summary</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -163,7 +163,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/source-repository.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/source-repository.html b/hbase-build-configuration/hbase-archetypes/source-repository.html
index 2f584e5..024e5d0 100644
--- a/hbase-build-configuration/hbase-archetypes/source-repository.html
+++ b/hbase-build-configuration/hbase-archetypes/source-repository.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Source Code Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -134,7 +134,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/team-list.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/team-list.html b/hbase-build-configuration/hbase-archetypes/team-list.html
index 73dfa57..422abbe 100644
--- a/hbase-build-configuration/hbase-archetypes/team-list.html
+++ b/hbase-build-configuration/hbase-archetypes/team-list.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Project Team</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -547,7 +547,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/checkstyle.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/checkstyle.html b/hbase-build-configuration/hbase-spark/checkstyle.html
index dfcd7b2..8036eb0 100644
--- a/hbase-build-configuration/hbase-spark/checkstyle.html
+++ b/hbase-build-configuration/hbase-spark/checkstyle.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; Checkstyle Results</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -517,7 +517,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/dependencies.html b/hbase-build-configuration/hbase-spark/dependencies.html
index 778fc67..81fa82b 100644
--- a/hbase-build-configuration/hbase-spark/dependencies.html
+++ b/hbase-build-configuration/hbase-spark/dependencies.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -5667,7 +5667,7 @@ file comparators, endian transformation classes, and much more.</p>
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/dependency-convergence.html b/hbase-build-configuration/hbase-spark/dependency-convergence.html
index deb4bd8..3b74707 100644
--- a/hbase-build-configuration/hbase-spark/dependency-convergence.html
+++ b/hbase-build-configuration/hbase-spark/dependency-convergence.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; Reactor Dependency Convergence</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -838,7 +838,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/dependency-info.html b/hbase-build-configuration/hbase-spark/dependency-info.html
index 9bcde02..95a75a9 100644
--- a/hbase-build-configuration/hbase-spark/dependency-info.html
+++ b/hbase-build-configuration/hbase-spark/dependency-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; Dependency Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -147,7 +147,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/dependency-management.html b/hbase-build-configuration/hbase-spark/dependency-management.html
index a740cf8..dd3c733 100644
--- a/hbase-build-configuration/hbase-spark/dependency-management.html
+++ b/hbase-build-configuration/hbase-spark/dependency-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; Project Dependency Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -804,7 +804,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/index.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/index.html b/hbase-build-configuration/hbase-spark/index.html
index 955708c..8fc8296 100644
--- a/hbase-build-configuration/hbase-spark/index.html
+++ b/hbase-build-configuration/hbase-spark/index.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; About</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -119,7 +119,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/integration.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/integration.html b/hbase-build-configuration/hbase-spark/integration.html
index b1a7524..2193d5c 100644
--- a/hbase-build-configuration/hbase-spark/integration.html
+++ b/hbase-build-configuration/hbase-spark/integration.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; CI Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -126,7 +126,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/issue-tracking.html b/hbase-build-configuration/hbase-spark/issue-tracking.html
index 8d6f488..a41dfbc 100644
--- a/hbase-build-configuration/hbase-spark/issue-tracking.html
+++ b/hbase-build-configuration/hbase-spark/issue-tracking.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; Issue Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -123,7 +123,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/license.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/license.html b/hbase-build-configuration/hbase-spark/license.html
index e8c23b2..f394f12 100644
--- a/hbase-build-configuration/hbase-spark/license.html
+++ b/hbase-build-configuration/hbase-spark/license.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; Project Licenses</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -326,7 +326,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/mail-lists.html b/hbase-build-configuration/hbase-spark/mail-lists.html
index f7b0f4b..22c4072 100644
--- a/hbase-build-configuration/hbase-spark/mail-lists.html
+++ b/hbase-build-configuration/hbase-spark/mail-lists.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; Project Mailing Lists</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -176,7 +176,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 


[12/14] hbase-site git commit: Published site at .

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/plugin-management.html b/hbase-build-configuration/hbase-spark/plugin-management.html
index 9b44bce..a58bcfe 100644
--- a/hbase-build-configuration/hbase-spark/plugin-management.html
+++ b/hbase-build-configuration/hbase-spark/plugin-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; Project Plugin Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -271,7 +271,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/plugins.html b/hbase-build-configuration/hbase-spark/plugins.html
index 6f8186e..e0821c8 100644
--- a/hbase-build-configuration/hbase-spark/plugins.html
+++ b/hbase-build-configuration/hbase-spark/plugins.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; Project Plugins</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -238,7 +238,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/project-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/project-info.html b/hbase-build-configuration/hbase-spark/project-info.html
index 5dea1c5..b965ffc 100644
--- a/hbase-build-configuration/hbase-spark/project-info.html
+++ b/hbase-build-configuration/hbase-spark/project-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; Project Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -167,7 +167,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/project-reports.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/project-reports.html b/hbase-build-configuration/hbase-spark/project-reports.html
index d11ea97..c89dcd5 100644
--- a/hbase-build-configuration/hbase-spark/project-reports.html
+++ b/hbase-build-configuration/hbase-spark/project-reports.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; Generated Reports</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -131,7 +131,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/project-summary.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/project-summary.html b/hbase-build-configuration/hbase-spark/project-summary.html
index 195f1da..56703b6 100644
--- a/hbase-build-configuration/hbase-spark/project-summary.html
+++ b/hbase-build-configuration/hbase-spark/project-summary.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; Project Summary</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -166,7 +166,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/source-repository.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/source-repository.html b/hbase-build-configuration/hbase-spark/source-repository.html
index f83e7f9..90d9d5d 100644
--- a/hbase-build-configuration/hbase-spark/source-repository.html
+++ b/hbase-build-configuration/hbase-spark/source-repository.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; Source Code Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -134,7 +134,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-spark/team-list.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-spark/team-list.html b/hbase-build-configuration/hbase-spark/team-list.html
index 4075e80..c2cd6ee 100644
--- a/hbase-build-configuration/hbase-spark/team-list.html
+++ b/hbase-build-configuration/hbase-spark/team-list.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Spark &#x2013; Project Team</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -547,7 +547,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/index.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/index.html b/hbase-build-configuration/index.html
index 338d4a5..d4da1da 100644
--- a/hbase-build-configuration/index.html
+++ b/hbase-build-configuration/index.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; About</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -119,7 +119,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/integration.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/integration.html b/hbase-build-configuration/integration.html
index 0e43ccb..634f547 100644
--- a/hbase-build-configuration/integration.html
+++ b/hbase-build-configuration/integration.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; CI Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -126,7 +126,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/issue-tracking.html b/hbase-build-configuration/issue-tracking.html
index 4fc222f..0cf00ed 100644
--- a/hbase-build-configuration/issue-tracking.html
+++ b/hbase-build-configuration/issue-tracking.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Issue Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -123,7 +123,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/license.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/license.html b/hbase-build-configuration/license.html
index 9e33e0f..b3309b0 100644
--- a/hbase-build-configuration/license.html
+++ b/hbase-build-configuration/license.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Project Licenses</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -326,7 +326,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/mail-lists.html b/hbase-build-configuration/mail-lists.html
index 120abb0..83edcf1 100644
--- a/hbase-build-configuration/mail-lists.html
+++ b/hbase-build-configuration/mail-lists.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Project Mailing Lists</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -176,7 +176,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/plugin-management.html b/hbase-build-configuration/plugin-management.html
index d55cefd..da5d598 100644
--- a/hbase-build-configuration/plugin-management.html
+++ b/hbase-build-configuration/plugin-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Project Plugin Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -271,7 +271,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/plugins.html b/hbase-build-configuration/plugins.html
index fe25497..dac962a 100644
--- a/hbase-build-configuration/plugins.html
+++ b/hbase-build-configuration/plugins.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Project Plugins</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -214,7 +214,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/project-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/project-info.html b/hbase-build-configuration/project-info.html
index ac4b79d..9007365 100644
--- a/hbase-build-configuration/project-info.html
+++ b/hbase-build-configuration/project-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Project Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -167,7 +167,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/project-summary.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/project-summary.html b/hbase-build-configuration/project-summary.html
index 539536c..29e22f9 100644
--- a/hbase-build-configuration/project-summary.html
+++ b/hbase-build-configuration/project-summary.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Project Summary</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -163,7 +163,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/source-repository.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/source-repository.html b/hbase-build-configuration/source-repository.html
index 89285ed..5005935 100644
--- a/hbase-build-configuration/source-repository.html
+++ b/hbase-build-configuration/source-repository.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Source Code Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -134,7 +134,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/team-list.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/team-list.html b/hbase-build-configuration/team-list.html
index 92d7cfe..6fa6813 100644
--- a/hbase-build-configuration/team-list.html
+++ b/hbase-build-configuration/team-list.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Project Team</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -547,7 +547,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/checkstyle.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/checkstyle.html b/hbase-shaded-check-invariants/checkstyle.html
index 62ae87d..d46f4f7 100644
--- a/hbase-shaded-check-invariants/checkstyle.html
+++ b/hbase-shaded-check-invariants/checkstyle.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; Checkstyle Results</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -150,7 +150,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/dependencies.html b/hbase-shaded-check-invariants/dependencies.html
index c885c98..6292cce 100644
--- a/hbase-shaded-check-invariants/dependencies.html
+++ b/hbase-shaded-check-invariants/dependencies.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -2883,7 +2883,7 @@ Jackson JSON processor's data binding functionality.</p>
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/dependency-convergence.html b/hbase-shaded-check-invariants/dependency-convergence.html
index 2a676ed..f9318f2 100644
--- a/hbase-shaded-check-invariants/dependency-convergence.html
+++ b/hbase-shaded-check-invariants/dependency-convergence.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; Reactor Dependency Convergence</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -838,7 +838,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/dependency-info.html b/hbase-shaded-check-invariants/dependency-info.html
index e06ec43..c95f90b 100644
--- a/hbase-shaded-check-invariants/dependency-info.html
+++ b/hbase-shaded-check-invariants/dependency-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; Dependency Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -148,7 +148,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/dependency-management.html b/hbase-shaded-check-invariants/dependency-management.html
index 01c4528..ac10e2c 100644
--- a/hbase-shaded-check-invariants/dependency-management.html
+++ b/hbase-shaded-check-invariants/dependency-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; Project Dependency Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -804,7 +804,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/index.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/index.html b/hbase-shaded-check-invariants/index.html
index fd4bf56..639f813 100644
--- a/hbase-shaded-check-invariants/index.html
+++ b/hbase-shaded-check-invariants/index.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; About</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -122,7 +122,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/integration.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/integration.html b/hbase-shaded-check-invariants/integration.html
index 8ef734e..ba9c6e6 100644
--- a/hbase-shaded-check-invariants/integration.html
+++ b/hbase-shaded-check-invariants/integration.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; CI Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -126,7 +126,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/issue-tracking.html b/hbase-shaded-check-invariants/issue-tracking.html
index 428a31c..6674936 100644
--- a/hbase-shaded-check-invariants/issue-tracking.html
+++ b/hbase-shaded-check-invariants/issue-tracking.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; Issue Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -123,7 +123,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/license.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/license.html b/hbase-shaded-check-invariants/license.html
index dd14ef2..c33e424 100644
--- a/hbase-shaded-check-invariants/license.html
+++ b/hbase-shaded-check-invariants/license.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; Project Licenses</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -326,7 +326,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/mail-lists.html b/hbase-shaded-check-invariants/mail-lists.html
index ab876df..e2c5062 100644
--- a/hbase-shaded-check-invariants/mail-lists.html
+++ b/hbase-shaded-check-invariants/mail-lists.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; Project Mailing Lists</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -176,7 +176,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/plugin-management.html b/hbase-shaded-check-invariants/plugin-management.html
index 6ab6e46..0a52860 100644
--- a/hbase-shaded-check-invariants/plugin-management.html
+++ b/hbase-shaded-check-invariants/plugin-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; Project Plugin Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -271,7 +271,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/plugins.html b/hbase-shaded-check-invariants/plugins.html
index e9b9392..5d32cef 100644
--- a/hbase-shaded-check-invariants/plugins.html
+++ b/hbase-shaded-check-invariants/plugins.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; Project Plugins</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -218,7 +218,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/project-info.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/project-info.html b/hbase-shaded-check-invariants/project-info.html
index 73fa63f..9b65514 100644
--- a/hbase-shaded-check-invariants/project-info.html
+++ b/hbase-shaded-check-invariants/project-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; Project Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -170,7 +170,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/project-reports.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/project-reports.html b/hbase-shaded-check-invariants/project-reports.html
index d577599..b4b7e7a 100644
--- a/hbase-shaded-check-invariants/project-reports.html
+++ b/hbase-shaded-check-invariants/project-reports.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; Generated Reports</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -128,7 +128,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/project-summary.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/project-summary.html b/hbase-shaded-check-invariants/project-summary.html
index 33d0ebe..735276f 100644
--- a/hbase-shaded-check-invariants/project-summary.html
+++ b/hbase-shaded-check-invariants/project-summary.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; Project Summary</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -166,7 +166,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/source-repository.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/source-repository.html b/hbase-shaded-check-invariants/source-repository.html
index 0684443..525373a 100644
--- a/hbase-shaded-check-invariants/source-repository.html
+++ b/hbase-shaded-check-invariants/source-repository.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; Source Code Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -134,7 +134,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-shaded-check-invariants/team-list.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/team-list.html b/hbase-shaded-check-invariants/team-list.html
index 89c71db..07545f9 100644
--- a/hbase-shaded-check-invariants/team-list.html
+++ b/hbase-shaded-check-invariants/team-list.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase Shaded Packaging Invariants &#x2013; Project Team</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -547,7 +547,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/index.html
----------------------------------------------------------------------
diff --git a/index.html b/index.html
index a173730..2883ec8 100644
--- a/index.html
+++ b/index.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Apache HBaseâ„¢ Home</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -438,7 +438,7 @@ Apache HBase is an open-source, distributed, versioned, non-relational database
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/integration.html
----------------------------------------------------------------------
diff --git a/integration.html b/integration.html
index b51bfbb..7f92ef1 100644
--- a/integration.html
+++ b/integration.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; CI Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -296,7 +296,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/issue-tracking.html
----------------------------------------------------------------------
diff --git a/issue-tracking.html b/issue-tracking.html
index af6754b..b7c0309 100644
--- a/issue-tracking.html
+++ b/issue-tracking.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Issue Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -293,7 +293,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/license.html
----------------------------------------------------------------------
diff --git a/license.html b/license.html
index a68e950..f817d10 100644
--- a/license.html
+++ b/license.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Project Licenses</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -496,7 +496,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/mail-lists.html
----------------------------------------------------------------------
diff --git a/mail-lists.html b/mail-lists.html
index aed3715..d4453ba 100644
--- a/mail-lists.html
+++ b/mail-lists.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Project Mailing Lists</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -346,7 +346,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/metrics.html
----------------------------------------------------------------------
diff --git a/metrics.html b/metrics.html
index 314f50d..c1ec558 100644
--- a/metrics.html
+++ b/metrics.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013;  
       Apache HBase (TM) Metrics
@@ -464,7 +464,7 @@ export HBASE_REGIONSERVER_OPTS=&quot;$HBASE_JMX_OPTS -Dcom.sun.management.jmxrem
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/old_news.html
----------------------------------------------------------------------
diff --git a/old_news.html b/old_news.html
index b3ed805..af43f87 100644
--- a/old_news.html
+++ b/old_news.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; 
       Old Apache HBase (TM) News
@@ -419,7 +419,7 @@ under the License. -->
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/plugin-management.html
----------------------------------------------------------------------
diff --git a/plugin-management.html b/plugin-management.html
index 5213115..b0cce00 100644
--- a/plugin-management.html
+++ b/plugin-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Project Plugin Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -441,7 +441,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/plugins.html
----------------------------------------------------------------------
diff --git a/plugins.html b/plugins.html
index 02a18f2..db7a81a 100644
--- a/plugins.html
+++ b/plugins.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Project Plugins</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -380,7 +380,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/poweredbyhbase.html
----------------------------------------------------------------------
diff --git a/poweredbyhbase.html b/poweredbyhbase.html
index d3b0404..2628344 100644
--- a/poweredbyhbase.html
+++ b/poweredbyhbase.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Powered By Apache HBase™</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -774,7 +774,7 @@ under the License. -->
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/project-info.html
----------------------------------------------------------------------
diff --git a/project-info.html b/project-info.html
index 6e6f303..8f7b0d6 100644
--- a/project-info.html
+++ b/project-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Project Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -340,7 +340,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/project-reports.html
----------------------------------------------------------------------
diff --git a/project-reports.html b/project-reports.html
index 173f54d..995ac3b 100644
--- a/project-reports.html
+++ b/project-reports.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Generated Reports</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -310,7 +310,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/project-summary.html
----------------------------------------------------------------------
diff --git a/project-summary.html b/project-summary.html
index a02ee75..1cc7a94 100644
--- a/project-summary.html
+++ b/project-summary.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Project Summary</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -336,7 +336,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/pseudo-distributed.html
----------------------------------------------------------------------
diff --git a/pseudo-distributed.html b/pseudo-distributed.html
index 3fc2beb..90ea5ae 100644
--- a/pseudo-distributed.html
+++ b/pseudo-distributed.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013;  
 Running Apache HBase (TM) in pseudo-distributed mode
@@ -313,7 +313,7 @@ under the License. -->
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/replication.html
----------------------------------------------------------------------
diff --git a/replication.html b/replication.html
index a17bd9d..20e98f3 100644
--- a/replication.html
+++ b/replication.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; 
       Apache HBase (TM) Replication
@@ -308,7 +308,7 @@ under the License. -->
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/resources.html
----------------------------------------------------------------------
diff --git a/resources.html b/resources.html
index 60c2f55..c88c97b 100644
--- a/resources.html
+++ b/resources.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Other Apache HBase (TM) Resources</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -336,7 +336,7 @@ under the License. -->
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/source-repository.html
----------------------------------------------------------------------
diff --git a/source-repository.html b/source-repository.html
index 064ff4c..94882d3 100644
--- a/source-repository.html
+++ b/source-repository.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Source Code Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -304,7 +304,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/sponsors.html
----------------------------------------------------------------------
diff --git a/sponsors.html b/sponsors.html
index ef49d9d..e39be9a 100644
--- a/sponsors.html
+++ b/sponsors.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Apache HBase™ Sponsors</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -338,7 +338,7 @@ under the License. -->
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/supportingprojects.html
----------------------------------------------------------------------
diff --git a/supportingprojects.html b/supportingprojects.html
index 9f95990..601e839 100644
--- a/supportingprojects.html
+++ b/supportingprojects.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Supporting Projects</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -525,7 +525,7 @@ under the License. -->
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/team-list.html
----------------------------------------------------------------------
diff --git a/team-list.html b/team-list.html
index e630eb1..a487bc0 100644
--- a/team-list.html
+++ b/team-list.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Project Team</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -717,7 +717,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testapidocs/index-all.html
----------------------------------------------------------------------
diff --git a/testapidocs/index-all.html b/testapidocs/index-all.html
index 73fe13f..719dec4 100644
--- a/testapidocs/index-all.html
+++ b/testapidocs/index-all.html
@@ -669,6 +669,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/HBaseTestingUtility.html#getNumHFilesForRS-org.apache.hadoop.hbase.regionserver.HRegionServer-org.apache.hadoop.hbase.TableName-byte:A-">getNumHFilesForRS(HRegionServer, TableName, byte[])</a></span> - Method in class org.apache.hadoop.hbase.<a href="org/apache/hadoop/hbase/HBaseTestingUtility.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/HBaseTestingUtility.html#getOtherRegionServer-org.apache.hadoop.hbase.regionserver.HRegionServer-">getOtherRegionServer(HRegionServer)</a></span> - Method in class org.apache.hadoop.hbase.<a href="org/apache/hadoop/hbase/HBaseTestingUtility.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/HBaseCommonTestingUtility.html#getRandomDir--">getRandomDir()</a></span> - Method in class org.apache.hadoop.hbase.<a href="org/apache/hadoop/hbase/HBaseCommonTestingUtility.html" title="class in org.apache.hadoop.hbase">HBaseCommonTestingUtility</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/MiniHBaseCluster.html#getRegions-byte:A-">getRegions(byte[])</a></span> - Method in class org.apache.hadoop.hbase.<a href="org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a></dt>


[05/14] hbase-site git commit: Published site at .

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.AvailablePortChecker.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.AvailablePortChecker.html b/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.AvailablePortChecker.html
index 0cec549..06b92ba 100644
--- a/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.AvailablePortChecker.html
+++ b/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.AvailablePortChecker.html
@@ -2518,1796 +2518,1811 @@
 <span class="sourceLineNo">2510</span>    return rows;<a name="line.2510"></a>
 <span class="sourceLineNo">2511</span>  }<a name="line.2511"></a>
 <span class="sourceLineNo">2512</span><a name="line.2512"></a>
-<span class="sourceLineNo">2513</span>  /**<a name="line.2513"></a>
-<span class="sourceLineNo">2514</span>   * Tool to get the reference to the region server object that holds the<a name="line.2514"></a>
-<span class="sourceLineNo">2515</span>   * region of the specified user table.<a name="line.2515"></a>
-<span class="sourceLineNo">2516</span>   * It first searches for the meta rows that contain the region of the<a name="line.2516"></a>
-<span class="sourceLineNo">2517</span>   * specified table, then gets the index of that RS, and finally retrieves<a name="line.2517"></a>
-<span class="sourceLineNo">2518</span>   * the RS's reference.<a name="line.2518"></a>
-<span class="sourceLineNo">2519</span>   * @param tableName user table to lookup in hbase:meta<a name="line.2519"></a>
-<span class="sourceLineNo">2520</span>   * @return region server that holds it, null if the row doesn't exist<a name="line.2520"></a>
-<span class="sourceLineNo">2521</span>   * @throws IOException<a name="line.2521"></a>
-<span class="sourceLineNo">2522</span>   * @throws InterruptedException<a name="line.2522"></a>
-<span class="sourceLineNo">2523</span>   */<a name="line.2523"></a>
-<span class="sourceLineNo">2524</span>  public HRegionServer getRSForFirstRegionInTable(TableName tableName)<a name="line.2524"></a>
-<span class="sourceLineNo">2525</span>      throws IOException, InterruptedException {<a name="line.2525"></a>
-<span class="sourceLineNo">2526</span>    List&lt;byte[]&gt; metaRows = getMetaTableRows(tableName);<a name="line.2526"></a>
-<span class="sourceLineNo">2527</span>    if (metaRows == null || metaRows.isEmpty()) {<a name="line.2527"></a>
-<span class="sourceLineNo">2528</span>      return null;<a name="line.2528"></a>
-<span class="sourceLineNo">2529</span>    }<a name="line.2529"></a>
-<span class="sourceLineNo">2530</span>    LOG.debug("Found " + metaRows.size() + " rows for table " +<a name="line.2530"></a>
-<span class="sourceLineNo">2531</span>      tableName);<a name="line.2531"></a>
-<span class="sourceLineNo">2532</span>    byte [] firstrow = metaRows.get(0);<a name="line.2532"></a>
-<span class="sourceLineNo">2533</span>    LOG.debug("FirstRow=" + Bytes.toString(firstrow));<a name="line.2533"></a>
-<span class="sourceLineNo">2534</span>    long pause = getConfiguration().getLong(HConstants.HBASE_CLIENT_PAUSE,<a name="line.2534"></a>
-<span class="sourceLineNo">2535</span>      HConstants.DEFAULT_HBASE_CLIENT_PAUSE);<a name="line.2535"></a>
-<span class="sourceLineNo">2536</span>    int numRetries = getConfiguration().getInt(HConstants.HBASE_CLIENT_RETRIES_NUMBER,<a name="line.2536"></a>
-<span class="sourceLineNo">2537</span>      HConstants.DEFAULT_HBASE_CLIENT_RETRIES_NUMBER);<a name="line.2537"></a>
-<span class="sourceLineNo">2538</span>    RetryCounter retrier = new RetryCounter(numRetries+1, (int)pause, TimeUnit.MICROSECONDS);<a name="line.2538"></a>
-<span class="sourceLineNo">2539</span>    while(retrier.shouldRetry()) {<a name="line.2539"></a>
-<span class="sourceLineNo">2540</span>      int index = getMiniHBaseCluster().getServerWith(firstrow);<a name="line.2540"></a>
-<span class="sourceLineNo">2541</span>      if (index != -1) {<a name="line.2541"></a>
-<span class="sourceLineNo">2542</span>        return getMiniHBaseCluster().getRegionServerThreads().get(index).getRegionServer();<a name="line.2542"></a>
-<span class="sourceLineNo">2543</span>      }<a name="line.2543"></a>
-<span class="sourceLineNo">2544</span>      // Came back -1.  Region may not be online yet.  Sleep a while.<a name="line.2544"></a>
-<span class="sourceLineNo">2545</span>      retrier.sleepUntilNextRetry();<a name="line.2545"></a>
-<span class="sourceLineNo">2546</span>    }<a name="line.2546"></a>
-<span class="sourceLineNo">2547</span>    return null;<a name="line.2547"></a>
-<span class="sourceLineNo">2548</span>  }<a name="line.2548"></a>
-<span class="sourceLineNo">2549</span><a name="line.2549"></a>
-<span class="sourceLineNo">2550</span>  /**<a name="line.2550"></a>
-<span class="sourceLineNo">2551</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt; with a default number of<a name="line.2551"></a>
-<span class="sourceLineNo">2552</span>   * &lt;code&gt;TaskTracker&lt;/code&gt;'s.<a name="line.2552"></a>
-<span class="sourceLineNo">2553</span>   *<a name="line.2553"></a>
-<span class="sourceLineNo">2554</span>   * @throws IOException When starting the cluster fails.<a name="line.2554"></a>
-<span class="sourceLineNo">2555</span>   */<a name="line.2555"></a>
-<span class="sourceLineNo">2556</span>  public MiniMRCluster startMiniMapReduceCluster() throws IOException {<a name="line.2556"></a>
-<span class="sourceLineNo">2557</span>    // Set a very high max-disk-utilization percentage to avoid the NodeManagers from failing.<a name="line.2557"></a>
-<span class="sourceLineNo">2558</span>    conf.setIfUnset(<a name="line.2558"></a>
-<span class="sourceLineNo">2559</span>        "yarn.nodemanager.disk-health-checker.max-disk-utilization-per-disk-percentage",<a name="line.2559"></a>
-<span class="sourceLineNo">2560</span>        "99.0");<a name="line.2560"></a>
-<span class="sourceLineNo">2561</span>    startMiniMapReduceCluster(2);<a name="line.2561"></a>
-<span class="sourceLineNo">2562</span>    return mrCluster;<a name="line.2562"></a>
+<span class="sourceLineNo">2513</span>  /*<a name="line.2513"></a>
+<span class="sourceLineNo">2514</span>   * Find any other region server which is different from the one identified by parameter<a name="line.2514"></a>
+<span class="sourceLineNo">2515</span>   * @param rs<a name="line.2515"></a>
+<span class="sourceLineNo">2516</span>   * @return another region server<a name="line.2516"></a>
+<span class="sourceLineNo">2517</span>   */<a name="line.2517"></a>
+<span class="sourceLineNo">2518</span>  public HRegionServer getOtherRegionServer(HRegionServer rs) {<a name="line.2518"></a>
+<span class="sourceLineNo">2519</span>    for (JVMClusterUtil.RegionServerThread rst :<a name="line.2519"></a>
+<span class="sourceLineNo">2520</span>      getMiniHBaseCluster().getRegionServerThreads()) {<a name="line.2520"></a>
+<span class="sourceLineNo">2521</span>      if (!(rst.getRegionServer() == rs)) {<a name="line.2521"></a>
+<span class="sourceLineNo">2522</span>        return rst.getRegionServer();<a name="line.2522"></a>
+<span class="sourceLineNo">2523</span>      }<a name="line.2523"></a>
+<span class="sourceLineNo">2524</span>    }<a name="line.2524"></a>
+<span class="sourceLineNo">2525</span>    return null;<a name="line.2525"></a>
+<span class="sourceLineNo">2526</span>  }<a name="line.2526"></a>
+<span class="sourceLineNo">2527</span><a name="line.2527"></a>
+<span class="sourceLineNo">2528</span>  /**<a name="line.2528"></a>
+<span class="sourceLineNo">2529</span>   * Tool to get the reference to the region server object that holds the<a name="line.2529"></a>
+<span class="sourceLineNo">2530</span>   * region of the specified user table.<a name="line.2530"></a>
+<span class="sourceLineNo">2531</span>   * It first searches for the meta rows that contain the region of the<a name="line.2531"></a>
+<span class="sourceLineNo">2532</span>   * specified table, then gets the index of that RS, and finally retrieves<a name="line.2532"></a>
+<span class="sourceLineNo">2533</span>   * the RS's reference.<a name="line.2533"></a>
+<span class="sourceLineNo">2534</span>   * @param tableName user table to lookup in hbase:meta<a name="line.2534"></a>
+<span class="sourceLineNo">2535</span>   * @return region server that holds it, null if the row doesn't exist<a name="line.2535"></a>
+<span class="sourceLineNo">2536</span>   * @throws IOException<a name="line.2536"></a>
+<span class="sourceLineNo">2537</span>   * @throws InterruptedException<a name="line.2537"></a>
+<span class="sourceLineNo">2538</span>   */<a name="line.2538"></a>
+<span class="sourceLineNo">2539</span>  public HRegionServer getRSForFirstRegionInTable(TableName tableName)<a name="line.2539"></a>
+<span class="sourceLineNo">2540</span>      throws IOException, InterruptedException {<a name="line.2540"></a>
+<span class="sourceLineNo">2541</span>    List&lt;byte[]&gt; metaRows = getMetaTableRows(tableName);<a name="line.2541"></a>
+<span class="sourceLineNo">2542</span>    if (metaRows == null || metaRows.isEmpty()) {<a name="line.2542"></a>
+<span class="sourceLineNo">2543</span>      return null;<a name="line.2543"></a>
+<span class="sourceLineNo">2544</span>    }<a name="line.2544"></a>
+<span class="sourceLineNo">2545</span>    LOG.debug("Found " + metaRows.size() + " rows for table " +<a name="line.2545"></a>
+<span class="sourceLineNo">2546</span>      tableName);<a name="line.2546"></a>
+<span class="sourceLineNo">2547</span>    byte [] firstrow = metaRows.get(0);<a name="line.2547"></a>
+<span class="sourceLineNo">2548</span>    LOG.debug("FirstRow=" + Bytes.toString(firstrow));<a name="line.2548"></a>
+<span class="sourceLineNo">2549</span>    long pause = getConfiguration().getLong(HConstants.HBASE_CLIENT_PAUSE,<a name="line.2549"></a>
+<span class="sourceLineNo">2550</span>      HConstants.DEFAULT_HBASE_CLIENT_PAUSE);<a name="line.2550"></a>
+<span class="sourceLineNo">2551</span>    int numRetries = getConfiguration().getInt(HConstants.HBASE_CLIENT_RETRIES_NUMBER,<a name="line.2551"></a>
+<span class="sourceLineNo">2552</span>      HConstants.DEFAULT_HBASE_CLIENT_RETRIES_NUMBER);<a name="line.2552"></a>
+<span class="sourceLineNo">2553</span>    RetryCounter retrier = new RetryCounter(numRetries+1, (int)pause, TimeUnit.MICROSECONDS);<a name="line.2553"></a>
+<span class="sourceLineNo">2554</span>    while(retrier.shouldRetry()) {<a name="line.2554"></a>
+<span class="sourceLineNo">2555</span>      int index = getMiniHBaseCluster().getServerWith(firstrow);<a name="line.2555"></a>
+<span class="sourceLineNo">2556</span>      if (index != -1) {<a name="line.2556"></a>
+<span class="sourceLineNo">2557</span>        return getMiniHBaseCluster().getRegionServerThreads().get(index).getRegionServer();<a name="line.2557"></a>
+<span class="sourceLineNo">2558</span>      }<a name="line.2558"></a>
+<span class="sourceLineNo">2559</span>      // Came back -1.  Region may not be online yet.  Sleep a while.<a name="line.2559"></a>
+<span class="sourceLineNo">2560</span>      retrier.sleepUntilNextRetry();<a name="line.2560"></a>
+<span class="sourceLineNo">2561</span>    }<a name="line.2561"></a>
+<span class="sourceLineNo">2562</span>    return null;<a name="line.2562"></a>
 <span class="sourceLineNo">2563</span>  }<a name="line.2563"></a>
 <span class="sourceLineNo">2564</span><a name="line.2564"></a>
 <span class="sourceLineNo">2565</span>  /**<a name="line.2565"></a>
-<span class="sourceLineNo">2566</span>   * Tasktracker has a bug where changing the hadoop.log.dir system property<a name="line.2566"></a>
-<span class="sourceLineNo">2567</span>   * will not change its internal static LOG_DIR variable.<a name="line.2567"></a>
-<span class="sourceLineNo">2568</span>   */<a name="line.2568"></a>
-<span class="sourceLineNo">2569</span>  private void forceChangeTaskLogDir() {<a name="line.2569"></a>
-<span class="sourceLineNo">2570</span>    Field logDirField;<a name="line.2570"></a>
-<span class="sourceLineNo">2571</span>    try {<a name="line.2571"></a>
-<span class="sourceLineNo">2572</span>      logDirField = TaskLog.class.getDeclaredField("LOG_DIR");<a name="line.2572"></a>
-<span class="sourceLineNo">2573</span>      logDirField.setAccessible(true);<a name="line.2573"></a>
-<span class="sourceLineNo">2574</span><a name="line.2574"></a>
-<span class="sourceLineNo">2575</span>      Field modifiersField = Field.class.getDeclaredField("modifiers");<a name="line.2575"></a>
-<span class="sourceLineNo">2576</span>      modifiersField.setAccessible(true);<a name="line.2576"></a>
-<span class="sourceLineNo">2577</span>      modifiersField.setInt(logDirField, logDirField.getModifiers() &amp; ~Modifier.FINAL);<a name="line.2577"></a>
-<span class="sourceLineNo">2578</span><a name="line.2578"></a>
-<span class="sourceLineNo">2579</span>      logDirField.set(null, new File(hadoopLogDir, "userlogs"));<a name="line.2579"></a>
-<span class="sourceLineNo">2580</span>    } catch (SecurityException e) {<a name="line.2580"></a>
-<span class="sourceLineNo">2581</span>      throw new RuntimeException(e);<a name="line.2581"></a>
-<span class="sourceLineNo">2582</span>    } catch (NoSuchFieldException e) {<a name="line.2582"></a>
-<span class="sourceLineNo">2583</span>      // TODO Auto-generated catch block<a name="line.2583"></a>
-<span class="sourceLineNo">2584</span>      throw new RuntimeException(e);<a name="line.2584"></a>
-<span class="sourceLineNo">2585</span>    } catch (IllegalArgumentException e) {<a name="line.2585"></a>
-<span class="sourceLineNo">2586</span>      throw new RuntimeException(e);<a name="line.2586"></a>
-<span class="sourceLineNo">2587</span>    } catch (IllegalAccessException e) {<a name="line.2587"></a>
-<span class="sourceLineNo">2588</span>      throw new RuntimeException(e);<a name="line.2588"></a>
-<span class="sourceLineNo">2589</span>    }<a name="line.2589"></a>
-<span class="sourceLineNo">2590</span>  }<a name="line.2590"></a>
-<span class="sourceLineNo">2591</span><a name="line.2591"></a>
-<span class="sourceLineNo">2592</span>  /**<a name="line.2592"></a>
-<span class="sourceLineNo">2593</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt;. Call {@link #setFileSystemURI(String)} to use a different<a name="line.2593"></a>
-<span class="sourceLineNo">2594</span>   * filesystem.<a name="line.2594"></a>
-<span class="sourceLineNo">2595</span>   * @param servers  The number of &lt;code&gt;TaskTracker&lt;/code&gt;'s to start.<a name="line.2595"></a>
-<span class="sourceLineNo">2596</span>   * @throws IOException When starting the cluster fails.<a name="line.2596"></a>
-<span class="sourceLineNo">2597</span>   */<a name="line.2597"></a>
-<span class="sourceLineNo">2598</span>  private void startMiniMapReduceCluster(final int servers) throws IOException {<a name="line.2598"></a>
-<span class="sourceLineNo">2599</span>    if (mrCluster != null) {<a name="line.2599"></a>
-<span class="sourceLineNo">2600</span>      throw new IllegalStateException("MiniMRCluster is already running");<a name="line.2600"></a>
-<span class="sourceLineNo">2601</span>    }<a name="line.2601"></a>
-<span class="sourceLineNo">2602</span>    LOG.info("Starting mini mapreduce cluster...");<a name="line.2602"></a>
-<span class="sourceLineNo">2603</span>    setupClusterTestDir();<a name="line.2603"></a>
-<span class="sourceLineNo">2604</span>    createDirsAndSetProperties();<a name="line.2604"></a>
-<span class="sourceLineNo">2605</span><a name="line.2605"></a>
-<span class="sourceLineNo">2606</span>    forceChangeTaskLogDir();<a name="line.2606"></a>
-<span class="sourceLineNo">2607</span><a name="line.2607"></a>
-<span class="sourceLineNo">2608</span>    //// hadoop2 specific settings<a name="line.2608"></a>
-<span class="sourceLineNo">2609</span>    // Tests were failing because this process used 6GB of virtual memory and was getting killed.<a name="line.2609"></a>
-<span class="sourceLineNo">2610</span>    // we up the VM usable so that processes don't get killed.<a name="line.2610"></a>
-<span class="sourceLineNo">2611</span>    conf.setFloat("yarn.nodemanager.vmem-pmem-ratio", 8.0f);<a name="line.2611"></a>
-<span class="sourceLineNo">2612</span><a name="line.2612"></a>
-<span class="sourceLineNo">2613</span>    // Tests were failing due to MAPREDUCE-4880 / MAPREDUCE-4607 against hadoop 2.0.2-alpha and<a name="line.2613"></a>
-<span class="sourceLineNo">2614</span>    // this avoids the problem by disabling speculative task execution in tests.<a name="line.2614"></a>
-<span class="sourceLineNo">2615</span>    conf.setBoolean("mapreduce.map.speculative", false);<a name="line.2615"></a>
-<span class="sourceLineNo">2616</span>    conf.setBoolean("mapreduce.reduce.speculative", false);<a name="line.2616"></a>
-<span class="sourceLineNo">2617</span>    ////<a name="line.2617"></a>
-<span class="sourceLineNo">2618</span><a name="line.2618"></a>
-<span class="sourceLineNo">2619</span>    // Allow the user to override FS URI for this map-reduce cluster to use.<a name="line.2619"></a>
-<span class="sourceLineNo">2620</span>    mrCluster = new MiniMRCluster(servers,<a name="line.2620"></a>
-<span class="sourceLineNo">2621</span>      FS_URI != null ? FS_URI : FileSystem.get(conf).getUri().toString(), 1,<a name="line.2621"></a>
-<span class="sourceLineNo">2622</span>      null, null, new JobConf(this.conf));<a name="line.2622"></a>
-<span class="sourceLineNo">2623</span>    JobConf jobConf = MapreduceTestingShim.getJobConf(mrCluster);<a name="line.2623"></a>
-<span class="sourceLineNo">2624</span>    if (jobConf == null) {<a name="line.2624"></a>
-<span class="sourceLineNo">2625</span>      jobConf = mrCluster.createJobConf();<a name="line.2625"></a>
-<span class="sourceLineNo">2626</span>    }<a name="line.2626"></a>
+<span class="sourceLineNo">2566</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt; with a default number of<a name="line.2566"></a>
+<span class="sourceLineNo">2567</span>   * &lt;code&gt;TaskTracker&lt;/code&gt;'s.<a name="line.2567"></a>
+<span class="sourceLineNo">2568</span>   *<a name="line.2568"></a>
+<span class="sourceLineNo">2569</span>   * @throws IOException When starting the cluster fails.<a name="line.2569"></a>
+<span class="sourceLineNo">2570</span>   */<a name="line.2570"></a>
+<span class="sourceLineNo">2571</span>  public MiniMRCluster startMiniMapReduceCluster() throws IOException {<a name="line.2571"></a>
+<span class="sourceLineNo">2572</span>    // Set a very high max-disk-utilization percentage to avoid the NodeManagers from failing.<a name="line.2572"></a>
+<span class="sourceLineNo">2573</span>    conf.setIfUnset(<a name="line.2573"></a>
+<span class="sourceLineNo">2574</span>        "yarn.nodemanager.disk-health-checker.max-disk-utilization-per-disk-percentage",<a name="line.2574"></a>
+<span class="sourceLineNo">2575</span>        "99.0");<a name="line.2575"></a>
+<span class="sourceLineNo">2576</span>    startMiniMapReduceCluster(2);<a name="line.2576"></a>
+<span class="sourceLineNo">2577</span>    return mrCluster;<a name="line.2577"></a>
+<span class="sourceLineNo">2578</span>  }<a name="line.2578"></a>
+<span class="sourceLineNo">2579</span><a name="line.2579"></a>
+<span class="sourceLineNo">2580</span>  /**<a name="line.2580"></a>
+<span class="sourceLineNo">2581</span>   * Tasktracker has a bug where changing the hadoop.log.dir system property<a name="line.2581"></a>
+<span class="sourceLineNo">2582</span>   * will not change its internal static LOG_DIR variable.<a name="line.2582"></a>
+<span class="sourceLineNo">2583</span>   */<a name="line.2583"></a>
+<span class="sourceLineNo">2584</span>  private void forceChangeTaskLogDir() {<a name="line.2584"></a>
+<span class="sourceLineNo">2585</span>    Field logDirField;<a name="line.2585"></a>
+<span class="sourceLineNo">2586</span>    try {<a name="line.2586"></a>
+<span class="sourceLineNo">2587</span>      logDirField = TaskLog.class.getDeclaredField("LOG_DIR");<a name="line.2587"></a>
+<span class="sourceLineNo">2588</span>      logDirField.setAccessible(true);<a name="line.2588"></a>
+<span class="sourceLineNo">2589</span><a name="line.2589"></a>
+<span class="sourceLineNo">2590</span>      Field modifiersField = Field.class.getDeclaredField("modifiers");<a name="line.2590"></a>
+<span class="sourceLineNo">2591</span>      modifiersField.setAccessible(true);<a name="line.2591"></a>
+<span class="sourceLineNo">2592</span>      modifiersField.setInt(logDirField, logDirField.getModifiers() &amp; ~Modifier.FINAL);<a name="line.2592"></a>
+<span class="sourceLineNo">2593</span><a name="line.2593"></a>
+<span class="sourceLineNo">2594</span>      logDirField.set(null, new File(hadoopLogDir, "userlogs"));<a name="line.2594"></a>
+<span class="sourceLineNo">2595</span>    } catch (SecurityException e) {<a name="line.2595"></a>
+<span class="sourceLineNo">2596</span>      throw new RuntimeException(e);<a name="line.2596"></a>
+<span class="sourceLineNo">2597</span>    } catch (NoSuchFieldException e) {<a name="line.2597"></a>
+<span class="sourceLineNo">2598</span>      // TODO Auto-generated catch block<a name="line.2598"></a>
+<span class="sourceLineNo">2599</span>      throw new RuntimeException(e);<a name="line.2599"></a>
+<span class="sourceLineNo">2600</span>    } catch (IllegalArgumentException e) {<a name="line.2600"></a>
+<span class="sourceLineNo">2601</span>      throw new RuntimeException(e);<a name="line.2601"></a>
+<span class="sourceLineNo">2602</span>    } catch (IllegalAccessException e) {<a name="line.2602"></a>
+<span class="sourceLineNo">2603</span>      throw new RuntimeException(e);<a name="line.2603"></a>
+<span class="sourceLineNo">2604</span>    }<a name="line.2604"></a>
+<span class="sourceLineNo">2605</span>  }<a name="line.2605"></a>
+<span class="sourceLineNo">2606</span><a name="line.2606"></a>
+<span class="sourceLineNo">2607</span>  /**<a name="line.2607"></a>
+<span class="sourceLineNo">2608</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt;. Call {@link #setFileSystemURI(String)} to use a different<a name="line.2608"></a>
+<span class="sourceLineNo">2609</span>   * filesystem.<a name="line.2609"></a>
+<span class="sourceLineNo">2610</span>   * @param servers  The number of &lt;code&gt;TaskTracker&lt;/code&gt;'s to start.<a name="line.2610"></a>
+<span class="sourceLineNo">2611</span>   * @throws IOException When starting the cluster fails.<a name="line.2611"></a>
+<span class="sourceLineNo">2612</span>   */<a name="line.2612"></a>
+<span class="sourceLineNo">2613</span>  private void startMiniMapReduceCluster(final int servers) throws IOException {<a name="line.2613"></a>
+<span class="sourceLineNo">2614</span>    if (mrCluster != null) {<a name="line.2614"></a>
+<span class="sourceLineNo">2615</span>      throw new IllegalStateException("MiniMRCluster is already running");<a name="line.2615"></a>
+<span class="sourceLineNo">2616</span>    }<a name="line.2616"></a>
+<span class="sourceLineNo">2617</span>    LOG.info("Starting mini mapreduce cluster...");<a name="line.2617"></a>
+<span class="sourceLineNo">2618</span>    setupClusterTestDir();<a name="line.2618"></a>
+<span class="sourceLineNo">2619</span>    createDirsAndSetProperties();<a name="line.2619"></a>
+<span class="sourceLineNo">2620</span><a name="line.2620"></a>
+<span class="sourceLineNo">2621</span>    forceChangeTaskLogDir();<a name="line.2621"></a>
+<span class="sourceLineNo">2622</span><a name="line.2622"></a>
+<span class="sourceLineNo">2623</span>    //// hadoop2 specific settings<a name="line.2623"></a>
+<span class="sourceLineNo">2624</span>    // Tests were failing because this process used 6GB of virtual memory and was getting killed.<a name="line.2624"></a>
+<span class="sourceLineNo">2625</span>    // we up the VM usable so that processes don't get killed.<a name="line.2625"></a>
+<span class="sourceLineNo">2626</span>    conf.setFloat("yarn.nodemanager.vmem-pmem-ratio", 8.0f);<a name="line.2626"></a>
 <span class="sourceLineNo">2627</span><a name="line.2627"></a>
-<span class="sourceLineNo">2628</span>    jobConf.set("mapreduce.cluster.local.dir",<a name="line.2628"></a>
-<span class="sourceLineNo">2629</span>      conf.get("mapreduce.cluster.local.dir")); //Hadoop MiniMR overwrites this while it should not<a name="line.2629"></a>
-<span class="sourceLineNo">2630</span>    LOG.info("Mini mapreduce cluster started");<a name="line.2630"></a>
-<span class="sourceLineNo">2631</span><a name="line.2631"></a>
-<span class="sourceLineNo">2632</span>    // In hadoop2, YARN/MR2 starts a mini cluster with its own conf instance and updates settings.<a name="line.2632"></a>
-<span class="sourceLineNo">2633</span>    // Our HBase MR jobs need several of these settings in order to properly run.  So we copy the<a name="line.2633"></a>
-<span class="sourceLineNo">2634</span>    // necessary config properties here.  YARN-129 required adding a few properties.<a name="line.2634"></a>
-<span class="sourceLineNo">2635</span>    conf.set("mapreduce.jobtracker.address", jobConf.get("mapreduce.jobtracker.address"));<a name="line.2635"></a>
-<span class="sourceLineNo">2636</span>    // this for mrv2 support; mr1 ignores this<a name="line.2636"></a>
-<span class="sourceLineNo">2637</span>    conf.set("mapreduce.framework.name", "yarn");<a name="line.2637"></a>
-<span class="sourceLineNo">2638</span>    conf.setBoolean("yarn.is.minicluster", true);<a name="line.2638"></a>
-<span class="sourceLineNo">2639</span>    String rmAddress = jobConf.get("yarn.resourcemanager.address");<a name="line.2639"></a>
-<span class="sourceLineNo">2640</span>    if (rmAddress != null) {<a name="line.2640"></a>
-<span class="sourceLineNo">2641</span>      conf.set("yarn.resourcemanager.address", rmAddress);<a name="line.2641"></a>
-<span class="sourceLineNo">2642</span>    }<a name="line.2642"></a>
-<span class="sourceLineNo">2643</span>    String historyAddress = jobConf.get("mapreduce.jobhistory.address");<a name="line.2643"></a>
-<span class="sourceLineNo">2644</span>    if (historyAddress != null) {<a name="line.2644"></a>
-<span class="sourceLineNo">2645</span>      conf.set("mapreduce.jobhistory.address", historyAddress);<a name="line.2645"></a>
-<span class="sourceLineNo">2646</span>    }<a name="line.2646"></a>
-<span class="sourceLineNo">2647</span>    String schedulerAddress =<a name="line.2647"></a>
-<span class="sourceLineNo">2648</span>      jobConf.get("yarn.resourcemanager.scheduler.address");<a name="line.2648"></a>
-<span class="sourceLineNo">2649</span>    if (schedulerAddress != null) {<a name="line.2649"></a>
-<span class="sourceLineNo">2650</span>      conf.set("yarn.resourcemanager.scheduler.address", schedulerAddress);<a name="line.2650"></a>
-<span class="sourceLineNo">2651</span>    }<a name="line.2651"></a>
-<span class="sourceLineNo">2652</span>    String mrJobHistoryWebappAddress =<a name="line.2652"></a>
-<span class="sourceLineNo">2653</span>      jobConf.get("mapreduce.jobhistory.webapp.address");<a name="line.2653"></a>
-<span class="sourceLineNo">2654</span>    if (mrJobHistoryWebappAddress != null) {<a name="line.2654"></a>
-<span class="sourceLineNo">2655</span>      conf.set("mapreduce.jobhistory.webapp.address", mrJobHistoryWebappAddress);<a name="line.2655"></a>
-<span class="sourceLineNo">2656</span>    }<a name="line.2656"></a>
-<span class="sourceLineNo">2657</span>    String yarnRMWebappAddress =<a name="line.2657"></a>
-<span class="sourceLineNo">2658</span>      jobConf.get("yarn.resourcemanager.webapp.address");<a name="line.2658"></a>
-<span class="sourceLineNo">2659</span>    if (yarnRMWebappAddress != null) {<a name="line.2659"></a>
-<span class="sourceLineNo">2660</span>      conf.set("yarn.resourcemanager.webapp.address", yarnRMWebappAddress);<a name="line.2660"></a>
+<span class="sourceLineNo">2628</span>    // Tests were failing due to MAPREDUCE-4880 / MAPREDUCE-4607 against hadoop 2.0.2-alpha and<a name="line.2628"></a>
+<span class="sourceLineNo">2629</span>    // this avoids the problem by disabling speculative task execution in tests.<a name="line.2629"></a>
+<span class="sourceLineNo">2630</span>    conf.setBoolean("mapreduce.map.speculative", false);<a name="line.2630"></a>
+<span class="sourceLineNo">2631</span>    conf.setBoolean("mapreduce.reduce.speculative", false);<a name="line.2631"></a>
+<span class="sourceLineNo">2632</span>    ////<a name="line.2632"></a>
+<span class="sourceLineNo">2633</span><a name="line.2633"></a>
+<span class="sourceLineNo">2634</span>    // Allow the user to override FS URI for this map-reduce cluster to use.<a name="line.2634"></a>
+<span class="sourceLineNo">2635</span>    mrCluster = new MiniMRCluster(servers,<a name="line.2635"></a>
+<span class="sourceLineNo">2636</span>      FS_URI != null ? FS_URI : FileSystem.get(conf).getUri().toString(), 1,<a name="line.2636"></a>
+<span class="sourceLineNo">2637</span>      null, null, new JobConf(this.conf));<a name="line.2637"></a>
+<span class="sourceLineNo">2638</span>    JobConf jobConf = MapreduceTestingShim.getJobConf(mrCluster);<a name="line.2638"></a>
+<span class="sourceLineNo">2639</span>    if (jobConf == null) {<a name="line.2639"></a>
+<span class="sourceLineNo">2640</span>      jobConf = mrCluster.createJobConf();<a name="line.2640"></a>
+<span class="sourceLineNo">2641</span>    }<a name="line.2641"></a>
+<span class="sourceLineNo">2642</span><a name="line.2642"></a>
+<span class="sourceLineNo">2643</span>    jobConf.set("mapreduce.cluster.local.dir",<a name="line.2643"></a>
+<span class="sourceLineNo">2644</span>      conf.get("mapreduce.cluster.local.dir")); //Hadoop MiniMR overwrites this while it should not<a name="line.2644"></a>
+<span class="sourceLineNo">2645</span>    LOG.info("Mini mapreduce cluster started");<a name="line.2645"></a>
+<span class="sourceLineNo">2646</span><a name="line.2646"></a>
+<span class="sourceLineNo">2647</span>    // In hadoop2, YARN/MR2 starts a mini cluster with its own conf instance and updates settings.<a name="line.2647"></a>
+<span class="sourceLineNo">2648</span>    // Our HBase MR jobs need several of these settings in order to properly run.  So we copy the<a name="line.2648"></a>
+<span class="sourceLineNo">2649</span>    // necessary config properties here.  YARN-129 required adding a few properties.<a name="line.2649"></a>
+<span class="sourceLineNo">2650</span>    conf.set("mapreduce.jobtracker.address", jobConf.get("mapreduce.jobtracker.address"));<a name="line.2650"></a>
+<span class="sourceLineNo">2651</span>    // this for mrv2 support; mr1 ignores this<a name="line.2651"></a>
+<span class="sourceLineNo">2652</span>    conf.set("mapreduce.framework.name", "yarn");<a name="line.2652"></a>
+<span class="sourceLineNo">2653</span>    conf.setBoolean("yarn.is.minicluster", true);<a name="line.2653"></a>
+<span class="sourceLineNo">2654</span>    String rmAddress = jobConf.get("yarn.resourcemanager.address");<a name="line.2654"></a>
+<span class="sourceLineNo">2655</span>    if (rmAddress != null) {<a name="line.2655"></a>
+<span class="sourceLineNo">2656</span>      conf.set("yarn.resourcemanager.address", rmAddress);<a name="line.2656"></a>
+<span class="sourceLineNo">2657</span>    }<a name="line.2657"></a>
+<span class="sourceLineNo">2658</span>    String historyAddress = jobConf.get("mapreduce.jobhistory.address");<a name="line.2658"></a>
+<span class="sourceLineNo">2659</span>    if (historyAddress != null) {<a name="line.2659"></a>
+<span class="sourceLineNo">2660</span>      conf.set("mapreduce.jobhistory.address", historyAddress);<a name="line.2660"></a>
 <span class="sourceLineNo">2661</span>    }<a name="line.2661"></a>
-<span class="sourceLineNo">2662</span>  }<a name="line.2662"></a>
-<span class="sourceLineNo">2663</span><a name="line.2663"></a>
-<span class="sourceLineNo">2664</span>  /**<a name="line.2664"></a>
-<span class="sourceLineNo">2665</span>   * Stops the previously started &lt;code&gt;MiniMRCluster&lt;/code&gt;.<a name="line.2665"></a>
-<span class="sourceLineNo">2666</span>   */<a name="line.2666"></a>
-<span class="sourceLineNo">2667</span>  public void shutdownMiniMapReduceCluster() {<a name="line.2667"></a>
-<span class="sourceLineNo">2668</span>    if (mrCluster != null) {<a name="line.2668"></a>
-<span class="sourceLineNo">2669</span>      LOG.info("Stopping mini mapreduce cluster...");<a name="line.2669"></a>
-<span class="sourceLineNo">2670</span>      mrCluster.shutdown();<a name="line.2670"></a>
-<span class="sourceLineNo">2671</span>      mrCluster = null;<a name="line.2671"></a>
-<span class="sourceLineNo">2672</span>      LOG.info("Mini mapreduce cluster stopped");<a name="line.2672"></a>
-<span class="sourceLineNo">2673</span>    }<a name="line.2673"></a>
-<span class="sourceLineNo">2674</span>    // Restore configuration to point to local jobtracker<a name="line.2674"></a>
-<span class="sourceLineNo">2675</span>    conf.set("mapreduce.jobtracker.address", "local");<a name="line.2675"></a>
-<span class="sourceLineNo">2676</span>  }<a name="line.2676"></a>
-<span class="sourceLineNo">2677</span><a name="line.2677"></a>
-<span class="sourceLineNo">2678</span>  /**<a name="line.2678"></a>
-<span class="sourceLineNo">2679</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2679"></a>
-<span class="sourceLineNo">2680</span>   */<a name="line.2680"></a>
-<span class="sourceLineNo">2681</span>  public RegionServerServices createMockRegionServerService() throws IOException {<a name="line.2681"></a>
-<span class="sourceLineNo">2682</span>    return createMockRegionServerService((ServerName)null);<a name="line.2682"></a>
-<span class="sourceLineNo">2683</span>  }<a name="line.2683"></a>
-<span class="sourceLineNo">2684</span><a name="line.2684"></a>
-<span class="sourceLineNo">2685</span>  /**<a name="line.2685"></a>
-<span class="sourceLineNo">2686</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2686"></a>
-<span class="sourceLineNo">2687</span>   * This version is used by TestTokenAuthentication<a name="line.2687"></a>
-<span class="sourceLineNo">2688</span>   */<a name="line.2688"></a>
-<span class="sourceLineNo">2689</span>  public RegionServerServices createMockRegionServerService(RpcServerInterface rpc) throws<a name="line.2689"></a>
-<span class="sourceLineNo">2690</span>      IOException {<a name="line.2690"></a>
-<span class="sourceLineNo">2691</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher());<a name="line.2691"></a>
-<span class="sourceLineNo">2692</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2692"></a>
-<span class="sourceLineNo">2693</span>    rss.setRpcServer(rpc);<a name="line.2693"></a>
-<span class="sourceLineNo">2694</span>    return rss;<a name="line.2694"></a>
-<span class="sourceLineNo">2695</span>  }<a name="line.2695"></a>
-<span class="sourceLineNo">2696</span><a name="line.2696"></a>
-<span class="sourceLineNo">2697</span>  /**<a name="line.2697"></a>
-<span class="sourceLineNo">2698</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2698"></a>
-<span class="sourceLineNo">2699</span>   * This version is used by TestOpenRegionHandler<a name="line.2699"></a>
-<span class="sourceLineNo">2700</span>   */<a name="line.2700"></a>
-<span class="sourceLineNo">2701</span>  public RegionServerServices createMockRegionServerService(ServerName name) throws IOException {<a name="line.2701"></a>
-<span class="sourceLineNo">2702</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher(), name);<a name="line.2702"></a>
-<span class="sourceLineNo">2703</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2703"></a>
-<span class="sourceLineNo">2704</span>    return rss;<a name="line.2704"></a>
-<span class="sourceLineNo">2705</span>  }<a name="line.2705"></a>
-<span class="sourceLineNo">2706</span><a name="line.2706"></a>
-<span class="sourceLineNo">2707</span>  /**<a name="line.2707"></a>
-<span class="sourceLineNo">2708</span>   * Switches the logger for the given class to DEBUG level.<a name="line.2708"></a>
-<span class="sourceLineNo">2709</span>   *<a name="line.2709"></a>
-<span class="sourceLineNo">2710</span>   * @param clazz  The class for which to switch to debug logging.<a name="line.2710"></a>
-<span class="sourceLineNo">2711</span>   */<a name="line.2711"></a>
-<span class="sourceLineNo">2712</span>  public void enableDebug(Class&lt;?&gt; clazz) {<a name="line.2712"></a>
-<span class="sourceLineNo">2713</span>    Log l = LogFactory.getLog(clazz);<a name="line.2713"></a>
-<span class="sourceLineNo">2714</span>    if (l instanceof Log4JLogger) {<a name="line.2714"></a>
-<span class="sourceLineNo">2715</span>      ((Log4JLogger) l).getLogger().setLevel(org.apache.log4j.Level.DEBUG);<a name="line.2715"></a>
-<span class="sourceLineNo">2716</span>    } else if (l instanceof Jdk14Logger) {<a name="line.2716"></a>
-<span class="sourceLineNo">2717</span>      ((Jdk14Logger) l).getLogger().setLevel(java.util.logging.Level.ALL);<a name="line.2717"></a>
-<span class="sourceLineNo">2718</span>    }<a name="line.2718"></a>
-<span class="sourceLineNo">2719</span>  }<a name="line.2719"></a>
-<span class="sourceLineNo">2720</span><a name="line.2720"></a>
-<span class="sourceLineNo">2721</span>  /**<a name="line.2721"></a>
-<span class="sourceLineNo">2722</span>   * Expire the Master's session<a name="line.2722"></a>
-<span class="sourceLineNo">2723</span>   * @throws Exception<a name="line.2723"></a>
-<span class="sourceLineNo">2724</span>   */<a name="line.2724"></a>
-<span class="sourceLineNo">2725</span>  public void expireMasterSession() throws Exception {<a name="line.2725"></a>
-<span class="sourceLineNo">2726</span>    HMaster master = getMiniHBaseCluster().getMaster();<a name="line.2726"></a>
-<span class="sourceLineNo">2727</span>    expireSession(master.getZooKeeper(), false);<a name="line.2727"></a>
-<span class="sourceLineNo">2728</span>  }<a name="line.2728"></a>
-<span class="sourceLineNo">2729</span><a name="line.2729"></a>
-<span class="sourceLineNo">2730</span>  /**<a name="line.2730"></a>
-<span class="sourceLineNo">2731</span>   * Expire a region server's session<a name="line.2731"></a>
-<span class="sourceLineNo">2732</span>   * @param index which RS<a name="line.2732"></a>
-<span class="sourceLineNo">2733</span>   * @throws Exception<a name="line.2733"></a>
-<span class="sourceLineNo">2734</span>   */<a name="line.2734"></a>
-<span class="sourceLineNo">2735</span>  public void expireRegionServerSession(int index) throws Exception {<a name="line.2735"></a>
-<span class="sourceLineNo">2736</span>    HRegionServer rs = getMiniHBaseCluster().getRegionServer(index);<a name="line.2736"></a>
-<span class="sourceLineNo">2737</span>    expireSession(rs.getZooKeeper(), false);<a name="line.2737"></a>
-<span class="sourceLineNo">2738</span>    decrementMinRegionServerCount();<a name="line.2738"></a>
-<span class="sourceLineNo">2739</span>  }<a name="line.2739"></a>
-<span class="sourceLineNo">2740</span><a name="line.2740"></a>
-<span class="sourceLineNo">2741</span>  private void decrementMinRegionServerCount() {<a name="line.2741"></a>
-<span class="sourceLineNo">2742</span>    // decrement the count for this.conf, for newly spwaned master<a name="line.2742"></a>
-<span class="sourceLineNo">2743</span>    // this.hbaseCluster shares this configuration too<a name="line.2743"></a>
-<span class="sourceLineNo">2744</span>    decrementMinRegionServerCount(getConfiguration());<a name="line.2744"></a>
-<span class="sourceLineNo">2745</span><a name="line.2745"></a>
-<span class="sourceLineNo">2746</span>    // each master thread keeps a copy of configuration<a name="line.2746"></a>
-<span class="sourceLineNo">2747</span>    for (MasterThread master : getHBaseCluster().getMasterThreads()) {<a name="line.2747"></a>
-<span class="sourceLineNo">2748</span>      decrementMinRegionServerCount(master.getMaster().getConfiguration());<a name="line.2748"></a>
-<span class="sourceLineNo">2749</span>    }<a name="line.2749"></a>
-<span class="sourceLineNo">2750</span>  }<a name="line.2750"></a>
-<span class="sourceLineNo">2751</span><a name="line.2751"></a>
-<span class="sourceLineNo">2752</span>  private void decrementMinRegionServerCount(Configuration conf) {<a name="line.2752"></a>
-<span class="sourceLineNo">2753</span>    int currentCount = conf.getInt(<a name="line.2753"></a>
-<span class="sourceLineNo">2754</span>        ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART, -1);<a name="line.2754"></a>
-<span class="sourceLineNo">2755</span>    if (currentCount != -1) {<a name="line.2755"></a>
-<span class="sourceLineNo">2756</span>      conf.setInt(ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART,<a name="line.2756"></a>
-<span class="sourceLineNo">2757</span>          Math.max(currentCount - 1, 1));<a name="line.2757"></a>
-<span class="sourceLineNo">2758</span>    }<a name="line.2758"></a>
-<span class="sourceLineNo">2759</span>  }<a name="line.2759"></a>
+<span class="sourceLineNo">2662</span>    String schedulerAddress =<a name="line.2662"></a>
+<span class="sourceLineNo">2663</span>      jobConf.get("yarn.resourcemanager.scheduler.address");<a name="line.2663"></a>
+<span class="sourceLineNo">2664</span>    if (schedulerAddress != null) {<a name="line.2664"></a>
+<span class="sourceLineNo">2665</span>      conf.set("yarn.resourcemanager.scheduler.address", schedulerAddress);<a name="line.2665"></a>
+<span class="sourceLineNo">2666</span>    }<a name="line.2666"></a>
+<span class="sourceLineNo">2667</span>    String mrJobHistoryWebappAddress =<a name="line.2667"></a>
+<span class="sourceLineNo">2668</span>      jobConf.get("mapreduce.jobhistory.webapp.address");<a name="line.2668"></a>
+<span class="sourceLineNo">2669</span>    if (mrJobHistoryWebappAddress != null) {<a name="line.2669"></a>
+<span class="sourceLineNo">2670</span>      conf.set("mapreduce.jobhistory.webapp.address", mrJobHistoryWebappAddress);<a name="line.2670"></a>
+<span class="sourceLineNo">2671</span>    }<a name="line.2671"></a>
+<span class="sourceLineNo">2672</span>    String yarnRMWebappAddress =<a name="line.2672"></a>
+<span class="sourceLineNo">2673</span>      jobConf.get("yarn.resourcemanager.webapp.address");<a name="line.2673"></a>
+<span class="sourceLineNo">2674</span>    if (yarnRMWebappAddress != null) {<a name="line.2674"></a>
+<span class="sourceLineNo">2675</span>      conf.set("yarn.resourcemanager.webapp.address", yarnRMWebappAddress);<a name="line.2675"></a>
+<span class="sourceLineNo">2676</span>    }<a name="line.2676"></a>
+<span class="sourceLineNo">2677</span>  }<a name="line.2677"></a>
+<span class="sourceLineNo">2678</span><a name="line.2678"></a>
+<span class="sourceLineNo">2679</span>  /**<a name="line.2679"></a>
+<span class="sourceLineNo">2680</span>   * Stops the previously started &lt;code&gt;MiniMRCluster&lt;/code&gt;.<a name="line.2680"></a>
+<span class="sourceLineNo">2681</span>   */<a name="line.2681"></a>
+<span class="sourceLineNo">2682</span>  public void shutdownMiniMapReduceCluster() {<a name="line.2682"></a>
+<span class="sourceLineNo">2683</span>    if (mrCluster != null) {<a name="line.2683"></a>
+<span class="sourceLineNo">2684</span>      LOG.info("Stopping mini mapreduce cluster...");<a name="line.2684"></a>
+<span class="sourceLineNo">2685</span>      mrCluster.shutdown();<a name="line.2685"></a>
+<span class="sourceLineNo">2686</span>      mrCluster = null;<a name="line.2686"></a>
+<span class="sourceLineNo">2687</span>      LOG.info("Mini mapreduce cluster stopped");<a name="line.2687"></a>
+<span class="sourceLineNo">2688</span>    }<a name="line.2688"></a>
+<span class="sourceLineNo">2689</span>    // Restore configuration to point to local jobtracker<a name="line.2689"></a>
+<span class="sourceLineNo">2690</span>    conf.set("mapreduce.jobtracker.address", "local");<a name="line.2690"></a>
+<span class="sourceLineNo">2691</span>  }<a name="line.2691"></a>
+<span class="sourceLineNo">2692</span><a name="line.2692"></a>
+<span class="sourceLineNo">2693</span>  /**<a name="line.2693"></a>
+<span class="sourceLineNo">2694</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2694"></a>
+<span class="sourceLineNo">2695</span>   */<a name="line.2695"></a>
+<span class="sourceLineNo">2696</span>  public RegionServerServices createMockRegionServerService() throws IOException {<a name="line.2696"></a>
+<span class="sourceLineNo">2697</span>    return createMockRegionServerService((ServerName)null);<a name="line.2697"></a>
+<span class="sourceLineNo">2698</span>  }<a name="line.2698"></a>
+<span class="sourceLineNo">2699</span><a name="line.2699"></a>
+<span class="sourceLineNo">2700</span>  /**<a name="line.2700"></a>
+<span class="sourceLineNo">2701</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2701"></a>
+<span class="sourceLineNo">2702</span>   * This version is used by TestTokenAuthentication<a name="line.2702"></a>
+<span class="sourceLineNo">2703</span>   */<a name="line.2703"></a>
+<span class="sourceLineNo">2704</span>  public RegionServerServices createMockRegionServerService(RpcServerInterface rpc) throws<a name="line.2704"></a>
+<span class="sourceLineNo">2705</span>      IOException {<a name="line.2705"></a>
+<span class="sourceLineNo">2706</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher());<a name="line.2706"></a>
+<span class="sourceLineNo">2707</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2707"></a>
+<span class="sourceLineNo">2708</span>    rss.setRpcServer(rpc);<a name="line.2708"></a>
+<span class="sourceLineNo">2709</span>    return rss;<a name="line.2709"></a>
+<span class="sourceLineNo">2710</span>  }<a name="line.2710"></a>
+<span class="sourceLineNo">2711</span><a name="line.2711"></a>
+<span class="sourceLineNo">2712</span>  /**<a name="line.2712"></a>
+<span class="sourceLineNo">2713</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2713"></a>
+<span class="sourceLineNo">2714</span>   * This version is used by TestOpenRegionHandler<a name="line.2714"></a>
+<span class="sourceLineNo">2715</span>   */<a name="line.2715"></a>
+<span class="sourceLineNo">2716</span>  public RegionServerServices createMockRegionServerService(ServerName name) throws IOException {<a name="line.2716"></a>
+<span class="sourceLineNo">2717</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher(), name);<a name="line.2717"></a>
+<span class="sourceLineNo">2718</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2718"></a>
+<span class="sourceLineNo">2719</span>    return rss;<a name="line.2719"></a>
+<span class="sourceLineNo">2720</span>  }<a name="line.2720"></a>
+<span class="sourceLineNo">2721</span><a name="line.2721"></a>
+<span class="sourceLineNo">2722</span>  /**<a name="line.2722"></a>
+<span class="sourceLineNo">2723</span>   * Switches the logger for the given class to DEBUG level.<a name="line.2723"></a>
+<span class="sourceLineNo">2724</span>   *<a name="line.2724"></a>
+<span class="sourceLineNo">2725</span>   * @param clazz  The class for which to switch to debug logging.<a name="line.2725"></a>
+<span class="sourceLineNo">2726</span>   */<a name="line.2726"></a>
+<span class="sourceLineNo">2727</span>  public void enableDebug(Class&lt;?&gt; clazz) {<a name="line.2727"></a>
+<span class="sourceLineNo">2728</span>    Log l = LogFactory.getLog(clazz);<a name="line.2728"></a>
+<span class="sourceLineNo">2729</span>    if (l instanceof Log4JLogger) {<a name="line.2729"></a>
+<span class="sourceLineNo">2730</span>      ((Log4JLogger) l).getLogger().setLevel(org.apache.log4j.Level.DEBUG);<a name="line.2730"></a>
+<span class="sourceLineNo">2731</span>    } else if (l instanceof Jdk14Logger) {<a name="line.2731"></a>
+<span class="sourceLineNo">2732</span>      ((Jdk14Logger) l).getLogger().setLevel(java.util.logging.Level.ALL);<a name="line.2732"></a>
+<span class="sourceLineNo">2733</span>    }<a name="line.2733"></a>
+<span class="sourceLineNo">2734</span>  }<a name="line.2734"></a>
+<span class="sourceLineNo">2735</span><a name="line.2735"></a>
+<span class="sourceLineNo">2736</span>  /**<a name="line.2736"></a>
+<span class="sourceLineNo">2737</span>   * Expire the Master's session<a name="line.2737"></a>
+<span class="sourceLineNo">2738</span>   * @throws Exception<a name="line.2738"></a>
+<span class="sourceLineNo">2739</span>   */<a name="line.2739"></a>
+<span class="sourceLineNo">2740</span>  public void expireMasterSession() throws Exception {<a name="line.2740"></a>
+<span class="sourceLineNo">2741</span>    HMaster master = getMiniHBaseCluster().getMaster();<a name="line.2741"></a>
+<span class="sourceLineNo">2742</span>    expireSession(master.getZooKeeper(), false);<a name="line.2742"></a>
+<span class="sourceLineNo">2743</span>  }<a name="line.2743"></a>
+<span class="sourceLineNo">2744</span><a name="line.2744"></a>
+<span class="sourceLineNo">2745</span>  /**<a name="line.2745"></a>
+<span class="sourceLineNo">2746</span>   * Expire a region server's session<a name="line.2746"></a>
+<span class="sourceLineNo">2747</span>   * @param index which RS<a name="line.2747"></a>
+<span class="sourceLineNo">2748</span>   * @throws Exception<a name="line.2748"></a>
+<span class="sourceLineNo">2749</span>   */<a name="line.2749"></a>
+<span class="sourceLineNo">2750</span>  public void expireRegionServerSession(int index) throws Exception {<a name="line.2750"></a>
+<span class="sourceLineNo">2751</span>    HRegionServer rs = getMiniHBaseCluster().getRegionServer(index);<a name="line.2751"></a>
+<span class="sourceLineNo">2752</span>    expireSession(rs.getZooKeeper(), false);<a name="line.2752"></a>
+<span class="sourceLineNo">2753</span>    decrementMinRegionServerCount();<a name="line.2753"></a>
+<span class="sourceLineNo">2754</span>  }<a name="line.2754"></a>
+<span class="sourceLineNo">2755</span><a name="line.2755"></a>
+<span class="sourceLineNo">2756</span>  private void decrementMinRegionServerCount() {<a name="line.2756"></a>
+<span class="sourceLineNo">2757</span>    // decrement the count for this.conf, for newly spwaned master<a name="line.2757"></a>
+<span class="sourceLineNo">2758</span>    // this.hbaseCluster shares this configuration too<a name="line.2758"></a>
+<span class="sourceLineNo">2759</span>    decrementMinRegionServerCount(getConfiguration());<a name="line.2759"></a>
 <span class="sourceLineNo">2760</span><a name="line.2760"></a>
-<span class="sourceLineNo">2761</span>  public void expireSession(ZKWatcher nodeZK) throws Exception {<a name="line.2761"></a>
-<span class="sourceLineNo">2762</span>   expireSession(nodeZK, false);<a name="line.2762"></a>
-<span class="sourceLineNo">2763</span>  }<a name="line.2763"></a>
-<span class="sourceLineNo">2764</span><a name="line.2764"></a>
-<span class="sourceLineNo">2765</span>  /**<a name="line.2765"></a>
-<span class="sourceLineNo">2766</span>   * Expire a ZooKeeper session as recommended in ZooKeeper documentation<a name="line.2766"></a>
-<span class="sourceLineNo">2767</span>   * http://hbase.apache.org/book.html#trouble.zookeeper<a name="line.2767"></a>
-<span class="sourceLineNo">2768</span>   * There are issues when doing this:<a name="line.2768"></a>
-<span class="sourceLineNo">2769</span>   * [1] http://www.mail-archive.com/dev@zookeeper.apache.org/msg01942.html<a name="line.2769"></a>
-<span class="sourceLineNo">2770</span>   * [2] https://issues.apache.org/jira/browse/ZOOKEEPER-1105<a name="line.2770"></a>
-<span class="sourceLineNo">2771</span>   *<a name="line.2771"></a>
-<span class="sourceLineNo">2772</span>   * @param nodeZK - the ZK watcher to expire<a name="line.2772"></a>
-<span class="sourceLineNo">2773</span>   * @param checkStatus - true to check if we can create a Table with the<a name="line.2773"></a>
-<span class="sourceLineNo">2774</span>   *                    current configuration.<a name="line.2774"></a>
-<span class="sourceLineNo">2775</span>   */<a name="line.2775"></a>
-<span class="sourceLineNo">2776</span>  public void expireSession(ZKWatcher nodeZK, boolean checkStatus)<a name="line.2776"></a>
-<span class="sourceLineNo">2777</span>    throws Exception {<a name="line.2777"></a>
-<span class="sourceLineNo">2778</span>    Configuration c = new Configuration(this.conf);<a name="line.2778"></a>
-<span class="sourceLineNo">2779</span>    String quorumServers = ZKConfig.getZKQuorumServersString(c);<a name="line.2779"></a>
-<span class="sourceLineNo">2780</span>    ZooKeeper zk = nodeZK.getRecoverableZooKeeper().getZooKeeper();<a name="line.2780"></a>
-<span class="sourceLineNo">2781</span>    byte[] password = zk.getSessionPasswd();<a name="line.2781"></a>
-<span class="sourceLineNo">2782</span>    long sessionID = zk.getSessionId();<a name="line.2782"></a>
-<span class="sourceLineNo">2783</span><a name="line.2783"></a>
-<span class="sourceLineNo">2784</span>    // Expiry seems to be asynchronous (see comment from P. Hunt in [1]),<a name="line.2784"></a>
-<span class="sourceLineNo">2785</span>    //  so we create a first watcher to be sure that the<a name="line.2785"></a>
-<span class="sourceLineNo">2786</span>    //  event was sent. We expect that if our watcher receives the event<a name="line.2786"></a>
-<span class="sourceLineNo">2787</span>    //  other watchers on the same machine will get is as well.<a name="line.2787"></a>
-<span class="sourceLineNo">2788</span>    // When we ask to close the connection, ZK does not close it before<a name="line.2788"></a>
-<span class="sourceLineNo">2789</span>    //  we receive all the events, so don't have to capture the event, just<a name="line.2789"></a>
-<span class="sourceLineNo">2790</span>    //  closing the connection should be enough.<a name="line.2790"></a>
-<span class="sourceLineNo">2791</span>    ZooKeeper monitor = new ZooKeeper(quorumServers,<a name="line.2791"></a>
-<span class="sourceLineNo">2792</span>      1000, new org.apache.zookeeper.Watcher(){<a name="line.2792"></a>
-<span class="sourceLineNo">2793</span>      @Override<a name="line.2793"></a>
-<span class="sourceLineNo">2794</span>      public void process(WatchedEvent watchedEvent) {<a name="line.2794"></a>
-<span class="sourceLineNo">2795</span>        LOG.info("Monitor ZKW received event="+watchedEvent);<a name="line.2795"></a>
-<span class="sourceLineNo">2796</span>      }<a name="line.2796"></a>
-<span class="sourceLineNo">2797</span>    } , sessionID, password);<a name="line.2797"></a>
+<span class="sourceLineNo">2761</span>    // each master thread keeps a copy of configuration<a name="line.2761"></a>
+<span class="sourceLineNo">2762</span>    for (MasterThread master : getHBaseCluster().getMasterThreads()) {<a name="line.2762"></a>
+<span class="sourceLineNo">2763</span>      decrementMinRegionServerCount(master.getMaster().getConfiguration());<a name="line.2763"></a>
+<span class="sourceLineNo">2764</span>    }<a name="line.2764"></a>
+<span class="sourceLineNo">2765</span>  }<a name="line.2765"></a>
+<span class="sourceLineNo">2766</span><a name="line.2766"></a>
+<span class="sourceLineNo">2767</span>  private void decrementMinRegionServerCount(Configuration conf) {<a name="line.2767"></a>
+<span class="sourceLineNo">2768</span>    int currentCount = conf.getInt(<a name="line.2768"></a>
+<span class="sourceLineNo">2769</span>        ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART, -1);<a name="line.2769"></a>
+<span class="sourceLineNo">2770</span>    if (currentCount != -1) {<a name="line.2770"></a>
+<span class="sourceLineNo">2771</span>      conf.setInt(ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART,<a name="line.2771"></a>
+<span class="sourceLineNo">2772</span>          Math.max(currentCount - 1, 1));<a name="line.2772"></a>
+<span class="sourceLineNo">2773</span>    }<a name="line.2773"></a>
+<span class="sourceLineNo">2774</span>  }<a name="line.2774"></a>
+<span class="sourceLineNo">2775</span><a name="line.2775"></a>
+<span class="sourceLineNo">2776</span>  public void expireSession(ZKWatcher nodeZK) throws Exception {<a name="line.2776"></a>
+<span class="sourceLineNo">2777</span>   expireSession(nodeZK, false);<a name="line.2777"></a>
+<span class="sourceLineNo">2778</span>  }<a name="line.2778"></a>
+<span class="sourceLineNo">2779</span><a name="line.2779"></a>
+<span class="sourceLineNo">2780</span>  /**<a name="line.2780"></a>
+<span class="sourceLineNo">2781</span>   * Expire a ZooKeeper session as recommended in ZooKeeper documentation<a name="line.2781"></a>
+<span class="sourceLineNo">2782</span>   * http://hbase.apache.org/book.html#trouble.zookeeper<a name="line.2782"></a>
+<span class="sourceLineNo">2783</span>   * There are issues when doing this:<a name="line.2783"></a>
+<span class="sourceLineNo">2784</span>   * [1] http://www.mail-archive.com/dev@zookeeper.apache.org/msg01942.html<a name="line.2784"></a>
+<span class="sourceLineNo">2785</span>   * [2] https://issues.apache.org/jira/browse/ZOOKEEPER-1105<a name="line.2785"></a>
+<span class="sourceLineNo">2786</span>   *<a name="line.2786"></a>
+<span class="sourceLineNo">2787</span>   * @param nodeZK - the ZK watcher to expire<a name="line.2787"></a>
+<span class="sourceLineNo">2788</span>   * @param checkStatus - true to check if we can create a Table with the<a name="line.2788"></a>
+<span class="sourceLineNo">2789</span>   *                    current configuration.<a name="line.2789"></a>
+<span class="sourceLineNo">2790</span>   */<a name="line.2790"></a>
+<span class="sourceLineNo">2791</span>  public void expireSession(ZKWatcher nodeZK, boolean checkStatus)<a name="line.2791"></a>
+<span class="sourceLineNo">2792</span>    throws Exception {<a name="line.2792"></a>
+<span class="sourceLineNo">2793</span>    Configuration c = new Configuration(this.conf);<a name="line.2793"></a>
+<span class="sourceLineNo">2794</span>    String quorumServers = ZKConfig.getZKQuorumServersString(c);<a name="line.2794"></a>
+<span class="sourceLineNo">2795</span>    ZooKeeper zk = nodeZK.getRecoverableZooKeeper().getZooKeeper();<a name="line.2795"></a>
+<span class="sourceLineNo">2796</span>    byte[] password = zk.getSessionPasswd();<a name="line.2796"></a>
+<span class="sourceLineNo">2797</span>    long sessionID = zk.getSessionId();<a name="line.2797"></a>
 <span class="sourceLineNo">2798</span><a name="line.2798"></a>
-<span class="sourceLineNo">2799</span>    // Making it expire<a name="line.2799"></a>
-<span class="sourceLineNo">2800</span>    ZooKeeper newZK = new ZooKeeper(quorumServers,<a name="line.2800"></a>
-<span class="sourceLineNo">2801</span>        1000, EmptyWatcher.instance, sessionID, password);<a name="line.2801"></a>
-<span class="sourceLineNo">2802</span><a name="line.2802"></a>
-<span class="sourceLineNo">2803</span>    //ensure that we have connection to the server before closing down, otherwise<a name="line.2803"></a>
-<span class="sourceLineNo">2804</span>    //the close session event will be eaten out before we start CONNECTING state<a name="line.2804"></a>
-<span class="sourceLineNo">2805</span>    long start = System.currentTimeMillis();<a name="line.2805"></a>
-<span class="sourceLineNo">2806</span>    while (newZK.getState() != States.CONNECTED<a name="line.2806"></a>
-<span class="sourceLineNo">2807</span>         &amp;&amp; System.currentTimeMillis() - start &lt; 1000) {<a name="line.2807"></a>
-<span class="sourceLineNo">2808</span>       Thread.sleep(1);<a name="line.2808"></a>
-<span class="sourceLineNo">2809</span>    }<a name="line.2809"></a>
-<span class="sourceLineNo">2810</span>    newZK.close();<a name="line.2810"></a>
-<span class="sourceLineNo">2811</span>    LOG.info("ZK Closed Session 0x" + Long.toHexString(sessionID));<a name="line.2811"></a>
-<span class="sourceLineNo">2812</span><a name="line.2812"></a>
-<span class="sourceLineNo">2813</span>    // Now closing &amp; waiting to be sure that the clients get it.<a name="line.2813"></a>
-<span class="sourceLineNo">2814</span>    monitor.close();<a name="line.2814"></a>
-<span class="sourceLineNo">2815</span><a name="line.2815"></a>
-<span class="sourceLineNo">2816</span>    if (checkStatus) {<a name="line.2816"></a>
-<span class="sourceLineNo">2817</span>      getConnection().getTable(TableName.META_TABLE_NAME).close();<a name="line.2817"></a>
-<span class="sourceLineNo">2818</span>    }<a name="line.2818"></a>
-<span class="sourceLineNo">2819</span>  }<a name="line.2819"></a>
-<span class="sourceLineNo">2820</span><a name="line.2820"></a>
-<span class="sourceLineNo">2821</span>  /**<a name="line.2821"></a>
-<span class="sourceLineNo">2822</span>   * Get the Mini HBase cluster.<a name="line.2822"></a>
-<span class="sourceLineNo">2823</span>   *<a name="line.2823"></a>
-<span class="sourceLineNo">2824</span>   * @return hbase cluster<a name="line.2824"></a>
-<span class="sourceLineNo">2825</span>   * @see #getHBaseClusterInterface()<a name="line.2825"></a>
-<span class="sourceLineNo">2826</span>   */<a name="line.2826"></a>
-<span class="sourceLineNo">2827</span>  public MiniHBaseCluster getHBaseCluster() {<a name="line.2827"></a>
-<span class="sourceLineNo">2828</span>    return getMiniHBaseCluster();<a name="line.2828"></a>
-<span class="sourceLineNo">2829</span>  }<a name="line.2829"></a>
+<span class="sourceLineNo">2799</span>    // Expiry seems to be asynchronous (see comment from P. Hunt in [1]),<a name="line.2799"></a>
+<span class="sourceLineNo">2800</span>    //  so we create a first watcher to be sure that the<a name="line.2800"></a>
+<span class="sourceLineNo">2801</span>    //  event was sent. We expect that if our watcher receives the event<a name="line.2801"></a>
+<span class="sourceLineNo">2802</span>    //  other watchers on the same machine will get is as well.<a name="line.2802"></a>
+<span class="sourceLineNo">2803</span>    // When we ask to close the connection, ZK does not close it before<a name="line.2803"></a>
+<span class="sourceLineNo">2804</span>    //  we receive all the events, so don't have to capture the event, just<a name="line.2804"></a>
+<span class="sourceLineNo">2805</span>    //  closing the connection should be enough.<a name="line.2805"></a>
+<span class="sourceLineNo">2806</span>    ZooKeeper monitor = new ZooKeeper(quorumServers,<a name="line.2806"></a>
+<span class="sourceLineNo">2807</span>      1000, new org.apache.zookeeper.Watcher(){<a name="line.2807"></a>
+<span class="sourceLineNo">2808</span>      @Override<a name="line.2808"></a>
+<span class="sourceLineNo">2809</span>      public void process(WatchedEvent watchedEvent) {<a name="line.2809"></a>
+<span class="sourceLineNo">2810</span>        LOG.info("Monitor ZKW received event="+watchedEvent);<a name="line.2810"></a>
+<span class="sourceLineNo">2811</span>      }<a name="line.2811"></a>
+<span class="sourceLineNo">2812</span>    } , sessionID, password);<a name="line.2812"></a>
+<span class="sourceLineNo">2813</span><a name="line.2813"></a>
+<span class="sourceLineNo">2814</span>    // Making it expire<a name="line.2814"></a>
+<span class="sourceLineNo">2815</span>    ZooKeeper newZK = new ZooKeeper(quorumServers,<a name="line.2815"></a>
+<span class="sourceLineNo">2816</span>        1000, EmptyWatcher.instance, sessionID, password);<a name="line.2816"></a>
+<span class="sourceLineNo">2817</span><a name="line.2817"></a>
+<span class="sourceLineNo">2818</span>    //ensure that we have connection to the server before closing down, otherwise<a name="line.2818"></a>
+<span class="sourceLineNo">2819</span>    //the close session event will be eaten out before we start CONNECTING state<a name="line.2819"></a>
+<span class="sourceLineNo">2820</span>    long start = System.currentTimeMillis();<a name="line.2820"></a>
+<span class="sourceLineNo">2821</span>    while (newZK.getState() != States.CONNECTED<a name="line.2821"></a>
+<span class="sourceLineNo">2822</span>         &amp;&amp; System.currentTimeMillis() - start &lt; 1000) {<a name="line.2822"></a>
+<span class="sourceLineNo">2823</span>       Thread.sleep(1);<a name="line.2823"></a>
+<span class="sourceLineNo">2824</span>    }<a name="line.2824"></a>
+<span class="sourceLineNo">2825</span>    newZK.close();<a name="line.2825"></a>
+<span class="sourceLineNo">2826</span>    LOG.info("ZK Closed Session 0x" + Long.toHexString(sessionID));<a name="line.2826"></a>
+<span class="sourceLineNo">2827</span><a name="line.2827"></a>
+<span class="sourceLineNo">2828</span>    // Now closing &amp; waiting to be sure that the clients get it.<a name="line.2828"></a>
+<span class="sourceLineNo">2829</span>    monitor.close();<a name="line.2829"></a>
 <span class="sourceLineNo">2830</span><a name="line.2830"></a>
-<span class="sourceLineNo">2831</span>  /**<a name="line.2831"></a>
-<span class="sourceLineNo">2832</span>   * Returns the HBaseCluster instance.<a name="line.2832"></a>
-<span class="sourceLineNo">2833</span>   * &lt;p&gt;Returned object can be any of the subclasses of HBaseCluster, and the<a name="line.2833"></a>
-<span class="sourceLineNo">2834</span>   * tests referring this should not assume that the cluster is a mini cluster or a<a name="line.2834"></a>
-<span class="sourceLineNo">2835</span>   * distributed one. If the test only works on a mini cluster, then specific<a name="line.2835"></a>
-<span class="sourceLineNo">2836</span>   * method {@link #getMiniHBaseCluster()} can be used instead w/o the<a name="line.2836"></a>
-<span class="sourceLineNo">2837</span>   * need to type-cast.<a name="line.2837"></a>
-<span class="sourceLineNo">2838</span>   */<a name="line.2838"></a>
-<span class="sourceLineNo">2839</span>  public HBaseCluster getHBaseClusterInterface() {<a name="line.2839"></a>
-<span class="sourceLineNo">2840</span>    //implementation note: we should rename this method as #getHBaseCluster(),<a name="line.2840"></a>
-<span class="sourceLineNo">2841</span>    //but this would require refactoring 90+ calls.<a name="line.2841"></a>
-<span class="sourceLineNo">2842</span>    return hbaseCluster;<a name="line.2842"></a>
-<span class="sourceLineNo">2843</span>  }<a name="line.2843"></a>
-<span class="sourceLineNo">2844</span><a name="line.2844"></a>
-<span class="sourceLineNo">2845</span>  /**<a name="line.2845"></a>
-<span class="sourceLineNo">2846</span>   * Get a Connection to the cluster.<a name="line.2846"></a>
-<span class="sourceLineNo">2847</span>   * Not thread-safe (This class needs a lot of work to make it thread-safe).<a name="line.2847"></a>
-<span class="sourceLineNo">2848</span>   * @return A Connection that can be shared. Don't close. Will be closed on shutdown of cluster.<a name="line.2848"></a>
-<span class="sourceLineNo">2849</span>   * @throws IOException<a name="line.2849"></a>
-<span class="sourceLineNo">2850</span>   */<a name="line.2850"></a>
-<span class="sourceLineNo">2851</span>  public Connection getConnection() throws IOException {<a name="line.2851"></a>
-<span class="sourceLineNo">2852</span>    if (this.connection == null) {<a name="line.2852"></a>
-<span class="sourceLineNo">2853</span>      this.connection = ConnectionFactory.createConnection(this.conf);<a name="line.2853"></a>
-<span class="sourceLineNo">2854</span>    }<a name="line.2854"></a>
-<span class="sourceLineNo">2855</span>    return this.connection;<a name="line.2855"></a>
-<span class="sourceLineNo">2856</span>  }<a name="line.2856"></a>
-<span class="sourceLineNo">2857</span><a name="line.2857"></a>
-<span class="sourceLineNo">2858</span>  /**<a name="line.2858"></a>
-<span class="sourceLineNo">2859</span>   * Returns a Admin instance.<a name="line.2859"></a>
-<span class="sourceLineNo">2860</span>   * This instance is shared between HBaseTestingUtility instance users. Closing it has no effect,<a name="line.2860"></a>
-<span class="sourceLineNo">2861</span>   * it will be closed automatically when the cluster shutdowns<a name="line.2861"></a>
-<span class="sourceLineNo">2862</span>   *<a name="line.2862"></a>
-<span class="sourceLineNo">2863</span>   * @return HBaseAdmin instance which is guaranteed to support only {@link Admin} interface.<a name="line.2863"></a>
-<span class="sourceLineNo">2864</span>   *   Functions in HBaseAdmin not provided by {@link Admin} interface can be changed/deleted<a name="line.2864"></a>
-<span class="sourceLineNo">2865</span>   *   anytime.<a name="line.2865"></a>
-<span class="sourceLineNo">2866</span>   * @deprecated Since 2.0. Will be removed in 3.0. Use {@link #getAdmin()} instead.<a name="line.2866"></a>
-<span class="sourceLineNo">2867</span>   */<a name="line.2867"></a>
-<span class="sourceLineNo">2868</span>  @Deprecated<a name="line.2868"></a>
-<span class="sourceLineNo">2869</span>  public synchronized HBaseAdmin getHBaseAdmin()<a name="line.2869"></a>
-<span class="sourceLineNo">2870</span>  throws IOException {<a name="line.2870"></a>
-<span class="sourceLineNo">2871</span>    if (hbaseAdmin == null){<a name="line.2871"></a>
-<span class="sourceLineNo">2872</span>      this.hbaseAdmin = (HBaseAdmin) getConnection().getAdmin();<a name="line.2872"></a>
-<span class="sourceLineNo">2873</span>    }<a name="line.2873"></a>
-<span class="sourceLineNo">2874</span>    return hbaseAdmin;<a name="line.2874"></a>
-<span class="sourceLineNo">2875</span>  }<a name="line.2875"></a>
-<span class="sourceLineNo">2876</span><a name="line.2876"></a>
-<span class="sourceLineNo">2877</span>  /**<a name="line.2877"></a>
-<span class="sourceLineNo">2878</span>   * Returns an Admin instance which is shared between HBaseTestingUtility instance users.<a name="line.2878"></a>
-<span class="sourceLineNo">2879</span>   * Closing it has no effect, it will be closed automatically when the cluster shutdowns<a name="line.2879"></a>
-<span class="sourceLineNo">2880</span>   */<a name="line.2880"></a>
-<span class="sourceLineNo">2881</span>  public synchronized Admin getAdmin() throws IOException {<a name="line.2881"></a>
-<span class="sourceLineNo">2882</span>    if (hbaseAdmin == null){<a name="line.2882"></a>
-<span class="sourceLineNo">2883</span>      this.hbaseAdmin = (HBaseAdmin) getConnection().getAdmin();<a name="line.2883"></a>
-<span class="sourceLineNo">2884</span>    }<a name="line.2884"></a>
-<span class="sourceLineNo">2885</span>    return hbaseAdmin;<a name="line.2885"></a>
-<span class="sourceLineNo">2886</span>  }<a name="line.2886"></a>
-<span class="sourceLineNo">2887</span><a name="line.2887"></a>
-<span class="sourceLineNo">2888</span>  private HBaseAdmin hbaseAdmin = null;<a name="line.2888"></a>
-<span class="sourceLineNo">2889</span><a name="line.2889"></a>
-<span class="sourceLineNo">2890</span>  /**<a name="line.2890"></a>
-<span class="sourceLineNo">2891</span>   * Returns a ZKWatcher instance.<a name="line.2891"></a>
-<span class="sourceLineNo">2892</span>   * This instance is shared between HBaseTestingUtility instance users.<a name="line.2892"></a>
-<span class="sourceLineNo">2893</span>   * Don't close it, it will be closed automatically when the<a name="line.2893"></a>
-<span class="sourceLineNo">2894</span>   * cluster shutdowns<a name="line.2894"></a>
-<span class="sourceLineNo">2895</span>   *<a name="line.2895"></a>
-<span class="sourceLineNo">2896</span>   * @return The ZKWatcher instance.<a name="line.2896"></a>
-<span class="sourceLineNo">2897</span>   * @throws IOException<a name="line.2897"></a>
-<span class="sourceLineNo">2898</span>   */<a name="line.2898"></a>
-<span class="sourceLineNo">2899</span>  public synchronized ZKWatcher getZooKeeperWatcher()<a name="line.2899"></a>
-<span class="sourceLineNo">2900</span>    throws IOException {<a name="line.2900"></a>
-<span class="sourceLineNo">2901</span>    if (zooKeeperWatcher == null) {<a name="line.2901"></a>
-<span class="sourceLineNo">2902</span>      zooKeeperWatcher = new ZKWatcher(conf, "testing utility",<a name="line.2902"></a>
-<span class="sourceLineNo">2903</span>        new Abortable() {<a name="line.2903"></a>
-<span class="sourceLineNo">2904</span>        @Override public void abort(String why, Throwable e) {<a name="line.2904"></a>
-<span class="sourceLineNo">2905</span>          throw new RuntimeException("Unexpected abort in HBaseTestingUtility:"+why, e);<a name="line.2905"></a>
-<span class="sourceLineNo">2906</span>        }<a name="line.2906"></a>
-<span class="sourceLineNo">2907</span>        @Override public boolean isAborted() {return false;}<a name="line.2907"></a>
-<span class="sourceLineNo">2908</span>      });<a name="line.2908"></a>
-<span class="sourceLineNo">2909</span>    }<a name="line.2909"></a>
-<span class="sourceLineNo">2910</span>    return zooKeeperWatcher;<a name="line.2910"></a>
-<span class="sourceLineNo">2911</span>  }<a name="line.2911"></a>
-<span class="sourceLineNo">2912</span>  private ZKWatcher zooKeeperWatcher;<a name="line.2912"></a>
-<span class="sourceLineNo">2913</span><a name="line.2913"></a>
-<span class="sourceLineNo">2914</span><a name="line.2914"></a>
-<span class="sourceLineNo">2915</span><a name="line.2915"></a>
-<span class="sourceLineNo">2916</span>  /**<a name="line.2916"></a>
-<span class="sourceLineNo">2917</span>   * Unassign the named region.<a name="line.2917"></a>
-<span class="sourceLineNo">2918</span>   *<a name="line.2918"></a>
-<span class="sourceLineNo">2919</span>   * @param regionName  The region to unassign.<a name="line.2919"></a>
-<span class="sourceLineNo">2920</span>   */<a name="line.2920"></a>
-<span class="sourceLineNo">2921</span>  public void unassignRegion(String regionName) throws IOException {<a name="line.2921"></a>
-<span class="sourceLineNo">2922</span>    unassignRegion(Bytes.toBytes(regionName));<a name="line.2922"></a>
-<span class="sourceLineNo">2923</span>  }<a name="line.2923"></a>
-<span class="sourceLineNo">2924</span><a name="line.2924"></a>
-<span class="sourceLineNo">2925</span>  /**<a name="line.2925"></a>
-<span class="sourceLineNo">2926</span>   * Unassign the named region.<a name="line.2926"></a>
-<span class="sourceLineNo">2927</span>   *<a name="line.2927"></a>
-<span class="sourceLineNo">2928</span>   * @param regionName  The region to unassign.<a name="line.2928"></a>
-<span class="sourceLineNo">2929</span>   */<a name="line.2929"></a>
-<span class="sourceLineNo">2930</span>  public void unassignRegion(byte[] regionName) throws IOException {<a name="line.2930"></a>
-<span class="sourceLineNo">2931</span>    getAdmin().unassign(regionName, true);<a name="line.2931"></a>
-<span class="sourceLineNo">2932</span>  }<a name="line.2932"></a>
-<span class="sourceLineNo">2933</span><a name="line.2933"></a>
-<span class="sourceLineNo">2934</span>  /**<a name="line.2934"></a>
-<span class="sourceLineNo">2935</span>   * Closes the region containing the given row.<a name="line.2935"></a>
-<span class="sourceLineNo">2936</span>   *<a name="line.2936"></a>
-<span class="sourceLineNo">2937</span>   * @param row  The row to find the containing region.<a name="line.2937"></a>
-<span class="sourceLineNo">2938</span>   * @param table  The table to find the region.<a name="line.2938"></a>
-<span class="sourceLineNo">2939</span>   */<a name="line.2939"></a>
-<span class="sourceLineNo">2940</span>  public void unassignRegionByRow(String row, RegionLocator table) throws IOException {<a name="line.2940"></a>
-<span class="sourceLineNo">2941</span>    unassignRegionByRow(Bytes.toBytes(row), table);<a name="line.2941"></a>
-<span class="sourceLineNo">2942</span>  }<a name="line.2942"></a>
-<span class="sourceLineNo">2943</span><a name="line.2943"></a>
-<span class="sourceLineNo">2944</span>  /**<a name="line.2944"></a>
-<span class="sourceLineNo">2945</span>   * Closes the region containing the given row.<a name="line.2945"></a>
-<span class="sourceLineNo">2946</span>   *<a name="line.2946"></a>
-<span class="sourceLineNo">2947</span>   * @param row  The row to find the containing region.<a name="line.2947"></a>
-<span class="sourceLineNo">2948</span>   * @param table  The table to find the region.<a name="line.2948"></a>
-<span class="sourceLineNo">2949</span>   * @throws IOException<a name="line.2949"></a>
-<span class="sourceLineNo">2950</span>   */<a name="line.2950"></a>
-<span class="sourceLineNo">2951</span>  public void unassignRegionByRow(byte[] row, RegionLocator table) throws IOException {<a name="line.2951"></a>
-<span class="sourceLineNo">2952</span>    HRegionLocation hrl = table.getRegionLocation(row);<a name="line.2952"></a>
-<span class="sourceLineNo">2953</span>    unassignRegion(hrl.getRegionInfo().getRegionName());<a name="line.2953"></a>
-<span class="sourceLineNo">2954</span>  }<a name="line.2954"></a>
-<span class="sourceLineNo">2955</span><a name="line.2955"></a>
-<span class="sourceLineNo">2956</span>  /*<a name="line.2956"></a>
-<span class="sourceLineNo">2957</span>   * Retrieves a splittable region randomly from tableName<a name="line.2957"></a>
-<span class="sourceLineNo">2958</span>   *<a name="line.2958"></a>
-<span class="sourceLineNo">2959</span>   * @param tableName name of table<a name="line.2959"></a>
-<span class="sourceLineNo">2960</span>   * @param maxAttempts maximum number of attempts, unlimited for value of -1<a name="line.2960"></a>
-<span class="sourceLineNo">2961</span>   * @return the HRegion chosen, null if none was found within limit of maxAttempts<a name="line.2961"></a>
-<span class="sourceLineNo">2962</span>   */<a name="line.2962"></a>
-<span class="sourceLineNo">2963</span>  public HRegion getSplittableRegion(TableName tableName, int maxAttempts) {<a name="line.2963"></a>
-<span class="sourceLineNo">2964</span>    List&lt;HRegion&gt; regions = getHBaseCluster().getRegions(tableName);<a name="line.2964"></a>
-<span class="sourceLineNo">2965</span>    int regCount = regions.size();<a name="line.2965"></a>
-<span class="sourceLineNo">2966</span>    Set&lt;Integer&gt; attempted = new HashSet&lt;&gt;();<a name="line.2966"></a>
-<span class="sourceLineNo">2967</span>    int idx;<a name="line.2967"></a>
-<span class="sourceLineNo">2968</span>    int attempts = 0;<a name="line.2968"></a>
-<span class="sourceLineNo">2969</span>    do {<a name="line.2969"></a>
-<span class="sourceLineNo">2970</span>      regions = getHBaseCluster().getRegions(tableName);<a name="line.2970"></a>
-<span class="sourceLineNo">2971</span>      if (regCount != regions.size()) {<a name="line.2971"></a>
-<span class="sourceLineNo">2972</span>        // if there was region movement, clear attempted Set<a name="line.2972"></a>
-<span class="sourceLineNo">2973</span>        attempted.clear();<a name="line.2973"></a>
-<span class="sourceLineNo">2974</span>      }<a name="line.2974"></a>
-<span class="sourceLineNo">2975</span>      regCount = regions.size();<a name="line.2975"></a>
-<span class="sourceLineNo">2976</span>      // There are chances that before we get the region for the table from an RS the region may<a name="line.2976"></a>
-<span class="sourceLineNo">2977</span>      // be going for CLOSE.  This may be because online schema change is enabled<a name="line.2977"></a>
-<span class="sourceLineNo">2978</span>      if (regCount &gt; 0) {<a name="line.2978"></a>
-<span class="sourceLineNo">2979</span>        idx = random.nextInt(regCount);<a name="line.2979"></a>
-<span class="sourceLineNo">2980</span>        // if we have just tried this region, there is no need to try again<a name="line.2980"></a>
-<span class="sourceLineNo">2981</span>        if (attempted.contains(idx))<a name="line.2981"></a>
-<span class="sourceLineNo">2982</span>          continue;<a name="line.2982"></a>
-<span class="sourceLineNo">2983</span>        try {<a name="line.2983"></a>
-<span class="sourceLineNo">2984</span>          regions.get(idx).checkSplit();<a name="line.2984"></a>
-<span class="sourceLineNo">2985</span>          return regions.get(idx);<a name="line.2985"></a>
-<span class="sourceLineNo">2986</span>        } catch (Exception ex) {<a name="line.2986"></a>
-<span class="sourceLineNo">2987</span>          LOG.warn("Caught exception", ex);<a name="line.2987"></a>
-<span class="sourceLineNo">2988</span>          attempted.add(idx);<a name="line.2988"></a>
-<span class="sourceLineNo">2989</span>        }<a name="line.2989"></a>
-<span class="sourceLineNo">2990</span>      }<a name="line.2990"></a>
-<span class="sourceLineNo">2991</span>      attempts++;<a name="line.2991"></a>
-<span class="sourceLineNo">2992</span>    } while (maxAttempts == -1 || attempts &lt; maxAttempts);<a name="line.2992"></a>
-<span class="sourceLineNo">2993</span>    return null;<a name="line.2993"></a>
-<span class="sourceLineNo">2994</span>  }<a name="line.2994"></a>
-<span class="sourceLineNo">2995</span><a name="line.2995"></a>
-<span class="sourceLineNo">2996</span>  public MiniZooKeeperCluster getZkCluster() {<a name="line.2996"></a>
-<span class="sourceLineNo">2997</span>    return zkCluster;<a name="line.2997"></a>
-<span class="sourceLineNo">2998</span>  }<a name="line.2998"></a>
-<span class="sourceLineNo">2999</span><a name="line.2999"></a>
-<span class="sourceLineNo">3000</span>  public void setZkCluster(MiniZooKeeperCluster zkCluster) {<a name="line.3000"></a>
-<span class="sourceLineNo">3001</span>    this.passedZkCluster = true;<a name="line.3001"></a>
-<span class="sourceLineNo">3002</span>    this.zkCluster = zkCluster;<a name="line.3002"></a>
-<span class="sourceLineNo">3003</span>    conf.setInt(HConstants.ZOOKEEPER_CLIENT_PORT, zkCluster.getClientPort());<a name="line.3003"></a>
-<span class="sourceLineNo">3004</span>  }<a name="line.3004"></a>
-<span class="sourceLineNo">3005</span><a name="line.3005"></a>
-<span class="sourceLineNo">3006</span>  public MiniDFSCluster getDFSCluster() {<a name="line.3006"></a>
-<span class="sourceLineNo">3007</span>    return dfsCluster;<a name="line.3007"></a>
-<span class="sourceLineNo">3008</span>  }<a name="line.3008"></a>
-<span class="sourceLineNo">3009</span><a name="line.3009"></a>
-<span class="sourceLineNo">3010</span>  public void setDFSCluster(MiniDFSCluster cluster) throws IllegalStateException, IOException {<a name="line.3010"></a>
-<span class="sourceLineNo">3011</span>    setDFSCluster(cluster, true);<a name="line.3011"></a>
-<span class="sourceLineNo">3012</span>  }<a name="line.3012"></a>
-<span class="sourceLineNo">3013</span><a name="line.3013"></a>
-<span class="sourceLineNo">3014</span>  /**<a name="line.3014"></a>
-<span class="sourceLineNo">3015</span>   * Set the MiniDFSCluster<a name="line.3015"></a>
-<span class="sourceLineNo">3016</span>   * @param cluster cluster to use<a name="line.3016"></a>
-<span class="sourceLineNo">3017</span>   * @param requireDown require the that cluster not be "up" (MiniDFSCluster#isClusterUp) before<a name="line.3017"></a>
-<span class="sourceLineNo">3018</span>   * it is set.<a name="line.3018"></a>
-<span class="sourceLineNo">3019</span>   * @throws IllegalStateException if the passed cluster is up when it is required to be down<a name="line.3019"></a>
-<span class="sourceLineNo">3020</span>   * @throws IOException if the FileSystem could not be set from the passed dfs cluster<a name="line.3020"></a>
-<span class="sourceLineNo">3021</span>   */<a name="line.3021"></a>
-<span class="sourceLineNo">3022</span>  public void setDFSCluster(MiniDFSCluster cluster, boolean requireDown)<a name="line.3022"></a>
-<span class="sourceLineNo">3023</span>      throws IllegalStateException, IOException {<a name="line.3023"></a>
-<span class="sourceLineNo">3024</span>    if (dfsCluster != null &amp;&amp; requireDown &amp;&amp; dfsCluster.isClusterUp()) {<a name="line.3024"></a>
-<span class="sourceLineNo">3025</span>      throw new IllegalStateException("DFSCluster is already running! Shut it down first.");<a name="line.3025"></a>
-<span class="sourceLineNo">3026</span>    }<a name="line.3026"></a>
-<span class="sourceLineNo">3027</span>    this.dfsCluster = cluster;<a name="line.3027"></a>
-<span class="sourceLineNo">3028</span>    this.setFs();<a name="line.3028"></a>
-<span class="sourceLineNo">3029</span>  }<a name="line.3029"></a>
-<span class="sourceLineNo">3030</span><a name="line.3030"></a>
-<span class="sourceLineNo">3031</span>  public FileSystem getTestFileSystem() throws IOException {<a name="line.3031"></a>
-<span class="sourceLineNo">3032</span>    return HFileSystem.get(conf);<a name="line.3032"></a>
-<span class="sourceLineNo">3033</span>  }<a name="line.3033"></a>
-<span class="sourceLineNo">3034</span><a name="line.3034"></a>
-<span class="sourceLineNo">3035</span>  /**<a name="line.3035"></a>
-<span class="sourceLineNo">3036</span>   * Wait until all regions in a table have been assigned.  Waits default timeout before giving up<a name="line.3036"></a>
-<span class="sourceLineNo">3037</span>   * (30 seconds).<a name="line.3037"></a>
-<span class="sourceLineNo">3038</span>   * @param table Table to wait on.<a name="line.3038"></a>
-<span class="sourceLineNo">3039</span>   * @throws InterruptedException<a name="line.3039"></a>
-<span class="sourceLineNo">3040</span>   * @throws IOException<a name="line.3040"></a>
-<span class="sourceLineNo">3041</span>   */<a name="line.3041"></a>
-<span class="sourceLineNo">3042</span>  public void waitTableAvailable(TableName table)<a name="line.3042"></a>
-<span class="sourceLineNo">3043</span>      throws InterruptedException, IOException {<a name="line.3043"></a>
-<span class="sourceLineNo">3044</span>    waitTableAvailable(table.getName(), 30000);<a name="line.3044"></a>
-<span class="sourceLineNo">3045</span>  }<a name="line.3045"></a>
-<span class="sourceLineNo">3046</span><a name="line.3046"></a>
-<span class="sourceLineNo">3047</span>  public void waitTableAvailable(TableName table, long timeoutMillis)<a name="line.3047"></a>
-<span class="sourceLineNo">3048</span>      throws InterruptedException, IOException {<a name="line.3048"></a>
-<span class="sourceLineNo">3049</span>    waitFor(timeoutMillis, predicateTableAvailable(table));<a name="line.3049"></a>
-<span class="sourceLineNo">3050</span>  }<a name="line.3050"></a>
-<span class="sourceLineNo">3051</span><a name="line.3051"></a>
-<span class="sourceLineNo">3052</span>  /**<a name="line.3052"></a>
-<span class="sourceLineNo">3053</span>   * Wait until all regions in a table have been assigned<a name="line.3053"></a>
-<span class="sourceLineNo">3054</span>   * @param table Table to wait on.<a name="line.3054"></a>
-<span class="sourceLineNo">3055</span>   * @param timeoutMillis Timeout.<a name="line.3055"></a>
-<span class="sourceLineNo">3056</span>   * @throws InterruptedException<a name="line.3056"></a>
-<span class="sourceLineNo">3057</span>   * @throws IOException<a name="line.3057"></a>
-<span class="sourceLineNo">3058</span>   */<a name="line.3058"></a>
-<span class="sourceLineNo">3059</span>  public void waitTableAvailable(byte[] table, long timeoutMillis)<a name="line.3059"></a>
-<span class="sourceLineNo">3060</span>  throws InterruptedException, IOException {<a name="line.3060"></a>
-<span class="sourceLineNo">3061</span>    waitFor(timeoutMillis, predicateTableAvailable(TableName.valueOf(table)));<a name="line.3061"></a>
-<span class="sourceLineNo">3062</span>  }<a name="line.3062"></a>
-<span class="sourceLineNo">3063</span><a name="line.3063"></a>
-<span class="sourceLineNo">3064</span>  public String explainTableAvailability(TableName tableName) throws IOException {<a name="line.3064"></a>
-<span class="sourceLineNo">3065</span>    String msg = explainTableState(tableName, TableState.State.ENABLED) + ", ";<a name="line.3065"></a>
-<span class="sourceLineNo">3066</span>    if (getHBaseCluster().getMaster().isAlive()) {<a name="line.3066"></a>
-<span class="sourceLineNo">3067</span>      Map&lt;RegionInfo, ServerName&gt; assignments =<a name="line.3067"></a>
-<span class="sourceLineNo">3068</span>          getHBaseCluster().getMaster().getAssignmentManager().getRegionStates()<a name="line.3068"></a>
-<span class="sourceLineNo">3069</span>              .getRegionAssignments();<a name="line.3069"></a>
-<span class="sourceLineNo">3070</span>      final List&lt;Pair&lt;RegionInfo, ServerName&gt;&gt; metaLocations =<a name="line.3070"></a>
-<span class="sourceLineNo">3071</span>          MetaTableAccessor.getTableRegionsAndLocations(connection, tableName);<a name="line.3071"></a>
-<span class="sourceLineNo">3072</span>      for (Pair&lt;RegionInfo, ServerName&gt; metaLocation : metaLocations) {<a name="line.3072"></a>
-<span class="sourceLineNo">3073</span>        RegionInfo hri = metaLocation.getFirst();<a name="line.3073"></a>
-<span class="sourceLineNo">3074</span>        ServerName sn = metaLocation.getSecond();<a name="line.3074"></a>
-<span class="sourceLineNo">3075</span>        if (!assignments.containsKey(hri)) {<a name="line.3

<TRUNCATED>

[14/14] hbase-site git commit: Published site at .

Posted by gi...@apache.org.
Published site at .


Project: http://git-wip-us.apache.org/repos/asf/hbase-site/repo
Commit: http://git-wip-us.apache.org/repos/asf/hbase-site/commit/29385b7e
Tree: http://git-wip-us.apache.org/repos/asf/hbase-site/tree/29385b7e
Diff: http://git-wip-us.apache.org/repos/asf/hbase-site/diff/29385b7e

Branch: refs/heads/asf-site
Commit: 29385b7e51d9a65ba44a04145f433effc184bb87
Parents: 9d4462e
Author: jenkins <bu...@apache.org>
Authored: Mon Dec 4 15:22:17 2017 +0000
Committer: jenkins <bu...@apache.org>
Committed: Mon Dec 4 15:22:17 2017 +0000

----------------------------------------------------------------------
 acid-semantics.html                             |    4 +-
 apache_hbase_reference_guide.pdf                |    4 +-
 book.html                                       |    2 +-
 bulk-loads.html                                 |    4 +-
 checkstyle-aggregate.html                       |  136 +-
 coc.html                                        |    4 +-
 cygwin.html                                     |    4 +-
 dependencies.html                               |    4 +-
 dependency-convergence.html                     |    4 +-
 dependency-info.html                            |    4 +-
 dependency-management.html                      |    4 +-
 devapidocs/constant-values.html                 |    4 +-
 .../org/apache/hadoop/hbase/Version.html        |    4 +-
 export_control.html                             |    4 +-
 hbase-annotations/checkstyle.html               |    4 +-
 hbase-annotations/dependencies.html             |    4 +-
 hbase-annotations/dependency-convergence.html   |    4 +-
 hbase-annotations/dependency-info.html          |    4 +-
 hbase-annotations/dependency-management.html    |    4 +-
 hbase-annotations/index.html                    |    4 +-
 hbase-annotations/integration.html              |    4 +-
 hbase-annotations/issue-tracking.html           |    4 +-
 hbase-annotations/license.html                  |    4 +-
 hbase-annotations/mail-lists.html               |    4 +-
 hbase-annotations/plugin-management.html        |    4 +-
 hbase-annotations/plugins.html                  |    4 +-
 hbase-annotations/project-info.html             |    4 +-
 hbase-annotations/project-reports.html          |    4 +-
 hbase-annotations/project-summary.html          |    4 +-
 hbase-annotations/source-repository.html        |    4 +-
 hbase-annotations/team-list.html                |    4 +-
 hbase-build-configuration/dependencies.html     |    4 +-
 .../dependency-convergence.html                 |    4 +-
 hbase-build-configuration/dependency-info.html  |    4 +-
 .../dependency-management.html                  |    4 +-
 .../hbase-archetypes/dependencies.html          |    4 +-
 .../dependency-convergence.html                 |    4 +-
 .../hbase-archetypes/dependency-info.html       |    4 +-
 .../hbase-archetypes/dependency-management.html |    4 +-
 .../hbase-archetype-builder/dependencies.html   |    4 +-
 .../dependency-convergence.html                 |    4 +-
 .../dependency-info.html                        |    4 +-
 .../dependency-management.html                  |    4 +-
 .../hbase-archetype-builder/index.html          |    4 +-
 .../hbase-archetype-builder/integration.html    |    4 +-
 .../hbase-archetype-builder/issue-tracking.html |    4 +-
 .../hbase-archetype-builder/license.html        |    4 +-
 .../hbase-archetype-builder/mail-lists.html     |    4 +-
 .../plugin-management.html                      |    4 +-
 .../hbase-archetype-builder/plugins.html        |    4 +-
 .../hbase-archetype-builder/project-info.html   |    4 +-
 .../project-summary.html                        |    4 +-
 .../source-repository.html                      |    4 +-
 .../hbase-archetype-builder/team-list.html      |    4 +-
 .../hbase-client-project/checkstyle.html        |    4 +-
 .../hbase-client-project/dependencies.html      |    4 +-
 .../dependency-convergence.html                 |    4 +-
 .../hbase-client-project/dependency-info.html   |    4 +-
 .../dependency-management.html                  |    4 +-
 .../hbase-client-project/index.html             |    4 +-
 .../hbase-client-project/integration.html       |    4 +-
 .../hbase-client-project/issue-tracking.html    |    4 +-
 .../hbase-client-project/license.html           |    4 +-
 .../hbase-client-project/mail-lists.html        |    4 +-
 .../hbase-client-project/plugin-management.html |    4 +-
 .../hbase-client-project/plugins.html           |    4 +-
 .../hbase-client-project/project-info.html      |    4 +-
 .../hbase-client-project/project-reports.html   |    4 +-
 .../hbase-client-project/project-summary.html   |    4 +-
 .../hbase-client-project/source-repository.html |    4 +-
 .../hbase-client-project/team-list.html         |    4 +-
 .../hbase-shaded-client-project/checkstyle.html |    4 +-
 .../dependencies.html                           |    4 +-
 .../dependency-convergence.html                 |    4 +-
 .../dependency-info.html                        |    4 +-
 .../dependency-management.html                  |    4 +-
 .../hbase-shaded-client-project/index.html      |    4 +-
 .../integration.html                            |    4 +-
 .../issue-tracking.html                         |    4 +-
 .../hbase-shaded-client-project/license.html    |    4 +-
 .../hbase-shaded-client-project/mail-lists.html |    4 +-
 .../plugin-management.html                      |    4 +-
 .../hbase-shaded-client-project/plugins.html    |    4 +-
 .../project-info.html                           |    4 +-
 .../project-reports.html                        |    4 +-
 .../project-summary.html                        |    4 +-
 .../source-repository.html                      |    4 +-
 .../hbase-shaded-client-project/team-list.html  |    4 +-
 .../hbase-archetypes/index.html                 |    4 +-
 .../hbase-archetypes/integration.html           |    4 +-
 .../hbase-archetypes/issue-tracking.html        |    4 +-
 .../hbase-archetypes/license.html               |    4 +-
 .../hbase-archetypes/mail-lists.html            |    4 +-
 .../hbase-archetypes/plugin-management.html     |    4 +-
 .../hbase-archetypes/plugins.html               |    4 +-
 .../hbase-archetypes/project-info.html          |    4 +-
 .../hbase-archetypes/project-summary.html       |    4 +-
 .../hbase-archetypes/source-repository.html     |    4 +-
 .../hbase-archetypes/team-list.html             |    4 +-
 .../hbase-spark/checkstyle.html                 |    4 +-
 .../hbase-spark/dependencies.html               |    4 +-
 .../hbase-spark/dependency-convergence.html     |    4 +-
 .../hbase-spark/dependency-info.html            |    4 +-
 .../hbase-spark/dependency-management.html      |    4 +-
 .../hbase-spark/index.html                      |    4 +-
 .../hbase-spark/integration.html                |    4 +-
 .../hbase-spark/issue-tracking.html             |    4 +-
 .../hbase-spark/license.html                    |    4 +-
 .../hbase-spark/mail-lists.html                 |    4 +-
 .../hbase-spark/plugin-management.html          |    4 +-
 .../hbase-spark/plugins.html                    |    4 +-
 .../hbase-spark/project-info.html               |    4 +-
 .../hbase-spark/project-reports.html            |    4 +-
 .../hbase-spark/project-summary.html            |    4 +-
 .../hbase-spark/source-repository.html          |    4 +-
 .../hbase-spark/team-list.html                  |    4 +-
 hbase-build-configuration/index.html            |    4 +-
 hbase-build-configuration/integration.html      |    4 +-
 hbase-build-configuration/issue-tracking.html   |    4 +-
 hbase-build-configuration/license.html          |    4 +-
 hbase-build-configuration/mail-lists.html       |    4 +-
 .../plugin-management.html                      |    4 +-
 hbase-build-configuration/plugins.html          |    4 +-
 hbase-build-configuration/project-info.html     |    4 +-
 hbase-build-configuration/project-summary.html  |    4 +-
 .../source-repository.html                      |    4 +-
 hbase-build-configuration/team-list.html        |    4 +-
 hbase-shaded-check-invariants/checkstyle.html   |    4 +-
 hbase-shaded-check-invariants/dependencies.html |    4 +-
 .../dependency-convergence.html                 |    4 +-
 .../dependency-info.html                        |    4 +-
 .../dependency-management.html                  |    4 +-
 hbase-shaded-check-invariants/index.html        |    4 +-
 hbase-shaded-check-invariants/integration.html  |    4 +-
 .../issue-tracking.html                         |    4 +-
 hbase-shaded-check-invariants/license.html      |    4 +-
 hbase-shaded-check-invariants/mail-lists.html   |    4 +-
 .../plugin-management.html                      |    4 +-
 hbase-shaded-check-invariants/plugins.html      |    4 +-
 hbase-shaded-check-invariants/project-info.html |    4 +-
 .../project-reports.html                        |    4 +-
 .../project-summary.html                        |    4 +-
 .../source-repository.html                      |    4 +-
 hbase-shaded-check-invariants/team-list.html    |    4 +-
 index.html                                      |    4 +-
 integration.html                                |    4 +-
 issue-tracking.html                             |    4 +-
 license.html                                    |    4 +-
 mail-lists.html                                 |    4 +-
 metrics.html                                    |    4 +-
 old_news.html                                   |    4 +-
 plugin-management.html                          |    4 +-
 plugins.html                                    |    4 +-
 poweredbyhbase.html                             |    4 +-
 project-info.html                               |    4 +-
 project-reports.html                            |    4 +-
 project-summary.html                            |    4 +-
 pseudo-distributed.html                         |    4 +-
 replication.html                                |    4 +-
 resources.html                                  |    4 +-
 source-repository.html                          |    4 +-
 sponsors.html                                   |    4 +-
 supportingprojects.html                         |    4 +-
 team-list.html                                  |    4 +-
 testapidocs/index-all.html                      |    2 +
 .../hadoop/hbase/HBaseTestingUtility.html       |  387 +-
 .../hadoop/hbase/HBaseTestingUtility.html       | 3533 +++++++++---------
 testdevapidocs/index-all.html                   |    4 +
 ...lity.PortAllocator.AvailablePortChecker.html |    4 +-
 .../HBaseTestingUtility.PortAllocator.html      |   20 +-
 .../hadoop/hbase/HBaseTestingUtility.html       |  423 ++-
 .../hadoop/hbase/IntegrationTestingUtility.html |    2 +-
 .../hadoop/hbase/backup/package-tree.html       |    2 +-
 .../hadoop/hbase/io/hfile/package-tree.html     |    2 +-
 .../org/apache/hadoop/hbase/package-tree.html   |   12 +-
 .../hadoop/hbase/procedure/package-tree.html    |    8 +-
 .../hadoop/hbase/procedure2/package-tree.html   |    2 +-
 ...onInDeadRegionServer.IgnoreYouAreDeadRS.html |    6 +-
 .../TestCompactionInDeadRegionServer.html       |   39 +-
 .../hadoop/hbase/regionserver/package-tree.html |    4 +-
 .../apache/hadoop/hbase/test/package-tree.html  |    2 +-
 .../apache/hadoop/hbase/wal/package-tree.html   |    2 +-
 ...lity.PortAllocator.AvailablePortChecker.html | 3533 +++++++++---------
 .../HBaseTestingUtility.PortAllocator.html      | 3533 +++++++++---------
 .../HBaseTestingUtility.SeenRowTracker.html     | 3533 +++++++++---------
 .../hadoop/hbase/HBaseTestingUtility.html       | 3533 +++++++++---------
 ...onInDeadRegionServer.IgnoreYouAreDeadRS.html |  280 +-
 .../TestCompactionInDeadRegionServer.html       |  280 +-
 188 files changed, 10044 insertions(+), 9888 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/acid-semantics.html
----------------------------------------------------------------------
diff --git a/acid-semantics.html b/acid-semantics.html
index c5b3aa4..2b6fa0f 100644
--- a/acid-semantics.html
+++ b/acid-semantics.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013;  
       Apache HBase (TM) ACID Properties
@@ -606,7 +606,7 @@ under the License. -->
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/apache_hbase_reference_guide.pdf
----------------------------------------------------------------------
diff --git a/apache_hbase_reference_guide.pdf b/apache_hbase_reference_guide.pdf
index d80011b..9323ebb 100644
--- a/apache_hbase_reference_guide.pdf
+++ b/apache_hbase_reference_guide.pdf
@@ -5,8 +5,8 @@
 /Author (Apache HBase Team)
 /Creator (Asciidoctor PDF 1.5.0.alpha.15, based on Prawn 2.2.2)
 /Producer (Apache HBase Team)
-/ModDate (D:20171203144752+00'00')
-/CreationDate (D:20171203144752+00'00')
+/ModDate (D:20171204145241+00'00')
+/CreationDate (D:20171204145241+00'00')
 >>
 endobj
 2 0 obj

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/book.html
----------------------------------------------------------------------
diff --git a/book.html b/book.html
index 90249f7..1b42d2c 100644
--- a/book.html
+++ b/book.html
@@ -36799,7 +36799,7 @@ The server will return cellblocks compressed using this same compressor as long
 <div id="footer">
 <div id="footer-text">
 Version 3.0.0-SNAPSHOT<br>
-Last updated 2017-12-03 14:29:39 UTC
+Last updated 2017-12-04 14:33:56 UTC
 </div>
 </div>
 </body>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/bulk-loads.html
----------------------------------------------------------------------
diff --git a/bulk-loads.html b/bulk-loads.html
index 7cf87b6..eb4115f 100644
--- a/bulk-loads.html
+++ b/bulk-loads.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013;  
       Bulk Loads in Apache HBase (TM)
@@ -311,7 +311,7 @@ under the License. -->
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/checkstyle-aggregate.html
----------------------------------------------------------------------
diff --git a/checkstyle-aggregate.html b/checkstyle-aggregate.html
index 718d005..a7e8089 100644
--- a/checkstyle-aggregate.html
+++ b/checkstyle-aggregate.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Checkstyle Results</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -16265,397 +16265,397 @@
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>2521</td></tr>
+<td>2536</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>2522</td></tr>
+<td>2537</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>2723</td></tr>
+<td>2738</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>2733</td></tr>
+<td>2748</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 3, expected level should be 4.</td>
-<td>2762</td></tr>
+<td>2777</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def modifier' have incorrect indentation level 6, expected level should be one of the following: 8, 10.</td>
-<td>2793</td></tr>
+<td>2808</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 8, expected level should be one of the following: 10, 12.</td>
-<td>2795</td></tr>
+<td>2810</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def rcurly' have incorrect indentation level 6, expected level should be one of the following: 8, 10.</td>
-<td>2796</td></tr>
+<td>2811</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'object def rcurly' have incorrect indentation level 4, expected level should be one of the following: 6, 8.</td>
-<td>2797</td></tr>
+<td>2812</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'while' child have incorrect indentation level 7, expected level should be 6.</td>
-<td>2808</td></tr>
+<td>2823</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>2849</td></tr>
+<td>2864</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>2897</td></tr>
+<td>2912</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def modifier' have incorrect indentation level 8, expected level should be one of the following: 10, 12.</td>
-<td>2904</td></tr>
+<td>2919</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def' child have incorrect indentation level 10, expected level should be one of the following: 12, 14.</td>
-<td>2905</td></tr>
+<td>2920</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def rcurly' have incorrect indentation level 8, expected level should be one of the following: 10, 12.</td>
-<td>2906</td></tr>
+<td>2921</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def modifier' have incorrect indentation level 8, expected level should be one of the following: 10, 12.</td>
-<td>2907</td></tr>
+<td>2922</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>blocks</td>
 <td>LeftCurly</td>
 <td>'{' at column 46 should have line break after.</td>
-<td>2907</td></tr>
+<td>2922</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'object def rcurly' have incorrect indentation level 6, expected level should be one of the following: 8, 10.</td>
-<td>2908</td></tr>
+<td>2923</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>2949</td></tr>
+<td>2964</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>blocks</td>
 <td>NeedBraces</td>
 <td>'if' construct must use '{}'s.</td>
-<td>2981</td></tr>
+<td>2996</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>JavadocTagContinuationIndentation</td>
 <td>Line continuation have incorrect indentation level, expected level should be 2.</td>
-<td>3018</td></tr>
+<td>3033</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3039</td></tr>
+<td>3054</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3040</td></tr>
+<td>3055</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3056</td></tr>
+<td>3071</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3057</td></tr>
+<td>3072</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>blocks</td>
 <td>NeedBraces</td>
 <td>'if' construct must use '{}'s.</td>
-<td>3111</td></tr>
+<td>3126</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>blocks</td>
 <td>NeedBraces</td>
 <td>'if' construct must use '{}'s.</td>
-<td>3114</td></tr>
+<td>3129</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3131</td></tr>
+<td>3146</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3132</td></tr>
+<td>3147</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3133</td></tr>
+<td>3148</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3146</td></tr>
+<td>3161</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3147</td></tr>
+<td>3162</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3163</td></tr>
+<td>3178</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3164</td></tr>
+<td>3179</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3180</td></tr>
+<td>3195</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3181</td></tr>
+<td>3196</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3193</td></tr>
+<td>3208</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3214</td></tr>
+<td>3229</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3246</td></tr>
+<td>3261</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3302</td></tr>
+<td>3317</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3303</td></tr>
+<td>3318</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3304</td></tr>
+<td>3319</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3305</td></tr>
+<td>3320</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3306</td></tr>
+<td>3321</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3332</td></tr>
+<td>3347</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3348</td></tr>
+<td>3363</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3349</td></tr>
+<td>3364</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3375</td></tr>
+<td>3390</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3385</td></tr>
+<td>3400</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3399</td></tr>
+<td>3414</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3506</td></tr>
+<td>3521</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3507</td></tr>
+<td>3522</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3509</td></tr>
+<td>3524</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'method def rparen' have incorrect indentation level 48, expected level should be 2.</td>
-<td>3527</td></tr>
+<td>3542</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>3537</td></tr>
+<td>3552</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>blocks</td>
 <td>EmptyBlock</td>
 <td>Must have at least one statement.</td>
-<td>3570</td></tr>
+<td>3585</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>sizes</td>
 <td>LineLength</td>
 <td>Line is longer than 100 characters (found 101).</td>
-<td>3864</td></tr>
+<td>3879</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>blocks</td>
 <td>NeedBraces</td>
 <td>'if' construct must use '{}'s.</td>
-<td>3951</td></tr>
+<td>3966</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>blocks</td>
 <td>NeedBraces</td>
 <td>'if' construct must use '{}'s.</td>
-<td>3953</td></tr>
+<td>3968</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>blocks</td>
 <td>NeedBraces</td>
 <td>'if' construct must use '{}'s.</td>
-<td>3987</td></tr>
+<td>4002</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>blocks</td>
 <td>NeedBraces</td>
 <td>'if' construct must use '{}'s.</td>
-<td>4048</td></tr>
+<td>4063</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>blocks</td>
 <td>NeedBraces</td>
 <td>'if' construct must use '{}'s.</td>
-<td>4050</td></tr>
+<td>4065</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>4128</td></tr>
+<td>4143</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>4136</td></tr>
+<td>4151</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>4144</td></tr>
+<td>4159</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>4145</td></tr></table></div>
+<td>4160</td></tr></table></div>
 <div class="section">
 <h3 id="org.apache.hadoop.hbase.HColumnDescriptor.java">org/apache/hadoop/hbase/HColumnDescriptor.java</h3>
 <table border="0" class="table table-striped">
@@ -160056,7 +160056,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/coc.html
----------------------------------------------------------------------
diff --git a/coc.html b/coc.html
index fbee962..73605f0 100644
--- a/coc.html
+++ b/coc.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; 
       Code of Conduct Policy
@@ -380,7 +380,7 @@ email to <a class="externalLink" href="mailto:private@hbase.apache.org">the priv
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/cygwin.html
----------------------------------------------------------------------
diff --git a/cygwin.html b/cygwin.html
index 22428f3..2904dbb 100644
--- a/cygwin.html
+++ b/cygwin.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Installing Apache HBase (TM) on Windows using Cygwin</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -679,7 +679,7 @@ Now your <b>HBase </b>server is running, <b>start coding</b> and build that next
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/dependencies.html
----------------------------------------------------------------------
diff --git a/dependencies.html b/dependencies.html
index 34edc89..3fba50a 100644
--- a/dependencies.html
+++ b/dependencies.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -445,7 +445,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/dependency-convergence.html b/dependency-convergence.html
index dbffb4b..9c9baf1 100644
--- a/dependency-convergence.html
+++ b/dependency-convergence.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Reactor Dependency Convergence</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -1008,7 +1008,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/dependency-info.html
----------------------------------------------------------------------
diff --git a/dependency-info.html b/dependency-info.html
index 0955f03..63c5ca8 100644
--- a/dependency-info.html
+++ b/dependency-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Dependency Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -318,7 +318,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/dependency-management.html
----------------------------------------------------------------------
diff --git a/dependency-management.html b/dependency-management.html
index 01dcc45..ff192aa 100644
--- a/dependency-management.html
+++ b/dependency-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; Project Dependency Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -974,7 +974,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/devapidocs/constant-values.html
----------------------------------------------------------------------
diff --git a/devapidocs/constant-values.html b/devapidocs/constant-values.html
index e5ddfff..1cd88ab 100644
--- a/devapidocs/constant-values.html
+++ b/devapidocs/constant-values.html
@@ -3705,14 +3705,14 @@
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a></code></td>
 <td><code><a href="org/apache/hadoop/hbase/Version.html#date">date</a></code></td>
-<td class="colLast"><code>"Sun Dec  3 14:42:16 UTC 2017"</code></td>
+<td class="colLast"><code>"Mon Dec  4 14:47:11 UTC 2017"</code></td>
 </tr>
 <tr class="rowColor">
 <td class="colFirst"><a name="org.apache.hadoop.hbase.Version.revision">
 <!--   -->
 </a><code>public&nbsp;static&nbsp;final&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a></code></td>
 <td><code><a href="org/apache/hadoop/hbase/Version.html#revision">revision</a></code></td>
-<td class="colLast"><code>"7a5b0783068415eaca70ea2ca938ecbfe3bed30f"</code></td>
+<td class="colLast"><code>"3c02d9681b2d777677ce2ce1b21c2537ddd91817"</code></td>
 </tr>
 <tr class="altColor">
 <td class="colFirst"><a name="org.apache.hadoop.hbase.Version.srcChecksum">

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/devapidocs/src-html/org/apache/hadoop/hbase/Version.html
----------------------------------------------------------------------
diff --git a/devapidocs/src-html/org/apache/hadoop/hbase/Version.html b/devapidocs/src-html/org/apache/hadoop/hbase/Version.html
index 6de369b..234b568 100644
--- a/devapidocs/src-html/org/apache/hadoop/hbase/Version.html
+++ b/devapidocs/src-html/org/apache/hadoop/hbase/Version.html
@@ -16,9 +16,9 @@
 <span class="sourceLineNo">008</span>@InterfaceAudience.Private<a name="line.8"></a>
 <span class="sourceLineNo">009</span>public class Version {<a name="line.9"></a>
 <span class="sourceLineNo">010</span>  public static final String version = "3.0.0-SNAPSHOT";<a name="line.10"></a>
-<span class="sourceLineNo">011</span>  public static final String revision = "7a5b0783068415eaca70ea2ca938ecbfe3bed30f";<a name="line.11"></a>
+<span class="sourceLineNo">011</span>  public static final String revision = "3c02d9681b2d777677ce2ce1b21c2537ddd91817";<a name="line.11"></a>
 <span class="sourceLineNo">012</span>  public static final String user = "jenkins";<a name="line.12"></a>
-<span class="sourceLineNo">013</span>  public static final String date = "Sun Dec  3 14:42:16 UTC 2017";<a name="line.13"></a>
+<span class="sourceLineNo">013</span>  public static final String date = "Mon Dec  4 14:47:11 UTC 2017";<a name="line.13"></a>
 <span class="sourceLineNo">014</span>  public static final String url = "git://asf920.gq1.ygridcore.net/home/jenkins/jenkins-slave/workspace/hbase_generate_website/hbase";<a name="line.14"></a>
 <span class="sourceLineNo">015</span>  public static final String srcChecksum = "30495beff23a8606d12cf6be21433aa2";<a name="line.15"></a>
 <span class="sourceLineNo">016</span>}<a name="line.16"></a>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/export_control.html
----------------------------------------------------------------------
diff --git a/export_control.html b/export_control.html
index 67b3b3a..6e674a9 100644
--- a/export_control.html
+++ b/export_control.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase &#x2013; 
       Export Control
@@ -336,7 +336,7 @@ for more details.</p>
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/checkstyle.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/checkstyle.html b/hbase-annotations/checkstyle.html
index fac2533..5256c7a 100644
--- a/hbase-annotations/checkstyle.html
+++ b/hbase-annotations/checkstyle.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Checkstyle Results</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -178,7 +178,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependencies.html b/hbase-annotations/dependencies.html
index 9a77e72..8a27635 100644
--- a/hbase-annotations/dependencies.html
+++ b/hbase-annotations/dependencies.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -272,7 +272,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-convergence.html b/hbase-annotations/dependency-convergence.html
index 25d7611..ddc2626 100644
--- a/hbase-annotations/dependency-convergence.html
+++ b/hbase-annotations/dependency-convergence.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Reactor Dependency Convergence</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -838,7 +838,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-info.html b/hbase-annotations/dependency-info.html
index 7996c78..20b3294 100644
--- a/hbase-annotations/dependency-info.html
+++ b/hbase-annotations/dependency-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Dependency Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -147,7 +147,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-management.html b/hbase-annotations/dependency-management.html
index 335511e..6a19449 100644
--- a/hbase-annotations/dependency-management.html
+++ b/hbase-annotations/dependency-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Dependency Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -804,7 +804,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/index.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/index.html b/hbase-annotations/index.html
index 244c2b6..50b2ca4 100644
--- a/hbase-annotations/index.html
+++ b/hbase-annotations/index.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; About</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -119,7 +119,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/integration.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/integration.html b/hbase-annotations/integration.html
index 96d7d65..807f143 100644
--- a/hbase-annotations/integration.html
+++ b/hbase-annotations/integration.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; CI Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -126,7 +126,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/issue-tracking.html b/hbase-annotations/issue-tracking.html
index 8e73ddb..1fbaaba 100644
--- a/hbase-annotations/issue-tracking.html
+++ b/hbase-annotations/issue-tracking.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Issue Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -123,7 +123,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/license.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/license.html b/hbase-annotations/license.html
index 7d3b49b..102f3c3 100644
--- a/hbase-annotations/license.html
+++ b/hbase-annotations/license.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Licenses</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -326,7 +326,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/mail-lists.html b/hbase-annotations/mail-lists.html
index aba24c5..6d705f9 100644
--- a/hbase-annotations/mail-lists.html
+++ b/hbase-annotations/mail-lists.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Mailing Lists</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -176,7 +176,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/plugin-management.html b/hbase-annotations/plugin-management.html
index 06a6cb9..30ce040 100644
--- a/hbase-annotations/plugin-management.html
+++ b/hbase-annotations/plugin-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Plugin Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -271,7 +271,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/plugins.html b/hbase-annotations/plugins.html
index ca92936..48159e5 100644
--- a/hbase-annotations/plugins.html
+++ b/hbase-annotations/plugins.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Plugins</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -222,7 +222,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/project-info.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-info.html b/hbase-annotations/project-info.html
index a9a3e19..3d21545 100644
--- a/hbase-annotations/project-info.html
+++ b/hbase-annotations/project-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -167,7 +167,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/project-reports.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-reports.html b/hbase-annotations/project-reports.html
index 24764ae..92d3a73 100644
--- a/hbase-annotations/project-reports.html
+++ b/hbase-annotations/project-reports.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Generated Reports</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -128,7 +128,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/project-summary.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-summary.html b/hbase-annotations/project-summary.html
index 3580c0b..6e1a36b 100644
--- a/hbase-annotations/project-summary.html
+++ b/hbase-annotations/project-summary.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Summary</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -166,7 +166,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/source-repository.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/source-repository.html b/hbase-annotations/source-repository.html
index 295a0e1..c23773e 100644
--- a/hbase-annotations/source-repository.html
+++ b/hbase-annotations/source-repository.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Source Code Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -134,7 +134,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-annotations/team-list.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/team-list.html b/hbase-annotations/team-list.html
index cdbfbe1..468d604 100644
--- a/hbase-annotations/team-list.html
+++ b/hbase-annotations/team-list.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Annotations &#x2013; Project Team</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -547,7 +547,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependencies.html b/hbase-build-configuration/dependencies.html
index f779c0f..d1d2693 100644
--- a/hbase-build-configuration/dependencies.html
+++ b/hbase-build-configuration/dependencies.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -330,7 +330,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-convergence.html b/hbase-build-configuration/dependency-convergence.html
index 56f97ad..9a2d516 100644
--- a/hbase-build-configuration/dependency-convergence.html
+++ b/hbase-build-configuration/dependency-convergence.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Reactor Dependency Convergence</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -838,7 +838,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-info.html b/hbase-build-configuration/dependency-info.html
index ac27e6d..231fdeb 100644
--- a/hbase-build-configuration/dependency-info.html
+++ b/hbase-build-configuration/dependency-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Dependency Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -148,7 +148,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-management.html b/hbase-build-configuration/dependency-management.html
index df49221..c5b19b5 100644
--- a/hbase-build-configuration/dependency-management.html
+++ b/hbase-build-configuration/dependency-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Build Configuration &#x2013; Project Dependency Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -804,7 +804,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/dependencies.html b/hbase-build-configuration/hbase-archetypes/dependencies.html
index 67536b6..1f1b104 100644
--- a/hbase-build-configuration/hbase-archetypes/dependencies.html
+++ b/hbase-build-configuration/hbase-archetypes/dependencies.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -330,7 +330,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/dependency-convergence.html b/hbase-build-configuration/hbase-archetypes/dependency-convergence.html
index 96c646a..dc596db 100644
--- a/hbase-build-configuration/hbase-archetypes/dependency-convergence.html
+++ b/hbase-build-configuration/hbase-archetypes/dependency-convergence.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Reactor Dependency Convergence</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -838,7 +838,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/dependency-info.html b/hbase-build-configuration/hbase-archetypes/dependency-info.html
index 43a9022..85d43ce 100644
--- a/hbase-build-configuration/hbase-archetypes/dependency-info.html
+++ b/hbase-build-configuration/hbase-archetypes/dependency-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Dependency Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -148,7 +148,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/dependency-management.html b/hbase-build-configuration/hbase-archetypes/dependency-management.html
index 9bd0e0e..f17991c 100644
--- a/hbase-build-configuration/hbase-archetypes/dependency-management.html
+++ b/hbase-build-configuration/hbase-archetypes/dependency-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetypes &#x2013; Project Dependency Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -804,7 +804,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependencies.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependencies.html
index e51e2e3..a93faea 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependencies.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependencies.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -330,7 +330,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-convergence.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-convergence.html
index 96dbbf9..39c8c07 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-convergence.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-convergence.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Reactor Dependency Convergence</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -838,7 +838,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-info.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-info.html
index 8b3e2b8..4c966b2 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-info.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-info.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Dependency Information</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -148,7 +148,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-management.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-management.html
index 9ddef5a..83d2d7b 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-management.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/dependency-management.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Project Dependency Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -804,7 +804,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/index.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/index.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/index.html
index b6c51a5..7bfbf0f 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/index.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/index.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; About</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -119,7 +119,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/integration.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/integration.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/integration.html
index be52b0c..602a9f6 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/integration.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/integration.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; CI Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -126,7 +126,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/issue-tracking.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/issue-tracking.html
index 4c9ea7a..205e107 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/issue-tracking.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/issue-tracking.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Issue Management</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -123,7 +123,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/license.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/license.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/license.html
index 9b72fb6..2c00ddd 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/license.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/license.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Project Licenses</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -326,7 +326,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/mail-lists.html b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/mail-lists.html
index bbc14a8..129fdc3 100644
--- a/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/mail-lists.html
+++ b/hbase-build-configuration/hbase-archetypes/hbase-archetype-builder/mail-lists.html
@@ -7,7 +7,7 @@
   <head>
     <meta charset="UTF-8" />
     <meta name="viewport" content="width=device-width, initial-scale=1.0" />
-    <meta name="Date-Revision-yyyymmdd" content="20171203" />
+    <meta name="Date-Revision-yyyymmdd" content="20171204" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Archetype builder &#x2013; Project Mailing Lists</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -176,7 +176,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2017-12-03</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-04</li>
             </p>
                 </div>
 


[04/14] hbase-site git commit: Published site at .

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/29385b7e/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html b/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html
index 0cec549..06b92ba 100644
--- a/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html
+++ b/testdevapidocs/src-html/org/apache/hadoop/hbase/HBaseTestingUtility.PortAllocator.html
@@ -2518,1796 +2518,1811 @@
 <span class="sourceLineNo">2510</span>    return rows;<a name="line.2510"></a>
 <span class="sourceLineNo">2511</span>  }<a name="line.2511"></a>
 <span class="sourceLineNo">2512</span><a name="line.2512"></a>
-<span class="sourceLineNo">2513</span>  /**<a name="line.2513"></a>
-<span class="sourceLineNo">2514</span>   * Tool to get the reference to the region server object that holds the<a name="line.2514"></a>
-<span class="sourceLineNo">2515</span>   * region of the specified user table.<a name="line.2515"></a>
-<span class="sourceLineNo">2516</span>   * It first searches for the meta rows that contain the region of the<a name="line.2516"></a>
-<span class="sourceLineNo">2517</span>   * specified table, then gets the index of that RS, and finally retrieves<a name="line.2517"></a>
-<span class="sourceLineNo">2518</span>   * the RS's reference.<a name="line.2518"></a>
-<span class="sourceLineNo">2519</span>   * @param tableName user table to lookup in hbase:meta<a name="line.2519"></a>
-<span class="sourceLineNo">2520</span>   * @return region server that holds it, null if the row doesn't exist<a name="line.2520"></a>
-<span class="sourceLineNo">2521</span>   * @throws IOException<a name="line.2521"></a>
-<span class="sourceLineNo">2522</span>   * @throws InterruptedException<a name="line.2522"></a>
-<span class="sourceLineNo">2523</span>   */<a name="line.2523"></a>
-<span class="sourceLineNo">2524</span>  public HRegionServer getRSForFirstRegionInTable(TableName tableName)<a name="line.2524"></a>
-<span class="sourceLineNo">2525</span>      throws IOException, InterruptedException {<a name="line.2525"></a>
-<span class="sourceLineNo">2526</span>    List&lt;byte[]&gt; metaRows = getMetaTableRows(tableName);<a name="line.2526"></a>
-<span class="sourceLineNo">2527</span>    if (metaRows == null || metaRows.isEmpty()) {<a name="line.2527"></a>
-<span class="sourceLineNo">2528</span>      return null;<a name="line.2528"></a>
-<span class="sourceLineNo">2529</span>    }<a name="line.2529"></a>
-<span class="sourceLineNo">2530</span>    LOG.debug("Found " + metaRows.size() + " rows for table " +<a name="line.2530"></a>
-<span class="sourceLineNo">2531</span>      tableName);<a name="line.2531"></a>
-<span class="sourceLineNo">2532</span>    byte [] firstrow = metaRows.get(0);<a name="line.2532"></a>
-<span class="sourceLineNo">2533</span>    LOG.debug("FirstRow=" + Bytes.toString(firstrow));<a name="line.2533"></a>
-<span class="sourceLineNo">2534</span>    long pause = getConfiguration().getLong(HConstants.HBASE_CLIENT_PAUSE,<a name="line.2534"></a>
-<span class="sourceLineNo">2535</span>      HConstants.DEFAULT_HBASE_CLIENT_PAUSE);<a name="line.2535"></a>
-<span class="sourceLineNo">2536</span>    int numRetries = getConfiguration().getInt(HConstants.HBASE_CLIENT_RETRIES_NUMBER,<a name="line.2536"></a>
-<span class="sourceLineNo">2537</span>      HConstants.DEFAULT_HBASE_CLIENT_RETRIES_NUMBER);<a name="line.2537"></a>
-<span class="sourceLineNo">2538</span>    RetryCounter retrier = new RetryCounter(numRetries+1, (int)pause, TimeUnit.MICROSECONDS);<a name="line.2538"></a>
-<span class="sourceLineNo">2539</span>    while(retrier.shouldRetry()) {<a name="line.2539"></a>
-<span class="sourceLineNo">2540</span>      int index = getMiniHBaseCluster().getServerWith(firstrow);<a name="line.2540"></a>
-<span class="sourceLineNo">2541</span>      if (index != -1) {<a name="line.2541"></a>
-<span class="sourceLineNo">2542</span>        return getMiniHBaseCluster().getRegionServerThreads().get(index).getRegionServer();<a name="line.2542"></a>
-<span class="sourceLineNo">2543</span>      }<a name="line.2543"></a>
-<span class="sourceLineNo">2544</span>      // Came back -1.  Region may not be online yet.  Sleep a while.<a name="line.2544"></a>
-<span class="sourceLineNo">2545</span>      retrier.sleepUntilNextRetry();<a name="line.2545"></a>
-<span class="sourceLineNo">2546</span>    }<a name="line.2546"></a>
-<span class="sourceLineNo">2547</span>    return null;<a name="line.2547"></a>
-<span class="sourceLineNo">2548</span>  }<a name="line.2548"></a>
-<span class="sourceLineNo">2549</span><a name="line.2549"></a>
-<span class="sourceLineNo">2550</span>  /**<a name="line.2550"></a>
-<span class="sourceLineNo">2551</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt; with a default number of<a name="line.2551"></a>
-<span class="sourceLineNo">2552</span>   * &lt;code&gt;TaskTracker&lt;/code&gt;'s.<a name="line.2552"></a>
-<span class="sourceLineNo">2553</span>   *<a name="line.2553"></a>
-<span class="sourceLineNo">2554</span>   * @throws IOException When starting the cluster fails.<a name="line.2554"></a>
-<span class="sourceLineNo">2555</span>   */<a name="line.2555"></a>
-<span class="sourceLineNo">2556</span>  public MiniMRCluster startMiniMapReduceCluster() throws IOException {<a name="line.2556"></a>
-<span class="sourceLineNo">2557</span>    // Set a very high max-disk-utilization percentage to avoid the NodeManagers from failing.<a name="line.2557"></a>
-<span class="sourceLineNo">2558</span>    conf.setIfUnset(<a name="line.2558"></a>
-<span class="sourceLineNo">2559</span>        "yarn.nodemanager.disk-health-checker.max-disk-utilization-per-disk-percentage",<a name="line.2559"></a>
-<span class="sourceLineNo">2560</span>        "99.0");<a name="line.2560"></a>
-<span class="sourceLineNo">2561</span>    startMiniMapReduceCluster(2);<a name="line.2561"></a>
-<span class="sourceLineNo">2562</span>    return mrCluster;<a name="line.2562"></a>
+<span class="sourceLineNo">2513</span>  /*<a name="line.2513"></a>
+<span class="sourceLineNo">2514</span>   * Find any other region server which is different from the one identified by parameter<a name="line.2514"></a>
+<span class="sourceLineNo">2515</span>   * @param rs<a name="line.2515"></a>
+<span class="sourceLineNo">2516</span>   * @return another region server<a name="line.2516"></a>
+<span class="sourceLineNo">2517</span>   */<a name="line.2517"></a>
+<span class="sourceLineNo">2518</span>  public HRegionServer getOtherRegionServer(HRegionServer rs) {<a name="line.2518"></a>
+<span class="sourceLineNo">2519</span>    for (JVMClusterUtil.RegionServerThread rst :<a name="line.2519"></a>
+<span class="sourceLineNo">2520</span>      getMiniHBaseCluster().getRegionServerThreads()) {<a name="line.2520"></a>
+<span class="sourceLineNo">2521</span>      if (!(rst.getRegionServer() == rs)) {<a name="line.2521"></a>
+<span class="sourceLineNo">2522</span>        return rst.getRegionServer();<a name="line.2522"></a>
+<span class="sourceLineNo">2523</span>      }<a name="line.2523"></a>
+<span class="sourceLineNo">2524</span>    }<a name="line.2524"></a>
+<span class="sourceLineNo">2525</span>    return null;<a name="line.2525"></a>
+<span class="sourceLineNo">2526</span>  }<a name="line.2526"></a>
+<span class="sourceLineNo">2527</span><a name="line.2527"></a>
+<span class="sourceLineNo">2528</span>  /**<a name="line.2528"></a>
+<span class="sourceLineNo">2529</span>   * Tool to get the reference to the region server object that holds the<a name="line.2529"></a>
+<span class="sourceLineNo">2530</span>   * region of the specified user table.<a name="line.2530"></a>
+<span class="sourceLineNo">2531</span>   * It first searches for the meta rows that contain the region of the<a name="line.2531"></a>
+<span class="sourceLineNo">2532</span>   * specified table, then gets the index of that RS, and finally retrieves<a name="line.2532"></a>
+<span class="sourceLineNo">2533</span>   * the RS's reference.<a name="line.2533"></a>
+<span class="sourceLineNo">2534</span>   * @param tableName user table to lookup in hbase:meta<a name="line.2534"></a>
+<span class="sourceLineNo">2535</span>   * @return region server that holds it, null if the row doesn't exist<a name="line.2535"></a>
+<span class="sourceLineNo">2536</span>   * @throws IOException<a name="line.2536"></a>
+<span class="sourceLineNo">2537</span>   * @throws InterruptedException<a name="line.2537"></a>
+<span class="sourceLineNo">2538</span>   */<a name="line.2538"></a>
+<span class="sourceLineNo">2539</span>  public HRegionServer getRSForFirstRegionInTable(TableName tableName)<a name="line.2539"></a>
+<span class="sourceLineNo">2540</span>      throws IOException, InterruptedException {<a name="line.2540"></a>
+<span class="sourceLineNo">2541</span>    List&lt;byte[]&gt; metaRows = getMetaTableRows(tableName);<a name="line.2541"></a>
+<span class="sourceLineNo">2542</span>    if (metaRows == null || metaRows.isEmpty()) {<a name="line.2542"></a>
+<span class="sourceLineNo">2543</span>      return null;<a name="line.2543"></a>
+<span class="sourceLineNo">2544</span>    }<a name="line.2544"></a>
+<span class="sourceLineNo">2545</span>    LOG.debug("Found " + metaRows.size() + " rows for table " +<a name="line.2545"></a>
+<span class="sourceLineNo">2546</span>      tableName);<a name="line.2546"></a>
+<span class="sourceLineNo">2547</span>    byte [] firstrow = metaRows.get(0);<a name="line.2547"></a>
+<span class="sourceLineNo">2548</span>    LOG.debug("FirstRow=" + Bytes.toString(firstrow));<a name="line.2548"></a>
+<span class="sourceLineNo">2549</span>    long pause = getConfiguration().getLong(HConstants.HBASE_CLIENT_PAUSE,<a name="line.2549"></a>
+<span class="sourceLineNo">2550</span>      HConstants.DEFAULT_HBASE_CLIENT_PAUSE);<a name="line.2550"></a>
+<span class="sourceLineNo">2551</span>    int numRetries = getConfiguration().getInt(HConstants.HBASE_CLIENT_RETRIES_NUMBER,<a name="line.2551"></a>
+<span class="sourceLineNo">2552</span>      HConstants.DEFAULT_HBASE_CLIENT_RETRIES_NUMBER);<a name="line.2552"></a>
+<span class="sourceLineNo">2553</span>    RetryCounter retrier = new RetryCounter(numRetries+1, (int)pause, TimeUnit.MICROSECONDS);<a name="line.2553"></a>
+<span class="sourceLineNo">2554</span>    while(retrier.shouldRetry()) {<a name="line.2554"></a>
+<span class="sourceLineNo">2555</span>      int index = getMiniHBaseCluster().getServerWith(firstrow);<a name="line.2555"></a>
+<span class="sourceLineNo">2556</span>      if (index != -1) {<a name="line.2556"></a>
+<span class="sourceLineNo">2557</span>        return getMiniHBaseCluster().getRegionServerThreads().get(index).getRegionServer();<a name="line.2557"></a>
+<span class="sourceLineNo">2558</span>      }<a name="line.2558"></a>
+<span class="sourceLineNo">2559</span>      // Came back -1.  Region may not be online yet.  Sleep a while.<a name="line.2559"></a>
+<span class="sourceLineNo">2560</span>      retrier.sleepUntilNextRetry();<a name="line.2560"></a>
+<span class="sourceLineNo">2561</span>    }<a name="line.2561"></a>
+<span class="sourceLineNo">2562</span>    return null;<a name="line.2562"></a>
 <span class="sourceLineNo">2563</span>  }<a name="line.2563"></a>
 <span class="sourceLineNo">2564</span><a name="line.2564"></a>
 <span class="sourceLineNo">2565</span>  /**<a name="line.2565"></a>
-<span class="sourceLineNo">2566</span>   * Tasktracker has a bug where changing the hadoop.log.dir system property<a name="line.2566"></a>
-<span class="sourceLineNo">2567</span>   * will not change its internal static LOG_DIR variable.<a name="line.2567"></a>
-<span class="sourceLineNo">2568</span>   */<a name="line.2568"></a>
-<span class="sourceLineNo">2569</span>  private void forceChangeTaskLogDir() {<a name="line.2569"></a>
-<span class="sourceLineNo">2570</span>    Field logDirField;<a name="line.2570"></a>
-<span class="sourceLineNo">2571</span>    try {<a name="line.2571"></a>
-<span class="sourceLineNo">2572</span>      logDirField = TaskLog.class.getDeclaredField("LOG_DIR");<a name="line.2572"></a>
-<span class="sourceLineNo">2573</span>      logDirField.setAccessible(true);<a name="line.2573"></a>
-<span class="sourceLineNo">2574</span><a name="line.2574"></a>
-<span class="sourceLineNo">2575</span>      Field modifiersField = Field.class.getDeclaredField("modifiers");<a name="line.2575"></a>
-<span class="sourceLineNo">2576</span>      modifiersField.setAccessible(true);<a name="line.2576"></a>
-<span class="sourceLineNo">2577</span>      modifiersField.setInt(logDirField, logDirField.getModifiers() &amp; ~Modifier.FINAL);<a name="line.2577"></a>
-<span class="sourceLineNo">2578</span><a name="line.2578"></a>
-<span class="sourceLineNo">2579</span>      logDirField.set(null, new File(hadoopLogDir, "userlogs"));<a name="line.2579"></a>
-<span class="sourceLineNo">2580</span>    } catch (SecurityException e) {<a name="line.2580"></a>
-<span class="sourceLineNo">2581</span>      throw new RuntimeException(e);<a name="line.2581"></a>
-<span class="sourceLineNo">2582</span>    } catch (NoSuchFieldException e) {<a name="line.2582"></a>
-<span class="sourceLineNo">2583</span>      // TODO Auto-generated catch block<a name="line.2583"></a>
-<span class="sourceLineNo">2584</span>      throw new RuntimeException(e);<a name="line.2584"></a>
-<span class="sourceLineNo">2585</span>    } catch (IllegalArgumentException e) {<a name="line.2585"></a>
-<span class="sourceLineNo">2586</span>      throw new RuntimeException(e);<a name="line.2586"></a>
-<span class="sourceLineNo">2587</span>    } catch (IllegalAccessException e) {<a name="line.2587"></a>
-<span class="sourceLineNo">2588</span>      throw new RuntimeException(e);<a name="line.2588"></a>
-<span class="sourceLineNo">2589</span>    }<a name="line.2589"></a>
-<span class="sourceLineNo">2590</span>  }<a name="line.2590"></a>
-<span class="sourceLineNo">2591</span><a name="line.2591"></a>
-<span class="sourceLineNo">2592</span>  /**<a name="line.2592"></a>
-<span class="sourceLineNo">2593</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt;. Call {@link #setFileSystemURI(String)} to use a different<a name="line.2593"></a>
-<span class="sourceLineNo">2594</span>   * filesystem.<a name="line.2594"></a>
-<span class="sourceLineNo">2595</span>   * @param servers  The number of &lt;code&gt;TaskTracker&lt;/code&gt;'s to start.<a name="line.2595"></a>
-<span class="sourceLineNo">2596</span>   * @throws IOException When starting the cluster fails.<a name="line.2596"></a>
-<span class="sourceLineNo">2597</span>   */<a name="line.2597"></a>
-<span class="sourceLineNo">2598</span>  private void startMiniMapReduceCluster(final int servers) throws IOException {<a name="line.2598"></a>
-<span class="sourceLineNo">2599</span>    if (mrCluster != null) {<a name="line.2599"></a>
-<span class="sourceLineNo">2600</span>      throw new IllegalStateException("MiniMRCluster is already running");<a name="line.2600"></a>
-<span class="sourceLineNo">2601</span>    }<a name="line.2601"></a>
-<span class="sourceLineNo">2602</span>    LOG.info("Starting mini mapreduce cluster...");<a name="line.2602"></a>
-<span class="sourceLineNo">2603</span>    setupClusterTestDir();<a name="line.2603"></a>
-<span class="sourceLineNo">2604</span>    createDirsAndSetProperties();<a name="line.2604"></a>
-<span class="sourceLineNo">2605</span><a name="line.2605"></a>
-<span class="sourceLineNo">2606</span>    forceChangeTaskLogDir();<a name="line.2606"></a>
-<span class="sourceLineNo">2607</span><a name="line.2607"></a>
-<span class="sourceLineNo">2608</span>    //// hadoop2 specific settings<a name="line.2608"></a>
-<span class="sourceLineNo">2609</span>    // Tests were failing because this process used 6GB of virtual memory and was getting killed.<a name="line.2609"></a>
-<span class="sourceLineNo">2610</span>    // we up the VM usable so that processes don't get killed.<a name="line.2610"></a>
-<span class="sourceLineNo">2611</span>    conf.setFloat("yarn.nodemanager.vmem-pmem-ratio", 8.0f);<a name="line.2611"></a>
-<span class="sourceLineNo">2612</span><a name="line.2612"></a>
-<span class="sourceLineNo">2613</span>    // Tests were failing due to MAPREDUCE-4880 / MAPREDUCE-4607 against hadoop 2.0.2-alpha and<a name="line.2613"></a>
-<span class="sourceLineNo">2614</span>    // this avoids the problem by disabling speculative task execution in tests.<a name="line.2614"></a>
-<span class="sourceLineNo">2615</span>    conf.setBoolean("mapreduce.map.speculative", false);<a name="line.2615"></a>
-<span class="sourceLineNo">2616</span>    conf.setBoolean("mapreduce.reduce.speculative", false);<a name="line.2616"></a>
-<span class="sourceLineNo">2617</span>    ////<a name="line.2617"></a>
-<span class="sourceLineNo">2618</span><a name="line.2618"></a>
-<span class="sourceLineNo">2619</span>    // Allow the user to override FS URI for this map-reduce cluster to use.<a name="line.2619"></a>
-<span class="sourceLineNo">2620</span>    mrCluster = new MiniMRCluster(servers,<a name="line.2620"></a>
-<span class="sourceLineNo">2621</span>      FS_URI != null ? FS_URI : FileSystem.get(conf).getUri().toString(), 1,<a name="line.2621"></a>
-<span class="sourceLineNo">2622</span>      null, null, new JobConf(this.conf));<a name="line.2622"></a>
-<span class="sourceLineNo">2623</span>    JobConf jobConf = MapreduceTestingShim.getJobConf(mrCluster);<a name="line.2623"></a>
-<span class="sourceLineNo">2624</span>    if (jobConf == null) {<a name="line.2624"></a>
-<span class="sourceLineNo">2625</span>      jobConf = mrCluster.createJobConf();<a name="line.2625"></a>
-<span class="sourceLineNo">2626</span>    }<a name="line.2626"></a>
+<span class="sourceLineNo">2566</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt; with a default number of<a name="line.2566"></a>
+<span class="sourceLineNo">2567</span>   * &lt;code&gt;TaskTracker&lt;/code&gt;'s.<a name="line.2567"></a>
+<span class="sourceLineNo">2568</span>   *<a name="line.2568"></a>
+<span class="sourceLineNo">2569</span>   * @throws IOException When starting the cluster fails.<a name="line.2569"></a>
+<span class="sourceLineNo">2570</span>   */<a name="line.2570"></a>
+<span class="sourceLineNo">2571</span>  public MiniMRCluster startMiniMapReduceCluster() throws IOException {<a name="line.2571"></a>
+<span class="sourceLineNo">2572</span>    // Set a very high max-disk-utilization percentage to avoid the NodeManagers from failing.<a name="line.2572"></a>
+<span class="sourceLineNo">2573</span>    conf.setIfUnset(<a name="line.2573"></a>
+<span class="sourceLineNo">2574</span>        "yarn.nodemanager.disk-health-checker.max-disk-utilization-per-disk-percentage",<a name="line.2574"></a>
+<span class="sourceLineNo">2575</span>        "99.0");<a name="line.2575"></a>
+<span class="sourceLineNo">2576</span>    startMiniMapReduceCluster(2);<a name="line.2576"></a>
+<span class="sourceLineNo">2577</span>    return mrCluster;<a name="line.2577"></a>
+<span class="sourceLineNo">2578</span>  }<a name="line.2578"></a>
+<span class="sourceLineNo">2579</span><a name="line.2579"></a>
+<span class="sourceLineNo">2580</span>  /**<a name="line.2580"></a>
+<span class="sourceLineNo">2581</span>   * Tasktracker has a bug where changing the hadoop.log.dir system property<a name="line.2581"></a>
+<span class="sourceLineNo">2582</span>   * will not change its internal static LOG_DIR variable.<a name="line.2582"></a>
+<span class="sourceLineNo">2583</span>   */<a name="line.2583"></a>
+<span class="sourceLineNo">2584</span>  private void forceChangeTaskLogDir() {<a name="line.2584"></a>
+<span class="sourceLineNo">2585</span>    Field logDirField;<a name="line.2585"></a>
+<span class="sourceLineNo">2586</span>    try {<a name="line.2586"></a>
+<span class="sourceLineNo">2587</span>      logDirField = TaskLog.class.getDeclaredField("LOG_DIR");<a name="line.2587"></a>
+<span class="sourceLineNo">2588</span>      logDirField.setAccessible(true);<a name="line.2588"></a>
+<span class="sourceLineNo">2589</span><a name="line.2589"></a>
+<span class="sourceLineNo">2590</span>      Field modifiersField = Field.class.getDeclaredField("modifiers");<a name="line.2590"></a>
+<span class="sourceLineNo">2591</span>      modifiersField.setAccessible(true);<a name="line.2591"></a>
+<span class="sourceLineNo">2592</span>      modifiersField.setInt(logDirField, logDirField.getModifiers() &amp; ~Modifier.FINAL);<a name="line.2592"></a>
+<span class="sourceLineNo">2593</span><a name="line.2593"></a>
+<span class="sourceLineNo">2594</span>      logDirField.set(null, new File(hadoopLogDir, "userlogs"));<a name="line.2594"></a>
+<span class="sourceLineNo">2595</span>    } catch (SecurityException e) {<a name="line.2595"></a>
+<span class="sourceLineNo">2596</span>      throw new RuntimeException(e);<a name="line.2596"></a>
+<span class="sourceLineNo">2597</span>    } catch (NoSuchFieldException e) {<a name="line.2597"></a>
+<span class="sourceLineNo">2598</span>      // TODO Auto-generated catch block<a name="line.2598"></a>
+<span class="sourceLineNo">2599</span>      throw new RuntimeException(e);<a name="line.2599"></a>
+<span class="sourceLineNo">2600</span>    } catch (IllegalArgumentException e) {<a name="line.2600"></a>
+<span class="sourceLineNo">2601</span>      throw new RuntimeException(e);<a name="line.2601"></a>
+<span class="sourceLineNo">2602</span>    } catch (IllegalAccessException e) {<a name="line.2602"></a>
+<span class="sourceLineNo">2603</span>      throw new RuntimeException(e);<a name="line.2603"></a>
+<span class="sourceLineNo">2604</span>    }<a name="line.2604"></a>
+<span class="sourceLineNo">2605</span>  }<a name="line.2605"></a>
+<span class="sourceLineNo">2606</span><a name="line.2606"></a>
+<span class="sourceLineNo">2607</span>  /**<a name="line.2607"></a>
+<span class="sourceLineNo">2608</span>   * Starts a &lt;code&gt;MiniMRCluster&lt;/code&gt;. Call {@link #setFileSystemURI(String)} to use a different<a name="line.2608"></a>
+<span class="sourceLineNo">2609</span>   * filesystem.<a name="line.2609"></a>
+<span class="sourceLineNo">2610</span>   * @param servers  The number of &lt;code&gt;TaskTracker&lt;/code&gt;'s to start.<a name="line.2610"></a>
+<span class="sourceLineNo">2611</span>   * @throws IOException When starting the cluster fails.<a name="line.2611"></a>
+<span class="sourceLineNo">2612</span>   */<a name="line.2612"></a>
+<span class="sourceLineNo">2613</span>  private void startMiniMapReduceCluster(final int servers) throws IOException {<a name="line.2613"></a>
+<span class="sourceLineNo">2614</span>    if (mrCluster != null) {<a name="line.2614"></a>
+<span class="sourceLineNo">2615</span>      throw new IllegalStateException("MiniMRCluster is already running");<a name="line.2615"></a>
+<span class="sourceLineNo">2616</span>    }<a name="line.2616"></a>
+<span class="sourceLineNo">2617</span>    LOG.info("Starting mini mapreduce cluster...");<a name="line.2617"></a>
+<span class="sourceLineNo">2618</span>    setupClusterTestDir();<a name="line.2618"></a>
+<span class="sourceLineNo">2619</span>    createDirsAndSetProperties();<a name="line.2619"></a>
+<span class="sourceLineNo">2620</span><a name="line.2620"></a>
+<span class="sourceLineNo">2621</span>    forceChangeTaskLogDir();<a name="line.2621"></a>
+<span class="sourceLineNo">2622</span><a name="line.2622"></a>
+<span class="sourceLineNo">2623</span>    //// hadoop2 specific settings<a name="line.2623"></a>
+<span class="sourceLineNo">2624</span>    // Tests were failing because this process used 6GB of virtual memory and was getting killed.<a name="line.2624"></a>
+<span class="sourceLineNo">2625</span>    // we up the VM usable so that processes don't get killed.<a name="line.2625"></a>
+<span class="sourceLineNo">2626</span>    conf.setFloat("yarn.nodemanager.vmem-pmem-ratio", 8.0f);<a name="line.2626"></a>
 <span class="sourceLineNo">2627</span><a name="line.2627"></a>
-<span class="sourceLineNo">2628</span>    jobConf.set("mapreduce.cluster.local.dir",<a name="line.2628"></a>
-<span class="sourceLineNo">2629</span>      conf.get("mapreduce.cluster.local.dir")); //Hadoop MiniMR overwrites this while it should not<a name="line.2629"></a>
-<span class="sourceLineNo">2630</span>    LOG.info("Mini mapreduce cluster started");<a name="line.2630"></a>
-<span class="sourceLineNo">2631</span><a name="line.2631"></a>
-<span class="sourceLineNo">2632</span>    // In hadoop2, YARN/MR2 starts a mini cluster with its own conf instance and updates settings.<a name="line.2632"></a>
-<span class="sourceLineNo">2633</span>    // Our HBase MR jobs need several of these settings in order to properly run.  So we copy the<a name="line.2633"></a>
-<span class="sourceLineNo">2634</span>    // necessary config properties here.  YARN-129 required adding a few properties.<a name="line.2634"></a>
-<span class="sourceLineNo">2635</span>    conf.set("mapreduce.jobtracker.address", jobConf.get("mapreduce.jobtracker.address"));<a name="line.2635"></a>
-<span class="sourceLineNo">2636</span>    // this for mrv2 support; mr1 ignores this<a name="line.2636"></a>
-<span class="sourceLineNo">2637</span>    conf.set("mapreduce.framework.name", "yarn");<a name="line.2637"></a>
-<span class="sourceLineNo">2638</span>    conf.setBoolean("yarn.is.minicluster", true);<a name="line.2638"></a>
-<span class="sourceLineNo">2639</span>    String rmAddress = jobConf.get("yarn.resourcemanager.address");<a name="line.2639"></a>
-<span class="sourceLineNo">2640</span>    if (rmAddress != null) {<a name="line.2640"></a>
-<span class="sourceLineNo">2641</span>      conf.set("yarn.resourcemanager.address", rmAddress);<a name="line.2641"></a>
-<span class="sourceLineNo">2642</span>    }<a name="line.2642"></a>
-<span class="sourceLineNo">2643</span>    String historyAddress = jobConf.get("mapreduce.jobhistory.address");<a name="line.2643"></a>
-<span class="sourceLineNo">2644</span>    if (historyAddress != null) {<a name="line.2644"></a>
-<span class="sourceLineNo">2645</span>      conf.set("mapreduce.jobhistory.address", historyAddress);<a name="line.2645"></a>
-<span class="sourceLineNo">2646</span>    }<a name="line.2646"></a>
-<span class="sourceLineNo">2647</span>    String schedulerAddress =<a name="line.2647"></a>
-<span class="sourceLineNo">2648</span>      jobConf.get("yarn.resourcemanager.scheduler.address");<a name="line.2648"></a>
-<span class="sourceLineNo">2649</span>    if (schedulerAddress != null) {<a name="line.2649"></a>
-<span class="sourceLineNo">2650</span>      conf.set("yarn.resourcemanager.scheduler.address", schedulerAddress);<a name="line.2650"></a>
-<span class="sourceLineNo">2651</span>    }<a name="line.2651"></a>
-<span class="sourceLineNo">2652</span>    String mrJobHistoryWebappAddress =<a name="line.2652"></a>
-<span class="sourceLineNo">2653</span>      jobConf.get("mapreduce.jobhistory.webapp.address");<a name="line.2653"></a>
-<span class="sourceLineNo">2654</span>    if (mrJobHistoryWebappAddress != null) {<a name="line.2654"></a>
-<span class="sourceLineNo">2655</span>      conf.set("mapreduce.jobhistory.webapp.address", mrJobHistoryWebappAddress);<a name="line.2655"></a>
-<span class="sourceLineNo">2656</span>    }<a name="line.2656"></a>
-<span class="sourceLineNo">2657</span>    String yarnRMWebappAddress =<a name="line.2657"></a>
-<span class="sourceLineNo">2658</span>      jobConf.get("yarn.resourcemanager.webapp.address");<a name="line.2658"></a>
-<span class="sourceLineNo">2659</span>    if (yarnRMWebappAddress != null) {<a name="line.2659"></a>
-<span class="sourceLineNo">2660</span>      conf.set("yarn.resourcemanager.webapp.address", yarnRMWebappAddress);<a name="line.2660"></a>
+<span class="sourceLineNo">2628</span>    // Tests were failing due to MAPREDUCE-4880 / MAPREDUCE-4607 against hadoop 2.0.2-alpha and<a name="line.2628"></a>
+<span class="sourceLineNo">2629</span>    // this avoids the problem by disabling speculative task execution in tests.<a name="line.2629"></a>
+<span class="sourceLineNo">2630</span>    conf.setBoolean("mapreduce.map.speculative", false);<a name="line.2630"></a>
+<span class="sourceLineNo">2631</span>    conf.setBoolean("mapreduce.reduce.speculative", false);<a name="line.2631"></a>
+<span class="sourceLineNo">2632</span>    ////<a name="line.2632"></a>
+<span class="sourceLineNo">2633</span><a name="line.2633"></a>
+<span class="sourceLineNo">2634</span>    // Allow the user to override FS URI for this map-reduce cluster to use.<a name="line.2634"></a>
+<span class="sourceLineNo">2635</span>    mrCluster = new MiniMRCluster(servers,<a name="line.2635"></a>
+<span class="sourceLineNo">2636</span>      FS_URI != null ? FS_URI : FileSystem.get(conf).getUri().toString(), 1,<a name="line.2636"></a>
+<span class="sourceLineNo">2637</span>      null, null, new JobConf(this.conf));<a name="line.2637"></a>
+<span class="sourceLineNo">2638</span>    JobConf jobConf = MapreduceTestingShim.getJobConf(mrCluster);<a name="line.2638"></a>
+<span class="sourceLineNo">2639</span>    if (jobConf == null) {<a name="line.2639"></a>
+<span class="sourceLineNo">2640</span>      jobConf = mrCluster.createJobConf();<a name="line.2640"></a>
+<span class="sourceLineNo">2641</span>    }<a name="line.2641"></a>
+<span class="sourceLineNo">2642</span><a name="line.2642"></a>
+<span class="sourceLineNo">2643</span>    jobConf.set("mapreduce.cluster.local.dir",<a name="line.2643"></a>
+<span class="sourceLineNo">2644</span>      conf.get("mapreduce.cluster.local.dir")); //Hadoop MiniMR overwrites this while it should not<a name="line.2644"></a>
+<span class="sourceLineNo">2645</span>    LOG.info("Mini mapreduce cluster started");<a name="line.2645"></a>
+<span class="sourceLineNo">2646</span><a name="line.2646"></a>
+<span class="sourceLineNo">2647</span>    // In hadoop2, YARN/MR2 starts a mini cluster with its own conf instance and updates settings.<a name="line.2647"></a>
+<span class="sourceLineNo">2648</span>    // Our HBase MR jobs need several of these settings in order to properly run.  So we copy the<a name="line.2648"></a>
+<span class="sourceLineNo">2649</span>    // necessary config properties here.  YARN-129 required adding a few properties.<a name="line.2649"></a>
+<span class="sourceLineNo">2650</span>    conf.set("mapreduce.jobtracker.address", jobConf.get("mapreduce.jobtracker.address"));<a name="line.2650"></a>
+<span class="sourceLineNo">2651</span>    // this for mrv2 support; mr1 ignores this<a name="line.2651"></a>
+<span class="sourceLineNo">2652</span>    conf.set("mapreduce.framework.name", "yarn");<a name="line.2652"></a>
+<span class="sourceLineNo">2653</span>    conf.setBoolean("yarn.is.minicluster", true);<a name="line.2653"></a>
+<span class="sourceLineNo">2654</span>    String rmAddress = jobConf.get("yarn.resourcemanager.address");<a name="line.2654"></a>
+<span class="sourceLineNo">2655</span>    if (rmAddress != null) {<a name="line.2655"></a>
+<span class="sourceLineNo">2656</span>      conf.set("yarn.resourcemanager.address", rmAddress);<a name="line.2656"></a>
+<span class="sourceLineNo">2657</span>    }<a name="line.2657"></a>
+<span class="sourceLineNo">2658</span>    String historyAddress = jobConf.get("mapreduce.jobhistory.address");<a name="line.2658"></a>
+<span class="sourceLineNo">2659</span>    if (historyAddress != null) {<a name="line.2659"></a>
+<span class="sourceLineNo">2660</span>      conf.set("mapreduce.jobhistory.address", historyAddress);<a name="line.2660"></a>
 <span class="sourceLineNo">2661</span>    }<a name="line.2661"></a>
-<span class="sourceLineNo">2662</span>  }<a name="line.2662"></a>
-<span class="sourceLineNo">2663</span><a name="line.2663"></a>
-<span class="sourceLineNo">2664</span>  /**<a name="line.2664"></a>
-<span class="sourceLineNo">2665</span>   * Stops the previously started &lt;code&gt;MiniMRCluster&lt;/code&gt;.<a name="line.2665"></a>
-<span class="sourceLineNo">2666</span>   */<a name="line.2666"></a>
-<span class="sourceLineNo">2667</span>  public void shutdownMiniMapReduceCluster() {<a name="line.2667"></a>
-<span class="sourceLineNo">2668</span>    if (mrCluster != null) {<a name="line.2668"></a>
-<span class="sourceLineNo">2669</span>      LOG.info("Stopping mini mapreduce cluster...");<a name="line.2669"></a>
-<span class="sourceLineNo">2670</span>      mrCluster.shutdown();<a name="line.2670"></a>
-<span class="sourceLineNo">2671</span>      mrCluster = null;<a name="line.2671"></a>
-<span class="sourceLineNo">2672</span>      LOG.info("Mini mapreduce cluster stopped");<a name="line.2672"></a>
-<span class="sourceLineNo">2673</span>    }<a name="line.2673"></a>
-<span class="sourceLineNo">2674</span>    // Restore configuration to point to local jobtracker<a name="line.2674"></a>
-<span class="sourceLineNo">2675</span>    conf.set("mapreduce.jobtracker.address", "local");<a name="line.2675"></a>
-<span class="sourceLineNo">2676</span>  }<a name="line.2676"></a>
-<span class="sourceLineNo">2677</span><a name="line.2677"></a>
-<span class="sourceLineNo">2678</span>  /**<a name="line.2678"></a>
-<span class="sourceLineNo">2679</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2679"></a>
-<span class="sourceLineNo">2680</span>   */<a name="line.2680"></a>
-<span class="sourceLineNo">2681</span>  public RegionServerServices createMockRegionServerService() throws IOException {<a name="line.2681"></a>
-<span class="sourceLineNo">2682</span>    return createMockRegionServerService((ServerName)null);<a name="line.2682"></a>
-<span class="sourceLineNo">2683</span>  }<a name="line.2683"></a>
-<span class="sourceLineNo">2684</span><a name="line.2684"></a>
-<span class="sourceLineNo">2685</span>  /**<a name="line.2685"></a>
-<span class="sourceLineNo">2686</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2686"></a>
-<span class="sourceLineNo">2687</span>   * This version is used by TestTokenAuthentication<a name="line.2687"></a>
-<span class="sourceLineNo">2688</span>   */<a name="line.2688"></a>
-<span class="sourceLineNo">2689</span>  public RegionServerServices createMockRegionServerService(RpcServerInterface rpc) throws<a name="line.2689"></a>
-<span class="sourceLineNo">2690</span>      IOException {<a name="line.2690"></a>
-<span class="sourceLineNo">2691</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher());<a name="line.2691"></a>
-<span class="sourceLineNo">2692</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2692"></a>
-<span class="sourceLineNo">2693</span>    rss.setRpcServer(rpc);<a name="line.2693"></a>
-<span class="sourceLineNo">2694</span>    return rss;<a name="line.2694"></a>
-<span class="sourceLineNo">2695</span>  }<a name="line.2695"></a>
-<span class="sourceLineNo">2696</span><a name="line.2696"></a>
-<span class="sourceLineNo">2697</span>  /**<a name="line.2697"></a>
-<span class="sourceLineNo">2698</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2698"></a>
-<span class="sourceLineNo">2699</span>   * This version is used by TestOpenRegionHandler<a name="line.2699"></a>
-<span class="sourceLineNo">2700</span>   */<a name="line.2700"></a>
-<span class="sourceLineNo">2701</span>  public RegionServerServices createMockRegionServerService(ServerName name) throws IOException {<a name="line.2701"></a>
-<span class="sourceLineNo">2702</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher(), name);<a name="line.2702"></a>
-<span class="sourceLineNo">2703</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2703"></a>
-<span class="sourceLineNo">2704</span>    return rss;<a name="line.2704"></a>
-<span class="sourceLineNo">2705</span>  }<a name="line.2705"></a>
-<span class="sourceLineNo">2706</span><a name="line.2706"></a>
-<span class="sourceLineNo">2707</span>  /**<a name="line.2707"></a>
-<span class="sourceLineNo">2708</span>   * Switches the logger for the given class to DEBUG level.<a name="line.2708"></a>
-<span class="sourceLineNo">2709</span>   *<a name="line.2709"></a>
-<span class="sourceLineNo">2710</span>   * @param clazz  The class for which to switch to debug logging.<a name="line.2710"></a>
-<span class="sourceLineNo">2711</span>   */<a name="line.2711"></a>
-<span class="sourceLineNo">2712</span>  public void enableDebug(Class&lt;?&gt; clazz) {<a name="line.2712"></a>
-<span class="sourceLineNo">2713</span>    Log l = LogFactory.getLog(clazz);<a name="line.2713"></a>
-<span class="sourceLineNo">2714</span>    if (l instanceof Log4JLogger) {<a name="line.2714"></a>
-<span class="sourceLineNo">2715</span>      ((Log4JLogger) l).getLogger().setLevel(org.apache.log4j.Level.DEBUG);<a name="line.2715"></a>
-<span class="sourceLineNo">2716</span>    } else if (l instanceof Jdk14Logger) {<a name="line.2716"></a>
-<span class="sourceLineNo">2717</span>      ((Jdk14Logger) l).getLogger().setLevel(java.util.logging.Level.ALL);<a name="line.2717"></a>
-<span class="sourceLineNo">2718</span>    }<a name="line.2718"></a>
-<span class="sourceLineNo">2719</span>  }<a name="line.2719"></a>
-<span class="sourceLineNo">2720</span><a name="line.2720"></a>
-<span class="sourceLineNo">2721</span>  /**<a name="line.2721"></a>
-<span class="sourceLineNo">2722</span>   * Expire the Master's session<a name="line.2722"></a>
-<span class="sourceLineNo">2723</span>   * @throws Exception<a name="line.2723"></a>
-<span class="sourceLineNo">2724</span>   */<a name="line.2724"></a>
-<span class="sourceLineNo">2725</span>  public void expireMasterSession() throws Exception {<a name="line.2725"></a>
-<span class="sourceLineNo">2726</span>    HMaster master = getMiniHBaseCluster().getMaster();<a name="line.2726"></a>
-<span class="sourceLineNo">2727</span>    expireSession(master.getZooKeeper(), false);<a name="line.2727"></a>
-<span class="sourceLineNo">2728</span>  }<a name="line.2728"></a>
-<span class="sourceLineNo">2729</span><a name="line.2729"></a>
-<span class="sourceLineNo">2730</span>  /**<a name="line.2730"></a>
-<span class="sourceLineNo">2731</span>   * Expire a region server's session<a name="line.2731"></a>
-<span class="sourceLineNo">2732</span>   * @param index which RS<a name="line.2732"></a>
-<span class="sourceLineNo">2733</span>   * @throws Exception<a name="line.2733"></a>
-<span class="sourceLineNo">2734</span>   */<a name="line.2734"></a>
-<span class="sourceLineNo">2735</span>  public void expireRegionServerSession(int index) throws Exception {<a name="line.2735"></a>
-<span class="sourceLineNo">2736</span>    HRegionServer rs = getMiniHBaseCluster().getRegionServer(index);<a name="line.2736"></a>
-<span class="sourceLineNo">2737</span>    expireSession(rs.getZooKeeper(), false);<a name="line.2737"></a>
-<span class="sourceLineNo">2738</span>    decrementMinRegionServerCount();<a name="line.2738"></a>
-<span class="sourceLineNo">2739</span>  }<a name="line.2739"></a>
-<span class="sourceLineNo">2740</span><a name="line.2740"></a>
-<span class="sourceLineNo">2741</span>  private void decrementMinRegionServerCount() {<a name="line.2741"></a>
-<span class="sourceLineNo">2742</span>    // decrement the count for this.conf, for newly spwaned master<a name="line.2742"></a>
-<span class="sourceLineNo">2743</span>    // this.hbaseCluster shares this configuration too<a name="line.2743"></a>
-<span class="sourceLineNo">2744</span>    decrementMinRegionServerCount(getConfiguration());<a name="line.2744"></a>
-<span class="sourceLineNo">2745</span><a name="line.2745"></a>
-<span class="sourceLineNo">2746</span>    // each master thread keeps a copy of configuration<a name="line.2746"></a>
-<span class="sourceLineNo">2747</span>    for (MasterThread master : getHBaseCluster().getMasterThreads()) {<a name="line.2747"></a>
-<span class="sourceLineNo">2748</span>      decrementMinRegionServerCount(master.getMaster().getConfiguration());<a name="line.2748"></a>
-<span class="sourceLineNo">2749</span>    }<a name="line.2749"></a>
-<span class="sourceLineNo">2750</span>  }<a name="line.2750"></a>
-<span class="sourceLineNo">2751</span><a name="line.2751"></a>
-<span class="sourceLineNo">2752</span>  private void decrementMinRegionServerCount(Configuration conf) {<a name="line.2752"></a>
-<span class="sourceLineNo">2753</span>    int currentCount = conf.getInt(<a name="line.2753"></a>
-<span class="sourceLineNo">2754</span>        ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART, -1);<a name="line.2754"></a>
-<span class="sourceLineNo">2755</span>    if (currentCount != -1) {<a name="line.2755"></a>
-<span class="sourceLineNo">2756</span>      conf.setInt(ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART,<a name="line.2756"></a>
-<span class="sourceLineNo">2757</span>          Math.max(currentCount - 1, 1));<a name="line.2757"></a>
-<span class="sourceLineNo">2758</span>    }<a name="line.2758"></a>
-<span class="sourceLineNo">2759</span>  }<a name="line.2759"></a>
+<span class="sourceLineNo">2662</span>    String schedulerAddress =<a name="line.2662"></a>
+<span class="sourceLineNo">2663</span>      jobConf.get("yarn.resourcemanager.scheduler.address");<a name="line.2663"></a>
+<span class="sourceLineNo">2664</span>    if (schedulerAddress != null) {<a name="line.2664"></a>
+<span class="sourceLineNo">2665</span>      conf.set("yarn.resourcemanager.scheduler.address", schedulerAddress);<a name="line.2665"></a>
+<span class="sourceLineNo">2666</span>    }<a name="line.2666"></a>
+<span class="sourceLineNo">2667</span>    String mrJobHistoryWebappAddress =<a name="line.2667"></a>
+<span class="sourceLineNo">2668</span>      jobConf.get("mapreduce.jobhistory.webapp.address");<a name="line.2668"></a>
+<span class="sourceLineNo">2669</span>    if (mrJobHistoryWebappAddress != null) {<a name="line.2669"></a>
+<span class="sourceLineNo">2670</span>      conf.set("mapreduce.jobhistory.webapp.address", mrJobHistoryWebappAddress);<a name="line.2670"></a>
+<span class="sourceLineNo">2671</span>    }<a name="line.2671"></a>
+<span class="sourceLineNo">2672</span>    String yarnRMWebappAddress =<a name="line.2672"></a>
+<span class="sourceLineNo">2673</span>      jobConf.get("yarn.resourcemanager.webapp.address");<a name="line.2673"></a>
+<span class="sourceLineNo">2674</span>    if (yarnRMWebappAddress != null) {<a name="line.2674"></a>
+<span class="sourceLineNo">2675</span>      conf.set("yarn.resourcemanager.webapp.address", yarnRMWebappAddress);<a name="line.2675"></a>
+<span class="sourceLineNo">2676</span>    }<a name="line.2676"></a>
+<span class="sourceLineNo">2677</span>  }<a name="line.2677"></a>
+<span class="sourceLineNo">2678</span><a name="line.2678"></a>
+<span class="sourceLineNo">2679</span>  /**<a name="line.2679"></a>
+<span class="sourceLineNo">2680</span>   * Stops the previously started &lt;code&gt;MiniMRCluster&lt;/code&gt;.<a name="line.2680"></a>
+<span class="sourceLineNo">2681</span>   */<a name="line.2681"></a>
+<span class="sourceLineNo">2682</span>  public void shutdownMiniMapReduceCluster() {<a name="line.2682"></a>
+<span class="sourceLineNo">2683</span>    if (mrCluster != null) {<a name="line.2683"></a>
+<span class="sourceLineNo">2684</span>      LOG.info("Stopping mini mapreduce cluster...");<a name="line.2684"></a>
+<span class="sourceLineNo">2685</span>      mrCluster.shutdown();<a name="line.2685"></a>
+<span class="sourceLineNo">2686</span>      mrCluster = null;<a name="line.2686"></a>
+<span class="sourceLineNo">2687</span>      LOG.info("Mini mapreduce cluster stopped");<a name="line.2687"></a>
+<span class="sourceLineNo">2688</span>    }<a name="line.2688"></a>
+<span class="sourceLineNo">2689</span>    // Restore configuration to point to local jobtracker<a name="line.2689"></a>
+<span class="sourceLineNo">2690</span>    conf.set("mapreduce.jobtracker.address", "local");<a name="line.2690"></a>
+<span class="sourceLineNo">2691</span>  }<a name="line.2691"></a>
+<span class="sourceLineNo">2692</span><a name="line.2692"></a>
+<span class="sourceLineNo">2693</span>  /**<a name="line.2693"></a>
+<span class="sourceLineNo">2694</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2694"></a>
+<span class="sourceLineNo">2695</span>   */<a name="line.2695"></a>
+<span class="sourceLineNo">2696</span>  public RegionServerServices createMockRegionServerService() throws IOException {<a name="line.2696"></a>
+<span class="sourceLineNo">2697</span>    return createMockRegionServerService((ServerName)null);<a name="line.2697"></a>
+<span class="sourceLineNo">2698</span>  }<a name="line.2698"></a>
+<span class="sourceLineNo">2699</span><a name="line.2699"></a>
+<span class="sourceLineNo">2700</span>  /**<a name="line.2700"></a>
+<span class="sourceLineNo">2701</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2701"></a>
+<span class="sourceLineNo">2702</span>   * This version is used by TestTokenAuthentication<a name="line.2702"></a>
+<span class="sourceLineNo">2703</span>   */<a name="line.2703"></a>
+<span class="sourceLineNo">2704</span>  public RegionServerServices createMockRegionServerService(RpcServerInterface rpc) throws<a name="line.2704"></a>
+<span class="sourceLineNo">2705</span>      IOException {<a name="line.2705"></a>
+<span class="sourceLineNo">2706</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher());<a name="line.2706"></a>
+<span class="sourceLineNo">2707</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2707"></a>
+<span class="sourceLineNo">2708</span>    rss.setRpcServer(rpc);<a name="line.2708"></a>
+<span class="sourceLineNo">2709</span>    return rss;<a name="line.2709"></a>
+<span class="sourceLineNo">2710</span>  }<a name="line.2710"></a>
+<span class="sourceLineNo">2711</span><a name="line.2711"></a>
+<span class="sourceLineNo">2712</span>  /**<a name="line.2712"></a>
+<span class="sourceLineNo">2713</span>   * Create a stubbed out RegionServerService, mainly for getting FS.<a name="line.2713"></a>
+<span class="sourceLineNo">2714</span>   * This version is used by TestOpenRegionHandler<a name="line.2714"></a>
+<span class="sourceLineNo">2715</span>   */<a name="line.2715"></a>
+<span class="sourceLineNo">2716</span>  public RegionServerServices createMockRegionServerService(ServerName name) throws IOException {<a name="line.2716"></a>
+<span class="sourceLineNo">2717</span>    final MockRegionServerServices rss = new MockRegionServerServices(getZooKeeperWatcher(), name);<a name="line.2717"></a>
+<span class="sourceLineNo">2718</span>    rss.setFileSystem(getTestFileSystem());<a name="line.2718"></a>
+<span class="sourceLineNo">2719</span>    return rss;<a name="line.2719"></a>
+<span class="sourceLineNo">2720</span>  }<a name="line.2720"></a>
+<span class="sourceLineNo">2721</span><a name="line.2721"></a>
+<span class="sourceLineNo">2722</span>  /**<a name="line.2722"></a>
+<span class="sourceLineNo">2723</span>   * Switches the logger for the given class to DEBUG level.<a name="line.2723"></a>
+<span class="sourceLineNo">2724</span>   *<a name="line.2724"></a>
+<span class="sourceLineNo">2725</span>   * @param clazz  The class for which to switch to debug logging.<a name="line.2725"></a>
+<span class="sourceLineNo">2726</span>   */<a name="line.2726"></a>
+<span class="sourceLineNo">2727</span>  public void enableDebug(Class&lt;?&gt; clazz) {<a name="line.2727"></a>
+<span class="sourceLineNo">2728</span>    Log l = LogFactory.getLog(clazz);<a name="line.2728"></a>
+<span class="sourceLineNo">2729</span>    if (l instanceof Log4JLogger) {<a name="line.2729"></a>
+<span class="sourceLineNo">2730</span>      ((Log4JLogger) l).getLogger().setLevel(org.apache.log4j.Level.DEBUG);<a name="line.2730"></a>
+<span class="sourceLineNo">2731</span>    } else if (l instanceof Jdk14Logger) {<a name="line.2731"></a>
+<span class="sourceLineNo">2732</span>      ((Jdk14Logger) l).getLogger().setLevel(java.util.logging.Level.ALL);<a name="line.2732"></a>
+<span class="sourceLineNo">2733</span>    }<a name="line.2733"></a>
+<span class="sourceLineNo">2734</span>  }<a name="line.2734"></a>
+<span class="sourceLineNo">2735</span><a name="line.2735"></a>
+<span class="sourceLineNo">2736</span>  /**<a name="line.2736"></a>
+<span class="sourceLineNo">2737</span>   * Expire the Master's session<a name="line.2737"></a>
+<span class="sourceLineNo">2738</span>   * @throws Exception<a name="line.2738"></a>
+<span class="sourceLineNo">2739</span>   */<a name="line.2739"></a>
+<span class="sourceLineNo">2740</span>  public void expireMasterSession() throws Exception {<a name="line.2740"></a>
+<span class="sourceLineNo">2741</span>    HMaster master = getMiniHBaseCluster().getMaster();<a name="line.2741"></a>
+<span class="sourceLineNo">2742</span>    expireSession(master.getZooKeeper(), false);<a name="line.2742"></a>
+<span class="sourceLineNo">2743</span>  }<a name="line.2743"></a>
+<span class="sourceLineNo">2744</span><a name="line.2744"></a>
+<span class="sourceLineNo">2745</span>  /**<a name="line.2745"></a>
+<span class="sourceLineNo">2746</span>   * Expire a region server's session<a name="line.2746"></a>
+<span class="sourceLineNo">2747</span>   * @param index which RS<a name="line.2747"></a>
+<span class="sourceLineNo">2748</span>   * @throws Exception<a name="line.2748"></a>
+<span class="sourceLineNo">2749</span>   */<a name="line.2749"></a>
+<span class="sourceLineNo">2750</span>  public void expireRegionServerSession(int index) throws Exception {<a name="line.2750"></a>
+<span class="sourceLineNo">2751</span>    HRegionServer rs = getMiniHBaseCluster().getRegionServer(index);<a name="line.2751"></a>
+<span class="sourceLineNo">2752</span>    expireSession(rs.getZooKeeper(), false);<a name="line.2752"></a>
+<span class="sourceLineNo">2753</span>    decrementMinRegionServerCount();<a name="line.2753"></a>
+<span class="sourceLineNo">2754</span>  }<a name="line.2754"></a>
+<span class="sourceLineNo">2755</span><a name="line.2755"></a>
+<span class="sourceLineNo">2756</span>  private void decrementMinRegionServerCount() {<a name="line.2756"></a>
+<span class="sourceLineNo">2757</span>    // decrement the count for this.conf, for newly spwaned master<a name="line.2757"></a>
+<span class="sourceLineNo">2758</span>    // this.hbaseCluster shares this configuration too<a name="line.2758"></a>
+<span class="sourceLineNo">2759</span>    decrementMinRegionServerCount(getConfiguration());<a name="line.2759"></a>
 <span class="sourceLineNo">2760</span><a name="line.2760"></a>
-<span class="sourceLineNo">2761</span>  public void expireSession(ZKWatcher nodeZK) throws Exception {<a name="line.2761"></a>
-<span class="sourceLineNo">2762</span>   expireSession(nodeZK, false);<a name="line.2762"></a>
-<span class="sourceLineNo">2763</span>  }<a name="line.2763"></a>
-<span class="sourceLineNo">2764</span><a name="line.2764"></a>
-<span class="sourceLineNo">2765</span>  /**<a name="line.2765"></a>
-<span class="sourceLineNo">2766</span>   * Expire a ZooKeeper session as recommended in ZooKeeper documentation<a name="line.2766"></a>
-<span class="sourceLineNo">2767</span>   * http://hbase.apache.org/book.html#trouble.zookeeper<a name="line.2767"></a>
-<span class="sourceLineNo">2768</span>   * There are issues when doing this:<a name="line.2768"></a>
-<span class="sourceLineNo">2769</span>   * [1] http://www.mail-archive.com/dev@zookeeper.apache.org/msg01942.html<a name="line.2769"></a>
-<span class="sourceLineNo">2770</span>   * [2] https://issues.apache.org/jira/browse/ZOOKEEPER-1105<a name="line.2770"></a>
-<span class="sourceLineNo">2771</span>   *<a name="line.2771"></a>
-<span class="sourceLineNo">2772</span>   * @param nodeZK - the ZK watcher to expire<a name="line.2772"></a>
-<span class="sourceLineNo">2773</span>   * @param checkStatus - true to check if we can create a Table with the<a name="line.2773"></a>
-<span class="sourceLineNo">2774</span>   *                    current configuration.<a name="line.2774"></a>
-<span class="sourceLineNo">2775</span>   */<a name="line.2775"></a>
-<span class="sourceLineNo">2776</span>  public void expireSession(ZKWatcher nodeZK, boolean checkStatus)<a name="line.2776"></a>
-<span class="sourceLineNo">2777</span>    throws Exception {<a name="line.2777"></a>
-<span class="sourceLineNo">2778</span>    Configuration c = new Configuration(this.conf);<a name="line.2778"></a>
-<span class="sourceLineNo">2779</span>    String quorumServers = ZKConfig.getZKQuorumServersString(c);<a name="line.2779"></a>
-<span class="sourceLineNo">2780</span>    ZooKeeper zk = nodeZK.getRecoverableZooKeeper().getZooKeeper();<a name="line.2780"></a>
-<span class="sourceLineNo">2781</span>    byte[] password = zk.getSessionPasswd();<a name="line.2781"></a>
-<span class="sourceLineNo">2782</span>    long sessionID = zk.getSessionId();<a name="line.2782"></a>
-<span class="sourceLineNo">2783</span><a name="line.2783"></a>
-<span class="sourceLineNo">2784</span>    // Expiry seems to be asynchronous (see comment from P. Hunt in [1]),<a name="line.2784"></a>
-<span class="sourceLineNo">2785</span>    //  so we create a first watcher to be sure that the<a name="line.2785"></a>
-<span class="sourceLineNo">2786</span>    //  event was sent. We expect that if our watcher receives the event<a name="line.2786"></a>
-<span class="sourceLineNo">2787</span>    //  other watchers on the same machine will get is as well.<a name="line.2787"></a>
-<span class="sourceLineNo">2788</span>    // When we ask to close the connection, ZK does not close it before<a name="line.2788"></a>
-<span class="sourceLineNo">2789</span>    //  we receive all the events, so don't have to capture the event, just<a name="line.2789"></a>
-<span class="sourceLineNo">2790</span>    //  closing the connection should be enough.<a name="line.2790"></a>
-<span class="sourceLineNo">2791</span>    ZooKeeper monitor = new ZooKeeper(quorumServers,<a name="line.2791"></a>
-<span class="sourceLineNo">2792</span>      1000, new org.apache.zookeeper.Watcher(){<a name="line.2792"></a>
-<span class="sourceLineNo">2793</span>      @Override<a name="line.2793"></a>
-<span class="sourceLineNo">2794</span>      public void process(WatchedEvent watchedEvent) {<a name="line.2794"></a>
-<span class="sourceLineNo">2795</span>        LOG.info("Monitor ZKW received event="+watchedEvent);<a name="line.2795"></a>
-<span class="sourceLineNo">2796</span>      }<a name="line.2796"></a>
-<span class="sourceLineNo">2797</span>    } , sessionID, password);<a name="line.2797"></a>
+<span class="sourceLineNo">2761</span>    // each master thread keeps a copy of configuration<a name="line.2761"></a>
+<span class="sourceLineNo">2762</span>    for (MasterThread master : getHBaseCluster().getMasterThreads()) {<a name="line.2762"></a>
+<span class="sourceLineNo">2763</span>      decrementMinRegionServerCount(master.getMaster().getConfiguration());<a name="line.2763"></a>
+<span class="sourceLineNo">2764</span>    }<a name="line.2764"></a>
+<span class="sourceLineNo">2765</span>  }<a name="line.2765"></a>
+<span class="sourceLineNo">2766</span><a name="line.2766"></a>
+<span class="sourceLineNo">2767</span>  private void decrementMinRegionServerCount(Configuration conf) {<a name="line.2767"></a>
+<span class="sourceLineNo">2768</span>    int currentCount = conf.getInt(<a name="line.2768"></a>
+<span class="sourceLineNo">2769</span>        ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART, -1);<a name="line.2769"></a>
+<span class="sourceLineNo">2770</span>    if (currentCount != -1) {<a name="line.2770"></a>
+<span class="sourceLineNo">2771</span>      conf.setInt(ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART,<a name="line.2771"></a>
+<span class="sourceLineNo">2772</span>          Math.max(currentCount - 1, 1));<a name="line.2772"></a>
+<span class="sourceLineNo">2773</span>    }<a name="line.2773"></a>
+<span class="sourceLineNo">2774</span>  }<a name="line.2774"></a>
+<span class="sourceLineNo">2775</span><a name="line.2775"></a>
+<span class="sourceLineNo">2776</span>  public void expireSession(ZKWatcher nodeZK) throws Exception {<a name="line.2776"></a>
+<span class="sourceLineNo">2777</span>   expireSession(nodeZK, false);<a name="line.2777"></a>
+<span class="sourceLineNo">2778</span>  }<a name="line.2778"></a>
+<span class="sourceLineNo">2779</span><a name="line.2779"></a>
+<span class="sourceLineNo">2780</span>  /**<a name="line.2780"></a>
+<span class="sourceLineNo">2781</span>   * Expire a ZooKeeper session as recommended in ZooKeeper documentation<a name="line.2781"></a>
+<span class="sourceLineNo">2782</span>   * http://hbase.apache.org/book.html#trouble.zookeeper<a name="line.2782"></a>
+<span class="sourceLineNo">2783</span>   * There are issues when doing this:<a name="line.2783"></a>
+<span class="sourceLineNo">2784</span>   * [1] http://www.mail-archive.com/dev@zookeeper.apache.org/msg01942.html<a name="line.2784"></a>
+<span class="sourceLineNo">2785</span>   * [2] https://issues.apache.org/jira/browse/ZOOKEEPER-1105<a name="line.2785"></a>
+<span class="sourceLineNo">2786</span>   *<a name="line.2786"></a>
+<span class="sourceLineNo">2787</span>   * @param nodeZK - the ZK watcher to expire<a name="line.2787"></a>
+<span class="sourceLineNo">2788</span>   * @param checkStatus - true to check if we can create a Table with the<a name="line.2788"></a>
+<span class="sourceLineNo">2789</span>   *                    current configuration.<a name="line.2789"></a>
+<span class="sourceLineNo">2790</span>   */<a name="line.2790"></a>
+<span class="sourceLineNo">2791</span>  public void expireSession(ZKWatcher nodeZK, boolean checkStatus)<a name="line.2791"></a>
+<span class="sourceLineNo">2792</span>    throws Exception {<a name="line.2792"></a>
+<span class="sourceLineNo">2793</span>    Configuration c = new Configuration(this.conf);<a name="line.2793"></a>
+<span class="sourceLineNo">2794</span>    String quorumServers = ZKConfig.getZKQuorumServersString(c);<a name="line.2794"></a>
+<span class="sourceLineNo">2795</span>    ZooKeeper zk = nodeZK.getRecoverableZooKeeper().getZooKeeper();<a name="line.2795"></a>
+<span class="sourceLineNo">2796</span>    byte[] password = zk.getSessionPasswd();<a name="line.2796"></a>
+<span class="sourceLineNo">2797</span>    long sessionID = zk.getSessionId();<a name="line.2797"></a>
 <span class="sourceLineNo">2798</span><a name="line.2798"></a>
-<span class="sourceLineNo">2799</span>    // Making it expire<a name="line.2799"></a>
-<span class="sourceLineNo">2800</span>    ZooKeeper newZK = new ZooKeeper(quorumServers,<a name="line.2800"></a>
-<span class="sourceLineNo">2801</span>        1000, EmptyWatcher.instance, sessionID, password);<a name="line.2801"></a>
-<span class="sourceLineNo">2802</span><a name="line.2802"></a>
-<span class="sourceLineNo">2803</span>    //ensure that we have connection to the server before closing down, otherwise<a name="line.2803"></a>
-<span class="sourceLineNo">2804</span>    //the close session event will be eaten out before we start CONNECTING state<a name="line.2804"></a>
-<span class="sourceLineNo">2805</span>    long start = System.currentTimeMillis();<a name="line.2805"></a>
-<span class="sourceLineNo">2806</span>    while (newZK.getState() != States.CONNECTED<a name="line.2806"></a>
-<span class="sourceLineNo">2807</span>         &amp;&amp; System.currentTimeMillis() - start &lt; 1000) {<a name="line.2807"></a>
-<span class="sourceLineNo">2808</span>       Thread.sleep(1);<a name="line.2808"></a>
-<span class="sourceLineNo">2809</span>    }<a name="line.2809"></a>
-<span class="sourceLineNo">2810</span>    newZK.close();<a name="line.2810"></a>
-<span class="sourceLineNo">2811</span>    LOG.info("ZK Closed Session 0x" + Long.toHexString(sessionID));<a name="line.2811"></a>
-<span class="sourceLineNo">2812</span><a name="line.2812"></a>
-<span class="sourceLineNo">2813</span>    // Now closing &amp; waiting to be sure that the clients get it.<a name="line.2813"></a>
-<span class="sourceLineNo">2814</span>    monitor.close();<a name="line.2814"></a>
-<span class="sourceLineNo">2815</span><a name="line.2815"></a>
-<span class="sourceLineNo">2816</span>    if (checkStatus) {<a name="line.2816"></a>
-<span class="sourceLineNo">2817</span>      getConnection().getTable(TableName.META_TABLE_NAME).close();<a name="line.2817"></a>
-<span class="sourceLineNo">2818</span>    }<a name="line.2818"></a>
-<span class="sourceLineNo">2819</span>  }<a name="line.2819"></a>
-<span class="sourceLineNo">2820</span><a name="line.2820"></a>
-<span class="sourceLineNo">2821</span>  /**<a name="line.2821"></a>
-<span class="sourceLineNo">2822</span>   * Get the Mini HBase cluster.<a name="line.2822"></a>
-<span class="sourceLineNo">2823</span>   *<a name="line.2823"></a>
-<span class="sourceLineNo">2824</span>   * @return hbase cluster<a name="line.2824"></a>
-<span class="sourceLineNo">2825</span>   * @see #getHBaseClusterInterface()<a name="line.2825"></a>
-<span class="sourceLineNo">2826</span>   */<a name="line.2826"></a>
-<span class="sourceLineNo">2827</span>  public MiniHBaseCluster getHBaseCluster() {<a name="line.2827"></a>
-<span class="sourceLineNo">2828</span>    return getMiniHBaseCluster();<a name="line.2828"></a>
-<span class="sourceLineNo">2829</span>  }<a name="line.2829"></a>
+<span class="sourceLineNo">2799</span>    // Expiry seems to be asynchronous (see comment from P. Hunt in [1]),<a name="line.2799"></a>
+<span class="sourceLineNo">2800</span>    //  so we create a first watcher to be sure that the<a name="line.2800"></a>
+<span class="sourceLineNo">2801</span>    //  event was sent. We expect that if our watcher receives the event<a name="line.2801"></a>
+<span class="sourceLineNo">2802</span>    //  other watchers on the same machine will get is as well.<a name="line.2802"></a>
+<span class="sourceLineNo">2803</span>    // When we ask to close the connection, ZK does not close it before<a name="line.2803"></a>
+<span class="sourceLineNo">2804</span>    //  we receive all the events, so don't have to capture the event, just<a name="line.2804"></a>
+<span class="sourceLineNo">2805</span>    //  closing the connection should be enough.<a name="line.2805"></a>
+<span class="sourceLineNo">2806</span>    ZooKeeper monitor = new ZooKeeper(quorumServers,<a name="line.2806"></a>
+<span class="sourceLineNo">2807</span>      1000, new org.apache.zookeeper.Watcher(){<a name="line.2807"></a>
+<span class="sourceLineNo">2808</span>      @Override<a name="line.2808"></a>
+<span class="sourceLineNo">2809</span>      public void process(WatchedEvent watchedEvent) {<a name="line.2809"></a>
+<span class="sourceLineNo">2810</span>        LOG.info("Monitor ZKW received event="+watchedEvent);<a name="line.2810"></a>
+<span class="sourceLineNo">2811</span>      }<a name="line.2811"></a>
+<span class="sourceLineNo">2812</span>    } , sessionID, password);<a name="line.2812"></a>
+<span class="sourceLineNo">2813</span><a name="line.2813"></a>
+<span class="sourceLineNo">2814</span>    // Making it expire<a name="line.2814"></a>
+<span class="sourceLineNo">2815</span>    ZooKeeper newZK = new ZooKeeper(quorumServers,<a name="line.2815"></a>
+<span class="sourceLineNo">2816</span>        1000, EmptyWatcher.instance, sessionID, password);<a name="line.2816"></a>
+<span class="sourceLineNo">2817</span><a name="line.2817"></a>
+<span class="sourceLineNo">2818</span>    //ensure that we have connection to the server before closing down, otherwise<a name="line.2818"></a>
+<span class="sourceLineNo">2819</span>    //the close session event will be eaten out before we start CONNECTING state<a name="line.2819"></a>
+<span class="sourceLineNo">2820</span>    long start = System.currentTimeMillis();<a name="line.2820"></a>
+<span class="sourceLineNo">2821</span>    while (newZK.getState() != States.CONNECTED<a name="line.2821"></a>
+<span class="sourceLineNo">2822</span>         &amp;&amp; System.currentTimeMillis() - start &lt; 1000) {<a name="line.2822"></a>
+<span class="sourceLineNo">2823</span>       Thread.sleep(1);<a name="line.2823"></a>
+<span class="sourceLineNo">2824</span>    }<a name="line.2824"></a>
+<span class="sourceLineNo">2825</span>    newZK.close();<a name="line.2825"></a>
+<span class="sourceLineNo">2826</span>    LOG.info("ZK Closed Session 0x" + Long.toHexString(sessionID));<a name="line.2826"></a>
+<span class="sourceLineNo">2827</span><a name="line.2827"></a>
+<span class="sourceLineNo">2828</span>    // Now closing &amp; waiting to be sure that the clients get it.<a name="line.2828"></a>
+<span class="sourceLineNo">2829</span>    monitor.close();<a name="line.2829"></a>
 <span class="sourceLineNo">2830</span><a name="line.2830"></a>
-<span class="sourceLineNo">2831</span>  /**<a name="line.2831"></a>
-<span class="sourceLineNo">2832</span>   * Returns the HBaseCluster instance.<a name="line.2832"></a>
-<span class="sourceLineNo">2833</span>   * &lt;p&gt;Returned object can be any of the subclasses of HBaseCluster, and the<a name="line.2833"></a>
-<span class="sourceLineNo">2834</span>   * tests referring this should not assume that the cluster is a mini cluster or a<a name="line.2834"></a>
-<span class="sourceLineNo">2835</span>   * distributed one. If the test only works on a mini cluster, then specific<a name="line.2835"></a>
-<span class="sourceLineNo">2836</span>   * method {@link #getMiniHBaseCluster()} can be used instead w/o the<a name="line.2836"></a>
-<span class="sourceLineNo">2837</span>   * need to type-cast.<a name="line.2837"></a>
-<span class="sourceLineNo">2838</span>   */<a name="line.2838"></a>
-<span class="sourceLineNo">2839</span>  public HBaseCluster getHBaseClusterInterface() {<a name="line.2839"></a>
-<span class="sourceLineNo">2840</span>    //implementation note: we should rename this method as #getHBaseCluster(),<a name="line.2840"></a>
-<span class="sourceLineNo">2841</span>    //but this would require refactoring 90+ calls.<a name="line.2841"></a>
-<span class="sourceLineNo">2842</span>    return hbaseCluster;<a name="line.2842"></a>
-<span class="sourceLineNo">2843</span>  }<a name="line.2843"></a>
-<span class="sourceLineNo">2844</span><a name="line.2844"></a>
-<span class="sourceLineNo">2845</span>  /**<a name="line.2845"></a>
-<span class="sourceLineNo">2846</span>   * Get a Connection to the cluster.<a name="line.2846"></a>
-<span class="sourceLineNo">2847</span>   * Not thread-safe (This class needs a lot of work to make it thread-safe).<a name="line.2847"></a>
-<span class="sourceLineNo">2848</span>   * @return A Connection that can be shared. Don't close. Will be closed on shutdown of cluster.<a name="line.2848"></a>
-<span class="sourceLineNo">2849</span>   * @throws IOException<a name="line.2849"></a>
-<span class="sourceLineNo">2850</span>   */<a name="line.2850"></a>
-<span class="sourceLineNo">2851</span>  public Connection getConnection() throws IOException {<a name="line.2851"></a>
-<span class="sourceLineNo">2852</span>    if (this.connection == null) {<a name="line.2852"></a>
-<span class="sourceLineNo">2853</span>      this.connection = ConnectionFactory.createConnection(this.conf);<a name="line.2853"></a>
-<span class="sourceLineNo">2854</span>    }<a name="line.2854"></a>
-<span class="sourceLineNo">2855</span>    return this.connection;<a name="line.2855"></a>
-<span class="sourceLineNo">2856</span>  }<a name="line.2856"></a>
-<span class="sourceLineNo">2857</span><a name="line.2857"></a>
-<span class="sourceLineNo">2858</span>  /**<a name="line.2858"></a>
-<span class="sourceLineNo">2859</span>   * Returns a Admin instance.<a name="line.2859"></a>
-<span class="sourceLineNo">2860</span>   * This instance is shared between HBaseTestingUtility instance users. Closing it has no effect,<a name="line.2860"></a>
-<span class="sourceLineNo">2861</span>   * it will be closed automatically when the cluster shutdowns<a name="line.2861"></a>
-<span class="sourceLineNo">2862</span>   *<a name="line.2862"></a>
-<span class="sourceLineNo">2863</span>   * @return HBaseAdmin instance which is guaranteed to support only {@link Admin} interface.<a name="line.2863"></a>
-<span class="sourceLineNo">2864</span>   *   Functions in HBaseAdmin not provided by {@link Admin} interface can be changed/deleted<a name="line.2864"></a>
-<span class="sourceLineNo">2865</span>   *   anytime.<a name="line.2865"></a>
-<span class="sourceLineNo">2866</span>   * @deprecated Since 2.0. Will be removed in 3.0. Use {@link #getAdmin()} instead.<a name="line.2866"></a>
-<span class="sourceLineNo">2867</span>   */<a name="line.2867"></a>
-<span class="sourceLineNo">2868</span>  @Deprecated<a name="line.2868"></a>
-<span class="sourceLineNo">2869</span>  public synchronized HBaseAdmin getHBaseAdmin()<a name="line.2869"></a>
-<span class="sourceLineNo">2870</span>  throws IOException {<a name="line.2870"></a>
-<span class="sourceLineNo">2871</span>    if (hbaseAdmin == null){<a name="line.2871"></a>
-<span class="sourceLineNo">2872</span>      this.hbaseAdmin = (HBaseAdmin) getConnection().getAdmin();<a name="line.2872"></a>
-<span class="sourceLineNo">2873</span>    }<a name="line.2873"></a>
-<span class="sourceLineNo">2874</span>    return hbaseAdmin;<a name="line.2874"></a>
-<span class="sourceLineNo">2875</span>  }<a name="line.2875"></a>
-<span class="sourceLineNo">2876</span><a name="line.2876"></a>
-<span class="sourceLineNo">2877</span>  /**<a name="line.2877"></a>
-<span class="sourceLineNo">2878</span>   * Returns an Admin instance which is shared between HBaseTestingUtility instance users.<a name="line.2878"></a>
-<span class="sourceLineNo">2879</span>   * Closing it has no effect, it will be closed automatically when the cluster shutdowns<a name="line.2879"></a>
-<span class="sourceLineNo">2880</span>   */<a name="line.2880"></a>
-<span class="sourceLineNo">2881</span>  public synchronized Admin getAdmin() throws IOException {<a name="line.2881"></a>
-<span class="sourceLineNo">2882</span>    if (hbaseAdmin == null){<a name="line.2882"></a>
-<span class="sourceLineNo">2883</span>      this.hbaseAdmin = (HBaseAdmin) getConnection().getAdmin();<a name="line.2883"></a>
-<span class="sourceLineNo">2884</span>    }<a name="line.2884"></a>
-<span class="sourceLineNo">2885</span>    return hbaseAdmin;<a name="line.2885"></a>
-<span class="sourceLineNo">2886</span>  }<a name="line.2886"></a>
-<span class="sourceLineNo">2887</span><a name="line.2887"></a>
-<span class="sourceLineNo">2888</span>  private HBaseAdmin hbaseAdmin = null;<a name="line.2888"></a>
-<span class="sourceLineNo">2889</span><a name="line.2889"></a>
-<span class="sourceLineNo">2890</span>  /**<a name="line.2890"></a>
-<span class="sourceLineNo">2891</span>   * Returns a ZKWatcher instance.<a name="line.2891"></a>
-<span class="sourceLineNo">2892</span>   * This instance is shared between HBaseTestingUtility instance users.<a name="line.2892"></a>
-<span class="sourceLineNo">2893</span>   * Don't close it, it will be closed automatically when the<a name="line.2893"></a>
-<span class="sourceLineNo">2894</span>   * cluster shutdowns<a name="line.2894"></a>
-<span class="sourceLineNo">2895</span>   *<a name="line.2895"></a>
-<span class="sourceLineNo">2896</span>   * @return The ZKWatcher instance.<a name="line.2896"></a>
-<span class="sourceLineNo">2897</span>   * @throws IOException<a name="line.2897"></a>
-<span class="sourceLineNo">2898</span>   */<a name="line.2898"></a>
-<span class="sourceLineNo">2899</span>  public synchronized ZKWatcher getZooKeeperWatcher()<a name="line.2899"></a>
-<span class="sourceLineNo">2900</span>    throws IOException {<a name="line.2900"></a>
-<span class="sourceLineNo">2901</span>    if (zooKeeperWatcher == null) {<a name="line.2901"></a>
-<span class="sourceLineNo">2902</span>      zooKeeperWatcher = new ZKWatcher(conf, "testing utility",<a name="line.2902"></a>
-<span class="sourceLineNo">2903</span>        new Abortable() {<a name="line.2903"></a>
-<span class="sourceLineNo">2904</span>        @Override public void abort(String why, Throwable e) {<a name="line.2904"></a>
-<span class="sourceLineNo">2905</span>          throw new RuntimeException("Unexpected abort in HBaseTestingUtility:"+why, e);<a name="line.2905"></a>
-<span class="sourceLineNo">2906</span>        }<a name="line.2906"></a>
-<span class="sourceLineNo">2907</span>        @Override public boolean isAborted() {return false;}<a name="line.2907"></a>
-<span class="sourceLineNo">2908</span>      });<a name="line.2908"></a>
-<span class="sourceLineNo">2909</span>    }<a name="line.2909"></a>
-<span class="sourceLineNo">2910</span>    return zooKeeperWatcher;<a name="line.2910"></a>
-<span class="sourceLineNo">2911</span>  }<a name="line.2911"></a>
-<span class="sourceLineNo">2912</span>  private ZKWatcher zooKeeperWatcher;<a name="line.2912"></a>
-<span class="sourceLineNo">2913</span><a name="line.2913"></a>
-<span class="sourceLineNo">2914</span><a name="line.2914"></a>
-<span class="sourceLineNo">2915</span><a name="line.2915"></a>
-<span class="sourceLineNo">2916</span>  /**<a name="line.2916"></a>
-<span class="sourceLineNo">2917</span>   * Unassign the named region.<a name="line.2917"></a>
-<span class="sourceLineNo">2918</span>   *<a name="line.2918"></a>
-<span class="sourceLineNo">2919</span>   * @param regionName  The region to unassign.<a name="line.2919"></a>
-<span class="sourceLineNo">2920</span>   */<a name="line.2920"></a>
-<span class="sourceLineNo">2921</span>  public void unassignRegion(String regionName) throws IOException {<a name="line.2921"></a>
-<span class="sourceLineNo">2922</span>    unassignRegion(Bytes.toBytes(regionName));<a name="line.2922"></a>
-<span class="sourceLineNo">2923</span>  }<a name="line.2923"></a>
-<span class="sourceLineNo">2924</span><a name="line.2924"></a>
-<span class="sourceLineNo">2925</span>  /**<a name="line.2925"></a>
-<span class="sourceLineNo">2926</span>   * Unassign the named region.<a name="line.2926"></a>
-<span class="sourceLineNo">2927</span>   *<a name="line.2927"></a>
-<span class="sourceLineNo">2928</span>   * @param regionName  The region to unassign.<a name="line.2928"></a>
-<span class="sourceLineNo">2929</span>   */<a name="line.2929"></a>
-<span class="sourceLineNo">2930</span>  public void unassignRegion(byte[] regionName) throws IOException {<a name="line.2930"></a>
-<span class="sourceLineNo">2931</span>    getAdmin().unassign(regionName, true);<a name="line.2931"></a>
-<span class="sourceLineNo">2932</span>  }<a name="line.2932"></a>
-<span class="sourceLineNo">2933</span><a name="line.2933"></a>
-<span class="sourceLineNo">2934</span>  /**<a name="line.2934"></a>
-<span class="sourceLineNo">2935</span>   * Closes the region containing the given row.<a name="line.2935"></a>
-<span class="sourceLineNo">2936</span>   *<a name="line.2936"></a>
-<span class="sourceLineNo">2937</span>   * @param row  The row to find the containing region.<a name="line.2937"></a>
-<span class="sourceLineNo">2938</span>   * @param table  The table to find the region.<a name="line.2938"></a>
-<span class="sourceLineNo">2939</span>   */<a name="line.2939"></a>
-<span class="sourceLineNo">2940</span>  public void unassignRegionByRow(String row, RegionLocator table) throws IOException {<a name="line.2940"></a>
-<span class="sourceLineNo">2941</span>    unassignRegionByRow(Bytes.toBytes(row), table);<a name="line.2941"></a>
-<span class="sourceLineNo">2942</span>  }<a name="line.2942"></a>
-<span class="sourceLineNo">2943</span><a name="line.2943"></a>
-<span class="sourceLineNo">2944</span>  /**<a name="line.2944"></a>
-<span class="sourceLineNo">2945</span>   * Closes the region containing the given row.<a name="line.2945"></a>
-<span class="sourceLineNo">2946</span>   *<a name="line.2946"></a>
-<span class="sourceLineNo">2947</span>   * @param row  The row to find the containing region.<a name="line.2947"></a>
-<span class="sourceLineNo">2948</span>   * @param table  The table to find the region.<a name="line.2948"></a>
-<span class="sourceLineNo">2949</span>   * @throws IOException<a name="line.2949"></a>
-<span class="sourceLineNo">2950</span>   */<a name="line.2950"></a>
-<span class="sourceLineNo">2951</span>  public void unassignRegionByRow(byte[] row, RegionLocator table) throws IOException {<a name="line.2951"></a>
-<span class="sourceLineNo">2952</span>    HRegionLocation hrl = table.getRegionLocation(row);<a name="line.2952"></a>
-<span class="sourceLineNo">2953</span>    unassignRegion(hrl.getRegionInfo().getRegionName());<a name="line.2953"></a>
-<span class="sourceLineNo">2954</span>  }<a name="line.2954"></a>
-<span class="sourceLineNo">2955</span><a name="line.2955"></a>
-<span class="sourceLineNo">2956</span>  /*<a name="line.2956"></a>
-<span class="sourceLineNo">2957</span>   * Retrieves a splittable region randomly from tableName<a name="line.2957"></a>
-<span class="sourceLineNo">2958</span>   *<a name="line.2958"></a>
-<span class="sourceLineNo">2959</span>   * @param tableName name of table<a name="line.2959"></a>
-<span class="sourceLineNo">2960</span>   * @param maxAttempts maximum number of attempts, unlimited for value of -1<a name="line.2960"></a>
-<span class="sourceLineNo">2961</span>   * @return the HRegion chosen, null if none was found within limit of maxAttempts<a name="line.2961"></a>
-<span class="sourceLineNo">2962</span>   */<a name="line.2962"></a>
-<span class="sourceLineNo">2963</span>  public HRegion getSplittableRegion(TableName tableName, int maxAttempts) {<a name="line.2963"></a>
-<span class="sourceLineNo">2964</span>    List&lt;HRegion&gt; regions = getHBaseCluster().getRegions(tableName);<a name="line.2964"></a>
-<span class="sourceLineNo">2965</span>    int regCount = regions.size();<a name="line.2965"></a>
-<span class="sourceLineNo">2966</span>    Set&lt;Integer&gt; attempted = new HashSet&lt;&gt;();<a name="line.2966"></a>
-<span class="sourceLineNo">2967</span>    int idx;<a name="line.2967"></a>
-<span class="sourceLineNo">2968</span>    int attempts = 0;<a name="line.2968"></a>
-<span class="sourceLineNo">2969</span>    do {<a name="line.2969"></a>
-<span class="sourceLineNo">2970</span>      regions = getHBaseCluster().getRegions(tableName);<a name="line.2970"></a>
-<span class="sourceLineNo">2971</span>      if (regCount != regions.size()) {<a name="line.2971"></a>
-<span class="sourceLineNo">2972</span>        // if there was region movement, clear attempted Set<a name="line.2972"></a>
-<span class="sourceLineNo">2973</span>        attempted.clear();<a name="line.2973"></a>
-<span class="sourceLineNo">2974</span>      }<a name="line.2974"></a>
-<span class="sourceLineNo">2975</span>      regCount = regions.size();<a name="line.2975"></a>
-<span class="sourceLineNo">2976</span>      // There are chances that before we get the region for the table from an RS the region may<a name="line.2976"></a>
-<span class="sourceLineNo">2977</span>      // be going for CLOSE.  This may be because online schema change is enabled<a name="line.2977"></a>
-<span class="sourceLineNo">2978</span>      if (regCount &gt; 0) {<a name="line.2978"></a>
-<span class="sourceLineNo">2979</span>        idx = random.nextInt(regCount);<a name="line.2979"></a>
-<span class="sourceLineNo">2980</span>        // if we have just tried this region, there is no need to try again<a name="line.2980"></a>
-<span class="sourceLineNo">2981</span>        if (attempted.contains(idx))<a name="line.2981"></a>
-<span class="sourceLineNo">2982</span>          continue;<a name="line.2982"></a>
-<span class="sourceLineNo">2983</span>        try {<a name="line.2983"></a>
-<span class="sourceLineNo">2984</span>          regions.get(idx).checkSplit();<a name="line.2984"></a>
-<span class="sourceLineNo">2985</span>          return regions.get(idx);<a name="line.2985"></a>
-<span class="sourceLineNo">2986</span>        } catch (Exception ex) {<a name="line.2986"></a>
-<span class="sourceLineNo">2987</span>          LOG.warn("Caught exception", ex);<a name="line.2987"></a>
-<span class="sourceLineNo">2988</span>          attempted.add(idx);<a name="line.2988"></a>
-<span class="sourceLineNo">2989</span>        }<a name="line.2989"></a>
-<span class="sourceLineNo">2990</span>      }<a name="line.2990"></a>
-<span class="sourceLineNo">2991</span>      attempts++;<a name="line.2991"></a>
-<span class="sourceLineNo">2992</span>    } while (maxAttempts == -1 || attempts &lt; maxAttempts);<a name="line.2992"></a>
-<span class="sourceLineNo">2993</span>    return null;<a name="line.2993"></a>
-<span class="sourceLineNo">2994</span>  }<a name="line.2994"></a>
-<span class="sourceLineNo">2995</span><a name="line.2995"></a>
-<span class="sourceLineNo">2996</span>  public MiniZooKeeperCluster getZkCluster() {<a name="line.2996"></a>
-<span class="sourceLineNo">2997</span>    return zkCluster;<a name="line.2997"></a>
-<span class="sourceLineNo">2998</span>  }<a name="line.2998"></a>
-<span class="sourceLineNo">2999</span><a name="line.2999"></a>
-<span class="sourceLineNo">3000</span>  public void setZkCluster(MiniZooKeeperCluster zkCluster) {<a name="line.3000"></a>
-<span class="sourceLineNo">3001</span>    this.passedZkCluster = true;<a name="line.3001"></a>
-<span class="sourceLineNo">3002</span>    this.zkCluster = zkCluster;<a name="line.3002"></a>
-<span class="sourceLineNo">3003</span>    conf.setInt(HConstants.ZOOKEEPER_CLIENT_PORT, zkCluster.getClientPort());<a name="line.3003"></a>
-<span class="sourceLineNo">3004</span>  }<a name="line.3004"></a>
-<span class="sourceLineNo">3005</span><a name="line.3005"></a>
-<span class="sourceLineNo">3006</span>  public MiniDFSCluster getDFSCluster() {<a name="line.3006"></a>
-<span class="sourceLineNo">3007</span>    return dfsCluster;<a name="line.3007"></a>
-<span class="sourceLineNo">3008</span>  }<a name="line.3008"></a>
-<span class="sourceLineNo">3009</span><a name="line.3009"></a>
-<span class="sourceLineNo">3010</span>  public void setDFSCluster(MiniDFSCluster cluster) throws IllegalStateException, IOException {<a name="line.3010"></a>
-<span class="sourceLineNo">3011</span>    setDFSCluster(cluster, true);<a name="line.3011"></a>
-<span class="sourceLineNo">3012</span>  }<a name="line.3012"></a>
-<span class="sourceLineNo">3013</span><a name="line.3013"></a>
-<span class="sourceLineNo">3014</span>  /**<a name="line.3014"></a>
-<span class="sourceLineNo">3015</span>   * Set the MiniDFSCluster<a name="line.3015"></a>
-<span class="sourceLineNo">3016</span>   * @param cluster cluster to use<a name="line.3016"></a>
-<span class="sourceLineNo">3017</span>   * @param requireDown require the that cluster not be "up" (MiniDFSCluster#isClusterUp) before<a name="line.3017"></a>
-<span class="sourceLineNo">3018</span>   * it is set.<a name="line.3018"></a>
-<span class="sourceLineNo">3019</span>   * @throws IllegalStateException if the passed cluster is up when it is required to be down<a name="line.3019"></a>
-<span class="sourceLineNo">3020</span>   * @throws IOException if the FileSystem could not be set from the passed dfs cluster<a name="line.3020"></a>
-<span class="sourceLineNo">3021</span>   */<a name="line.3021"></a>
-<span class="sourceLineNo">3022</span>  public void setDFSCluster(MiniDFSCluster cluster, boolean requireDown)<a name="line.3022"></a>
-<span class="sourceLineNo">3023</span>      throws IllegalStateException, IOException {<a name="line.3023"></a>
-<span class="sourceLineNo">3024</span>    if (dfsCluster != null &amp;&amp; requireDown &amp;&amp; dfsCluster.isClusterUp()) {<a name="line.3024"></a>
-<span class="sourceLineNo">3025</span>      throw new IllegalStateException("DFSCluster is already running! Shut it down first.");<a name="line.3025"></a>
-<span class="sourceLineNo">3026</span>    }<a name="line.3026"></a>
-<span class="sourceLineNo">3027</span>    this.dfsCluster = cluster;<a name="line.3027"></a>
-<span class="sourceLineNo">3028</span>    this.setFs();<a name="line.3028"></a>
-<span class="sourceLineNo">3029</span>  }<a name="line.3029"></a>
-<span class="sourceLineNo">3030</span><a name="line.3030"></a>
-<span class="sourceLineNo">3031</span>  public FileSystem getTestFileSystem() throws IOException {<a name="line.3031"></a>
-<span class="sourceLineNo">3032</span>    return HFileSystem.get(conf);<a name="line.3032"></a>
-<span class="sourceLineNo">3033</span>  }<a name="line.3033"></a>
-<span class="sourceLineNo">3034</span><a name="line.3034"></a>
-<span class="sourceLineNo">3035</span>  /**<a name="line.3035"></a>
-<span class="sourceLineNo">3036</span>   * Wait until all regions in a table have been assigned.  Waits default timeout before giving up<a name="line.3036"></a>
-<span class="sourceLineNo">3037</span>   * (30 seconds).<a name="line.3037"></a>
-<span class="sourceLineNo">3038</span>   * @param table Table to wait on.<a name="line.3038"></a>
-<span class="sourceLineNo">3039</span>   * @throws InterruptedException<a name="line.3039"></a>
-<span class="sourceLineNo">3040</span>   * @throws IOException<a name="line.3040"></a>
-<span class="sourceLineNo">3041</span>   */<a name="line.3041"></a>
-<span class="sourceLineNo">3042</span>  public void waitTableAvailable(TableName table)<a name="line.3042"></a>
-<span class="sourceLineNo">3043</span>      throws InterruptedException, IOException {<a name="line.3043"></a>
-<span class="sourceLineNo">3044</span>    waitTableAvailable(table.getName(), 30000);<a name="line.3044"></a>
-<span class="sourceLineNo">3045</span>  }<a name="line.3045"></a>
-<span class="sourceLineNo">3046</span><a name="line.3046"></a>
-<span class="sourceLineNo">3047</span>  public void waitTableAvailable(TableName table, long timeoutMillis)<a name="line.3047"></a>
-<span class="sourceLineNo">3048</span>      throws InterruptedException, IOException {<a name="line.3048"></a>
-<span class="sourceLineNo">3049</span>    waitFor(timeoutMillis, predicateTableAvailable(table));<a name="line.3049"></a>
-<span class="sourceLineNo">3050</span>  }<a name="line.3050"></a>
-<span class="sourceLineNo">3051</span><a name="line.3051"></a>
-<span class="sourceLineNo">3052</span>  /**<a name="line.3052"></a>
-<span class="sourceLineNo">3053</span>   * Wait until all regions in a table have been assigned<a name="line.3053"></a>
-<span class="sourceLineNo">3054</span>   * @param table Table to wait on.<a name="line.3054"></a>
-<span class="sourceLineNo">3055</span>   * @param timeoutMillis Timeout.<a name="line.3055"></a>
-<span class="sourceLineNo">3056</span>   * @throws InterruptedException<a name="line.3056"></a>
-<span class="sourceLineNo">3057</span>   * @throws IOException<a name="line.3057"></a>
-<span class="sourceLineNo">3058</span>   */<a name="line.3058"></a>
-<span class="sourceLineNo">3059</span>  public void waitTableAvailable(byte[] table, long timeoutMillis)<a name="line.3059"></a>
-<span class="sourceLineNo">3060</span>  throws InterruptedException, IOException {<a name="line.3060"></a>
-<span class="sourceLineNo">3061</span>    waitFor(timeoutMillis, predicateTableAvailable(TableName.valueOf(table)));<a name="line.3061"></a>
-<span class="sourceLineNo">3062</span>  }<a name="line.3062"></a>
-<span class="sourceLineNo">3063</span><a name="line.3063"></a>
-<span class="sourceLineNo">3064</span>  public String explainTableAvailability(TableName tableName) throws IOException {<a name="line.3064"></a>
-<span class="sourceLineNo">3065</span>    String msg = explainTableState(tableName, TableState.State.ENABLED) + ", ";<a name="line.3065"></a>
-<span class="sourceLineNo">3066</span>    if (getHBaseCluster().getMaster().isAlive()) {<a name="line.3066"></a>
-<span class="sourceLineNo">3067</span>      Map&lt;RegionInfo, ServerName&gt; assignments =<a name="line.3067"></a>
-<span class="sourceLineNo">3068</span>          getHBaseCluster().getMaster().getAssignmentManager().getRegionStates()<a name="line.3068"></a>
-<span class="sourceLineNo">3069</span>              .getRegionAssignments();<a name="line.3069"></a>
-<span class="sourceLineNo">3070</span>      final List&lt;Pair&lt;RegionInfo, ServerName&gt;&gt; metaLocations =<a name="line.3070"></a>
-<span class="sourceLineNo">3071</span>          MetaTableAccessor.getTableRegionsAndLocations(connection, tableName);<a name="line.3071"></a>
-<span class="sourceLineNo">3072</span>      for (Pair&lt;RegionInfo, ServerName&gt; metaLocation : metaLocations) {<a name="line.3072"></a>
-<span class="sourceLineNo">3073</span>        RegionInfo hri = metaLocation.getFirst();<a name="line.3073"></a>
-<span class="sourceLineNo">3074</span>        ServerName sn = metaLocation.getSecond();<a name="line.3074"></a>
-<span class="sourceLineNo">3075</span>        if (!assignments.containsKey(hri)) {<a name="line.3075"></a>
-<span class="sourceLineNo">3076</span>          msg += ", region " + hri<a name="line.3076"></

<TRUNCATED>