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/18 15:17:21 UTC

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

Repository: hbase-site
Updated Branches:
  refs/heads/asf-site abbe3df34 -> a80edfeca


http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/testdevapidocs/src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html b/testdevapidocs/src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html
index cccfe2e..295ed45 100644
--- a/testdevapidocs/src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html
+++ b/testdevapidocs/src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html
@@ -6,7 +6,7 @@
 </head>
 <body>
 <div class="sourceContainer">
-<pre><span class="sourceLineNo">001</span>/*<a name="line.1"></a>
+<pre><span class="sourceLineNo">001</span>/**<a name="line.1"></a>
 <span class="sourceLineNo">002</span> * Licensed to the Apache Software Foundation (ASF) under one<a name="line.2"></a>
 <span class="sourceLineNo">003</span> * or more contributor license agreements.  See the NOTICE file<a name="line.3"></a>
 <span class="sourceLineNo">004</span> * distributed with this work for additional information<a name="line.4"></a>
@@ -46,722 +46,719 @@
 <span class="sourceLineNo">038</span>import org.apache.hadoop.fs.Path;<a name="line.38"></a>
 <span class="sourceLineNo">039</span>import org.apache.hadoop.hbase.Cell;<a name="line.39"></a>
 <span class="sourceLineNo">040</span>import org.apache.hadoop.hbase.ClusterStatus;<a name="line.40"></a>
-<span class="sourceLineNo">041</span>import org.apache.hadoop.hbase.HBaseConfiguration;<a name="line.41"></a>
-<span class="sourceLineNo">042</span>import org.apache.hadoop.hbase.HBaseTestingUtility;<a name="line.42"></a>
-<span class="sourceLineNo">043</span>import org.apache.hadoop.hbase.HColumnDescriptor;<a name="line.43"></a>
+<span class="sourceLineNo">041</span>import org.apache.hadoop.hbase.ClusterStatus.Option;<a name="line.41"></a>
+<span class="sourceLineNo">042</span>import org.apache.hadoop.hbase.HBaseConfiguration;<a name="line.42"></a>
+<span class="sourceLineNo">043</span>import org.apache.hadoop.hbase.HBaseTestingUtility;<a name="line.43"></a>
 <span class="sourceLineNo">044</span>import org.apache.hadoop.hbase.HConstants;<a name="line.44"></a>
-<span class="sourceLineNo">045</span>import org.apache.hadoop.hbase.HTableDescriptor;<a name="line.45"></a>
-<span class="sourceLineNo">046</span>import org.apache.hadoop.hbase.KeyValue;<a name="line.46"></a>
-<span class="sourceLineNo">047</span>import org.apache.hadoop.hbase.MiniHBaseCluster;<a name="line.47"></a>
-<span class="sourceLineNo">048</span>import org.apache.hadoop.hbase.ServerLoad;<a name="line.48"></a>
-<span class="sourceLineNo">049</span>import org.apache.hadoop.hbase.ServerName;<a name="line.49"></a>
-<span class="sourceLineNo">050</span>import org.apache.hadoop.hbase.TableName;<a name="line.50"></a>
-<span class="sourceLineNo">051</span>import org.apache.hadoop.hbase.Waiter;<a name="line.51"></a>
-<span class="sourceLineNo">052</span>import org.apache.hadoop.hbase.ClusterStatus.Option;<a name="line.52"></a>
-<span class="sourceLineNo">053</span>import org.apache.hadoop.hbase.client.Admin;<a name="line.53"></a>
-<span class="sourceLineNo">054</span>import org.apache.hadoop.hbase.client.ConnectionFactory;<a name="line.54"></a>
-<span class="sourceLineNo">055</span>import org.apache.hadoop.hbase.client.Delete;<a name="line.55"></a>
-<span class="sourceLineNo">056</span>import org.apache.hadoop.hbase.client.Durability;<a name="line.56"></a>
-<span class="sourceLineNo">057</span>import org.apache.hadoop.hbase.client.Get;<a name="line.57"></a>
-<span class="sourceLineNo">058</span>import org.apache.hadoop.hbase.client.Put;<a name="line.58"></a>
-<span class="sourceLineNo">059</span>import org.apache.hadoop.hbase.client.Result;<a name="line.59"></a>
-<span class="sourceLineNo">060</span>import org.apache.hadoop.hbase.client.Table;<a name="line.60"></a>
-<span class="sourceLineNo">061</span>import org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil;<a name="line.61"></a>
-<span class="sourceLineNo">062</span>import org.apache.hadoop.hbase.coprocessor.CoprocessorHost;<a name="line.62"></a>
-<span class="sourceLineNo">063</span>import org.apache.hadoop.hbase.coprocessor.ObserverContext;<a name="line.63"></a>
-<span class="sourceLineNo">064</span>import org.apache.hadoop.hbase.coprocessor.RegionCoprocessor;<a name="line.64"></a>
-<span class="sourceLineNo">065</span>import org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment;<a name="line.65"></a>
-<span class="sourceLineNo">066</span>import org.apache.hadoop.hbase.coprocessor.RegionObserver;<a name="line.66"></a>
-<span class="sourceLineNo">067</span>import org.apache.hadoop.hbase.regionserver.HRegion;<a name="line.67"></a>
-<span class="sourceLineNo">068</span>import org.apache.hadoop.hbase.regionserver.wal.WALActionsListener;<a name="line.68"></a>
-<span class="sourceLineNo">069</span>import org.apache.hadoop.hbase.wal.WALEdit;<a name="line.69"></a>
+<span class="sourceLineNo">045</span>import org.apache.hadoop.hbase.KeyValue;<a name="line.45"></a>
+<span class="sourceLineNo">046</span>import org.apache.hadoop.hbase.MiniHBaseCluster;<a name="line.46"></a>
+<span class="sourceLineNo">047</span>import org.apache.hadoop.hbase.ServerLoad;<a name="line.47"></a>
+<span class="sourceLineNo">048</span>import org.apache.hadoop.hbase.ServerName;<a name="line.48"></a>
+<span class="sourceLineNo">049</span>import org.apache.hadoop.hbase.TableName;<a name="line.49"></a>
+<span class="sourceLineNo">050</span>import org.apache.hadoop.hbase.Waiter;<a name="line.50"></a>
+<span class="sourceLineNo">051</span>import org.apache.hadoop.hbase.client.Admin;<a name="line.51"></a>
+<span class="sourceLineNo">052</span>import org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder;<a name="line.52"></a>
+<span class="sourceLineNo">053</span>import org.apache.hadoop.hbase.client.ConnectionFactory;<a name="line.53"></a>
+<span class="sourceLineNo">054</span>import org.apache.hadoop.hbase.client.Delete;<a name="line.54"></a>
+<span class="sourceLineNo">055</span>import org.apache.hadoop.hbase.client.Durability;<a name="line.55"></a>
+<span class="sourceLineNo">056</span>import org.apache.hadoop.hbase.client.Get;<a name="line.56"></a>
+<span class="sourceLineNo">057</span>import org.apache.hadoop.hbase.client.Put;<a name="line.57"></a>
+<span class="sourceLineNo">058</span>import org.apache.hadoop.hbase.client.Result;<a name="line.58"></a>
+<span class="sourceLineNo">059</span>import org.apache.hadoop.hbase.client.Table;<a name="line.59"></a>
+<span class="sourceLineNo">060</span>import org.apache.hadoop.hbase.client.TableDescriptor;<a name="line.60"></a>
+<span class="sourceLineNo">061</span>import org.apache.hadoop.hbase.client.TableDescriptorBuilder;<a name="line.61"></a>
+<span class="sourceLineNo">062</span>import org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil;<a name="line.62"></a>
+<span class="sourceLineNo">063</span>import org.apache.hadoop.hbase.coprocessor.CoprocessorHost;<a name="line.63"></a>
+<span class="sourceLineNo">064</span>import org.apache.hadoop.hbase.coprocessor.ObserverContext;<a name="line.64"></a>
+<span class="sourceLineNo">065</span>import org.apache.hadoop.hbase.coprocessor.RegionCoprocessor;<a name="line.65"></a>
+<span class="sourceLineNo">066</span>import org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment;<a name="line.66"></a>
+<span class="sourceLineNo">067</span>import org.apache.hadoop.hbase.coprocessor.RegionObserver;<a name="line.67"></a>
+<span class="sourceLineNo">068</span>import org.apache.hadoop.hbase.regionserver.HRegion;<a name="line.68"></a>
+<span class="sourceLineNo">069</span>import org.apache.hadoop.hbase.regionserver.wal.WALActionsListener;<a name="line.69"></a>
 <span class="sourceLineNo">070</span>import org.apache.hadoop.hbase.replication.regionserver.TestSourceFSConfigurationProvider;<a name="line.70"></a>
 <span class="sourceLineNo">071</span>import org.apache.hadoop.hbase.testclassification.LargeTests;<a name="line.71"></a>
 <span class="sourceLineNo">072</span>import org.apache.hadoop.hbase.testclassification.ReplicationTests;<a name="line.72"></a>
 <span class="sourceLineNo">073</span>import org.apache.hadoop.hbase.tool.LoadIncrementalHFiles;<a name="line.73"></a>
 <span class="sourceLineNo">074</span>import org.apache.hadoop.hbase.util.Bytes;<a name="line.74"></a>
 <span class="sourceLineNo">075</span>import org.apache.hadoop.hbase.util.HFileTestUtil;<a name="line.75"></a>
-<span class="sourceLineNo">076</span>import org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster;<a name="line.76"></a>
-<span class="sourceLineNo">077</span>import org.apache.hadoop.hbase.zookeeper.ZKUtil;<a name="line.77"></a>
-<span class="sourceLineNo">078</span>import org.apache.hadoop.hbase.zookeeper.ZKWatcher;<a name="line.78"></a>
-<span class="sourceLineNo">079</span>import org.apache.hadoop.hbase.zookeeper.ZNodePaths;<a name="line.79"></a>
-<span class="sourceLineNo">080</span>import org.junit.After;<a name="line.80"></a>
-<span class="sourceLineNo">081</span>import org.junit.Before;<a name="line.81"></a>
-<span class="sourceLineNo">082</span>import org.junit.Test;<a name="line.82"></a>
-<span class="sourceLineNo">083</span>import org.junit.experimental.categories.Category;<a name="line.83"></a>
-<span class="sourceLineNo">084</span><a name="line.84"></a>
-<span class="sourceLineNo">085</span>@Category({ReplicationTests.class, LargeTests.class})<a name="line.85"></a>
-<span class="sourceLineNo">086</span>public class TestMasterReplication {<a name="line.86"></a>
-<span class="sourceLineNo">087</span><a name="line.87"></a>
-<span class="sourceLineNo">088</span>  private static final Log LOG = LogFactory.getLog(TestReplicationBase.class);<a name="line.88"></a>
-<span class="sourceLineNo">089</span><a name="line.89"></a>
-<span class="sourceLineNo">090</span>  private Configuration baseConfiguration;<a name="line.90"></a>
-<span class="sourceLineNo">091</span><a name="line.91"></a>
-<span class="sourceLineNo">092</span>  private HBaseTestingUtility[] utilities;<a name="line.92"></a>
-<span class="sourceLineNo">093</span>  private Configuration[] configurations;<a name="line.93"></a>
-<span class="sourceLineNo">094</span>  private MiniZooKeeperCluster miniZK;<a name="line.94"></a>
-<span class="sourceLineNo">095</span><a name="line.95"></a>
-<span class="sourceLineNo">096</span>  private static final long SLEEP_TIME = 1000;<a name="line.96"></a>
-<span class="sourceLineNo">097</span>  private static final int NB_RETRIES = 120;<a name="line.97"></a>
-<span class="sourceLineNo">098</span><a name="line.98"></a>
-<span class="sourceLineNo">099</span>  private static final TableName tableName = TableName.valueOf("test");<a name="line.99"></a>
-<span class="sourceLineNo">100</span>  private static final byte[] famName = Bytes.toBytes("f");<a name="line.100"></a>
-<span class="sourceLineNo">101</span>  private static final byte[] famName1 = Bytes.toBytes("f1");<a name="line.101"></a>
-<span class="sourceLineNo">102</span>  private static final byte[] row = Bytes.toBytes("row");<a name="line.102"></a>
-<span class="sourceLineNo">103</span>  private static final byte[] row1 = Bytes.toBytes("row1");<a name="line.103"></a>
-<span class="sourceLineNo">104</span>  private static final byte[] row2 = Bytes.toBytes("row2");<a name="line.104"></a>
-<span class="sourceLineNo">105</span>  private static final byte[] row3 = Bytes.toBytes("row3");<a name="line.105"></a>
-<span class="sourceLineNo">106</span>  private static final byte[] row4 = Bytes.toBytes("row4");<a name="line.106"></a>
-<span class="sourceLineNo">107</span>  private static final byte[] noRepfamName = Bytes.toBytes("norep");<a name="line.107"></a>
-<span class="sourceLineNo">108</span><a name="line.108"></a>
-<span class="sourceLineNo">109</span>  private static final byte[] count = Bytes.toBytes("count");<a name="line.109"></a>
-<span class="sourceLineNo">110</span>  private static final byte[] put = Bytes.toBytes("put");<a name="line.110"></a>
-<span class="sourceLineNo">111</span>  private static final byte[] delete = Bytes.toBytes("delete");<a name="line.111"></a>
-<span class="sourceLineNo">112</span><a name="line.112"></a>
-<span class="sourceLineNo">113</span>  private HTableDescriptor table;<a name="line.113"></a>
-<span class="sourceLineNo">114</span><a name="line.114"></a>
-<span class="sourceLineNo">115</span>  @Before<a name="line.115"></a>
-<span class="sourceLineNo">116</span>  public void setUp() throws Exception {<a name="line.116"></a>
-<span class="sourceLineNo">117</span>    baseConfiguration = HBaseConfiguration.create();<a name="line.117"></a>
-<span class="sourceLineNo">118</span>    // smaller block size and capacity to trigger more operations<a name="line.118"></a>
-<span class="sourceLineNo">119</span>    // and test them<a name="line.119"></a>
-<span class="sourceLineNo">120</span>    baseConfiguration.setInt("hbase.regionserver.hlog.blocksize", 1024 * 20);<a name="line.120"></a>
-<span class="sourceLineNo">121</span>    baseConfiguration.setInt("replication.source.size.capacity", 1024);<a name="line.121"></a>
-<span class="sourceLineNo">122</span>    baseConfiguration.setLong("replication.source.sleepforretries", 100);<a name="line.122"></a>
-<span class="sourceLineNo">123</span>    baseConfiguration.setInt("hbase.regionserver.maxlogs", 10);<a name="line.123"></a>
-<span class="sourceLineNo">124</span>    baseConfiguration.setLong("hbase.master.logcleaner.ttl", 10);<a name="line.124"></a>
-<span class="sourceLineNo">125</span>    baseConfiguration.setBoolean(HConstants.REPLICATION_BULKLOAD_ENABLE_KEY, true);<a name="line.125"></a>
-<span class="sourceLineNo">126</span>    baseConfiguration.set("hbase.replication.source.fs.conf.provider",<a name="line.126"></a>
-<span class="sourceLineNo">127</span>      TestSourceFSConfigurationProvider.class.getCanonicalName());<a name="line.127"></a>
-<span class="sourceLineNo">128</span>    baseConfiguration.set(HConstants.REPLICATION_CLUSTER_ID, "12345");<a name="line.128"></a>
-<span class="sourceLineNo">129</span>    baseConfiguration.setLong(HConstants.THREAD_WAKE_FREQUENCY, 100);<a name="line.129"></a>
-<span class="sourceLineNo">130</span>    baseConfiguration.setStrings(<a name="line.130"></a>
-<span class="sourceLineNo">131</span>        CoprocessorHost.USER_REGION_COPROCESSOR_CONF_KEY,<a name="line.131"></a>
-<span class="sourceLineNo">132</span>        CoprocessorCounter.class.getName());<a name="line.132"></a>
-<span class="sourceLineNo">133</span><a name="line.133"></a>
-<span class="sourceLineNo">134</span>    table = new HTableDescriptor(tableName);<a name="line.134"></a>
-<span class="sourceLineNo">135</span>    HColumnDescriptor fam = new HColumnDescriptor(famName);<a name="line.135"></a>
-<span class="sourceLineNo">136</span>    fam.setScope(HConstants.REPLICATION_SCOPE_GLOBAL);<a name="line.136"></a>
-<span class="sourceLineNo">137</span>    table.addFamily(fam);<a name="line.137"></a>
-<span class="sourceLineNo">138</span>    fam = new HColumnDescriptor(famName1);<a name="line.138"></a>
-<span class="sourceLineNo">139</span>    fam.setScope(HConstants.REPLICATION_SCOPE_GLOBAL);<a name="line.139"></a>
-<span class="sourceLineNo">140</span>    table.addFamily(fam);<a name="line.140"></a>
-<span class="sourceLineNo">141</span>    fam = new HColumnDescriptor(noRepfamName);<a name="line.141"></a>
-<span class="sourceLineNo">142</span>    table.addFamily(fam);<a name="line.142"></a>
-<span class="sourceLineNo">143</span>  }<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>   * It tests the replication scenario involving 0 -&gt; 1 -&gt; 0. It does it by<a name="line.146"></a>
-<span class="sourceLineNo">147</span>   * adding and deleting a row to a table in each cluster, checking if it's<a name="line.147"></a>
-<span class="sourceLineNo">148</span>   * replicated. It also tests that the puts and deletes are not replicated back<a name="line.148"></a>
-<span class="sourceLineNo">149</span>   * to the originating cluster.<a name="line.149"></a>
-<span class="sourceLineNo">150</span>   */<a name="line.150"></a>
-<span class="sourceLineNo">151</span>  @Test(timeout = 300000)<a name="line.151"></a>
-<span class="sourceLineNo">152</span>  public void testCyclicReplication1() throws Exception {<a name="line.152"></a>
-<span class="sourceLineNo">153</span>    LOG.info("testSimplePutDelete");<a name="line.153"></a>
-<span class="sourceLineNo">154</span>    int numClusters = 2;<a name="line.154"></a>
-<span class="sourceLineNo">155</span>    Table[] htables = null;<a name="line.155"></a>
-<span class="sourceLineNo">156</span>    try {<a name="line.156"></a>
-<span class="sourceLineNo">157</span>      htables = setUpClusterTablesAndPeers(numClusters);<a name="line.157"></a>
-<span class="sourceLineNo">158</span><a name="line.158"></a>
-<span class="sourceLineNo">159</span>      int[] expectedCounts = new int[] { 2, 2 };<a name="line.159"></a>
-<span class="sourceLineNo">160</span><a name="line.160"></a>
-<span class="sourceLineNo">161</span>      // add rows to both clusters,<a name="line.161"></a>
-<span class="sourceLineNo">162</span>      // make sure they are both replication<a name="line.162"></a>
-<span class="sourceLineNo">163</span>      putAndWait(row, famName, htables[0], htables[1]);<a name="line.163"></a>
-<span class="sourceLineNo">164</span>      putAndWait(row1, famName, htables[1], htables[0]);<a name="line.164"></a>
-<span class="sourceLineNo">165</span>      validateCounts(htables, put, expectedCounts);<a name="line.165"></a>
-<span class="sourceLineNo">166</span><a name="line.166"></a>
-<span class="sourceLineNo">167</span>      deleteAndWait(row, htables[0], htables[1]);<a name="line.167"></a>
-<span class="sourceLineNo">168</span>      deleteAndWait(row1, htables[1], htables[0]);<a name="line.168"></a>
-<span class="sourceLineNo">169</span>      validateCounts(htables, delete, expectedCounts);<a name="line.169"></a>
-<span class="sourceLineNo">170</span>    } finally {<a name="line.170"></a>
-<span class="sourceLineNo">171</span>      close(htables);<a name="line.171"></a>
-<span class="sourceLineNo">172</span>      shutDownMiniClusters();<a name="line.172"></a>
-<span class="sourceLineNo">173</span>    }<a name="line.173"></a>
-<span class="sourceLineNo">174</span>  }<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>   * Tests the replication scenario 0 -&gt; 0. By default<a name="line.177"></a>
-<span class="sourceLineNo">178</span>   * {@link BaseReplicationEndpoint#canReplicateToSameCluster()} returns false, so the<a name="line.178"></a>
-<span class="sourceLineNo">179</span>   * ReplicationSource should terminate, and no further logs should get enqueued<a name="line.179"></a>
-<span class="sourceLineNo">180</span>   */<a name="line.180"></a>
-<span class="sourceLineNo">181</span>  @Test(timeout = 300000)<a name="line.181"></a>
-<span class="sourceLineNo">182</span>  public void testLoopedReplication() throws Exception {<a name="line.182"></a>
-<span class="sourceLineNo">183</span>    LOG.info("testLoopedReplication");<a name="line.183"></a>
-<span class="sourceLineNo">184</span>    startMiniClusters(1);<a name="line.184"></a>
-<span class="sourceLineNo">185</span>    createTableOnClusters(table);<a name="line.185"></a>
-<span class="sourceLineNo">186</span>    addPeer("1", 0, 0);<a name="line.186"></a>
-<span class="sourceLineNo">187</span>    Thread.sleep(SLEEP_TIME);<a name="line.187"></a>
-<span class="sourceLineNo">188</span><a name="line.188"></a>
-<span class="sourceLineNo">189</span>    // wait for source to terminate<a name="line.189"></a>
-<span class="sourceLineNo">190</span>    final ServerName rsName = utilities[0].getHBaseCluster().getRegionServer(0).getServerName();<a name="line.190"></a>
-<span class="sourceLineNo">191</span>    Waiter.waitFor(baseConfiguration, 10000, new Waiter.Predicate&lt;Exception&gt;() {<a name="line.191"></a>
-<span class="sourceLineNo">192</span>      @Override<a name="line.192"></a>
-<span class="sourceLineNo">193</span>      public boolean evaluate() throws Exception {<a name="line.193"></a>
-<span class="sourceLineNo">194</span>        ClusterStatus clusterStatus = utilities[0].getAdmin()<a name="line.194"></a>
-<span class="sourceLineNo">195</span>            .getClusterStatus(EnumSet.of(Option.LIVE_SERVERS));<a name="line.195"></a>
-<span class="sourceLineNo">196</span>        ServerLoad serverLoad = clusterStatus.getLoad(rsName);<a name="line.196"></a>
-<span class="sourceLineNo">197</span>        List&lt;ReplicationLoadSource&gt; replicationLoadSourceList =<a name="line.197"></a>
-<span class="sourceLineNo">198</span>            serverLoad.getReplicationLoadSourceList();<a name="line.198"></a>
-<span class="sourceLineNo">199</span>        return replicationLoadSourceList.isEmpty();<a name="line.199"></a>
-<span class="sourceLineNo">200</span>      }<a name="line.200"></a>
-<span class="sourceLineNo">201</span>    });<a name="line.201"></a>
-<span class="sourceLineNo">202</span><a name="line.202"></a>
-<span class="sourceLineNo">203</span>    Table[] htables = getHTablesOnClusters(tableName);<a name="line.203"></a>
-<span class="sourceLineNo">204</span>    putAndWait(row, famName, htables[0], htables[0]);<a name="line.204"></a>
-<span class="sourceLineNo">205</span>    rollWALAndWait(utilities[0], table.getTableName(), row);<a name="line.205"></a>
-<span class="sourceLineNo">206</span>    ZKWatcher zkw = utilities[0].getZooKeeperWatcher();<a name="line.206"></a>
-<span class="sourceLineNo">207</span>    String queuesZnode = ZNodePaths.joinZNode(zkw.getZNodePaths().baseZNode,<a name="line.207"></a>
-<span class="sourceLineNo">208</span>      ZNodePaths.joinZNode("replication", "rs"));<a name="line.208"></a>
-<span class="sourceLineNo">209</span>    List&lt;String&gt; listChildrenNoWatch =<a name="line.209"></a>
-<span class="sourceLineNo">210</span>        ZKUtil.listChildrenNoWatch(zkw, ZNodePaths.joinZNode(queuesZnode, rsName.toString()));<a name="line.210"></a>
-<span class="sourceLineNo">211</span>    assertEquals(0, listChildrenNoWatch.size());<a name="line.211"></a>
-<span class="sourceLineNo">212</span>  }<a name="line.212"></a>
-<span class="sourceLineNo">213</span><a name="line.213"></a>
-<span class="sourceLineNo">214</span>  /**<a name="line.214"></a>
-<span class="sourceLineNo">215</span>   * It tests the replication scenario involving 0 -&gt; 1 -&gt; 0. It does it by bulk loading a set of<a name="line.215"></a>
-<span class="sourceLineNo">216</span>   * HFiles to a table in each cluster, checking if it's replicated.<a name="line.216"></a>
-<span class="sourceLineNo">217</span>   */<a name="line.217"></a>
-<span class="sourceLineNo">218</span>  @Test(timeout = 300000)<a name="line.218"></a>
-<span class="sourceLineNo">219</span>  public void testHFileCyclicReplication() throws Exception {<a name="line.219"></a>
-<span class="sourceLineNo">220</span>    LOG.info("testHFileCyclicReplication");<a name="line.220"></a>
-<span class="sourceLineNo">221</span>    int numClusters = 2;<a name="line.221"></a>
-<span class="sourceLineNo">222</span>    Table[] htables = null;<a name="line.222"></a>
-<span class="sourceLineNo">223</span>    try {<a name="line.223"></a>
-<span class="sourceLineNo">224</span>      htables = setUpClusterTablesAndPeers(numClusters);<a name="line.224"></a>
-<span class="sourceLineNo">225</span><a name="line.225"></a>
-<span class="sourceLineNo">226</span>      // Load 100 rows for each hfile range in cluster '0' and validate whether its been replicated<a name="line.226"></a>
-<span class="sourceLineNo">227</span>      // to cluster '1'.<a name="line.227"></a>
-<span class="sourceLineNo">228</span>      byte[][][] hfileRanges =<a name="line.228"></a>
-<span class="sourceLineNo">229</span>          new byte[][][] { new byte[][] { Bytes.toBytes("aaaa"), Bytes.toBytes("cccc") },<a name="line.229"></a>
-<span class="sourceLineNo">230</span>              new byte[][] { Bytes.toBytes("ddd"), Bytes.toBytes("fff") }, };<a name="line.230"></a>
-<span class="sourceLineNo">231</span>      int numOfRows = 100;<a name="line.231"></a>
-<span class="sourceLineNo">232</span>      int[] expectedCounts =<a name="line.232"></a>
-<span class="sourceLineNo">233</span>          new int[] { hfileRanges.length * numOfRows, hfileRanges.length * numOfRows };<a name="line.233"></a>
+<span class="sourceLineNo">076</span>import org.apache.hadoop.hbase.wal.WALEdit;<a name="line.76"></a>
+<span class="sourceLineNo">077</span>import org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster;<a name="line.77"></a>
+<span class="sourceLineNo">078</span>import org.apache.hadoop.hbase.zookeeper.ZKUtil;<a name="line.78"></a>
+<span class="sourceLineNo">079</span>import org.apache.hadoop.hbase.zookeeper.ZKWatcher;<a name="line.79"></a>
+<span class="sourceLineNo">080</span>import org.apache.hadoop.hbase.zookeeper.ZNodePaths;<a name="line.80"></a>
+<span class="sourceLineNo">081</span>import org.junit.After;<a name="line.81"></a>
+<span class="sourceLineNo">082</span>import org.junit.Before;<a name="line.82"></a>
+<span class="sourceLineNo">083</span>import org.junit.Test;<a name="line.83"></a>
+<span class="sourceLineNo">084</span>import org.junit.experimental.categories.Category;<a name="line.84"></a>
+<span class="sourceLineNo">085</span><a name="line.85"></a>
+<span class="sourceLineNo">086</span>@Category({ReplicationTests.class, LargeTests.class})<a name="line.86"></a>
+<span class="sourceLineNo">087</span>public class TestMasterReplication {<a name="line.87"></a>
+<span class="sourceLineNo">088</span><a name="line.88"></a>
+<span class="sourceLineNo">089</span>  private static final Log LOG = LogFactory.getLog(TestReplicationBase.class);<a name="line.89"></a>
+<span class="sourceLineNo">090</span><a name="line.90"></a>
+<span class="sourceLineNo">091</span>  private Configuration baseConfiguration;<a name="line.91"></a>
+<span class="sourceLineNo">092</span><a name="line.92"></a>
+<span class="sourceLineNo">093</span>  private HBaseTestingUtility[] utilities;<a name="line.93"></a>
+<span class="sourceLineNo">094</span>  private Configuration[] configurations;<a name="line.94"></a>
+<span class="sourceLineNo">095</span>  private MiniZooKeeperCluster miniZK;<a name="line.95"></a>
+<span class="sourceLineNo">096</span><a name="line.96"></a>
+<span class="sourceLineNo">097</span>  private static final long SLEEP_TIME = 1000;<a name="line.97"></a>
+<span class="sourceLineNo">098</span>  private static final int NB_RETRIES = 120;<a name="line.98"></a>
+<span class="sourceLineNo">099</span><a name="line.99"></a>
+<span class="sourceLineNo">100</span>  private static final TableName tableName = TableName.valueOf("test");<a name="line.100"></a>
+<span class="sourceLineNo">101</span>  private static final byte[] famName = Bytes.toBytes("f");<a name="line.101"></a>
+<span class="sourceLineNo">102</span>  private static final byte[] famName1 = Bytes.toBytes("f1");<a name="line.102"></a>
+<span class="sourceLineNo">103</span>  private static final byte[] row = Bytes.toBytes("row");<a name="line.103"></a>
+<span class="sourceLineNo">104</span>  private static final byte[] row1 = Bytes.toBytes("row1");<a name="line.104"></a>
+<span class="sourceLineNo">105</span>  private static final byte[] row2 = Bytes.toBytes("row2");<a name="line.105"></a>
+<span class="sourceLineNo">106</span>  private static final byte[] row3 = Bytes.toBytes("row3");<a name="line.106"></a>
+<span class="sourceLineNo">107</span>  private static final byte[] row4 = Bytes.toBytes("row4");<a name="line.107"></a>
+<span class="sourceLineNo">108</span>  private static final byte[] noRepfamName = Bytes.toBytes("norep");<a name="line.108"></a>
+<span class="sourceLineNo">109</span><a name="line.109"></a>
+<span class="sourceLineNo">110</span>  private static final byte[] count = Bytes.toBytes("count");<a name="line.110"></a>
+<span class="sourceLineNo">111</span>  private static final byte[] put = Bytes.toBytes("put");<a name="line.111"></a>
+<span class="sourceLineNo">112</span>  private static final byte[] delete = Bytes.toBytes("delete");<a name="line.112"></a>
+<span class="sourceLineNo">113</span><a name="line.113"></a>
+<span class="sourceLineNo">114</span>  private TableDescriptor table;<a name="line.114"></a>
+<span class="sourceLineNo">115</span><a name="line.115"></a>
+<span class="sourceLineNo">116</span>  @Before<a name="line.116"></a>
+<span class="sourceLineNo">117</span>  public void setUp() throws Exception {<a name="line.117"></a>
+<span class="sourceLineNo">118</span>    baseConfiguration = HBaseConfiguration.create();<a name="line.118"></a>
+<span class="sourceLineNo">119</span>    // smaller block size and capacity to trigger more operations<a name="line.119"></a>
+<span class="sourceLineNo">120</span>    // and test them<a name="line.120"></a>
+<span class="sourceLineNo">121</span>    baseConfiguration.setInt("hbase.regionserver.hlog.blocksize", 1024 * 20);<a name="line.121"></a>
+<span class="sourceLineNo">122</span>    baseConfiguration.setInt("replication.source.size.capacity", 1024);<a name="line.122"></a>
+<span class="sourceLineNo">123</span>    baseConfiguration.setLong("replication.source.sleepforretries", 100);<a name="line.123"></a>
+<span class="sourceLineNo">124</span>    baseConfiguration.setInt("hbase.regionserver.maxlogs", 10);<a name="line.124"></a>
+<span class="sourceLineNo">125</span>    baseConfiguration.setLong("hbase.master.logcleaner.ttl", 10);<a name="line.125"></a>
+<span class="sourceLineNo">126</span>    baseConfiguration.setBoolean(HConstants.REPLICATION_BULKLOAD_ENABLE_KEY, true);<a name="line.126"></a>
+<span class="sourceLineNo">127</span>    baseConfiguration.set("hbase.replication.source.fs.conf.provider",<a name="line.127"></a>
+<span class="sourceLineNo">128</span>      TestSourceFSConfigurationProvider.class.getCanonicalName());<a name="line.128"></a>
+<span class="sourceLineNo">129</span>    baseConfiguration.set(HConstants.REPLICATION_CLUSTER_ID, "12345");<a name="line.129"></a>
+<span class="sourceLineNo">130</span>    baseConfiguration.setLong(HConstants.THREAD_WAKE_FREQUENCY, 100);<a name="line.130"></a>
+<span class="sourceLineNo">131</span>    baseConfiguration.setStrings(<a name="line.131"></a>
+<span class="sourceLineNo">132</span>        CoprocessorHost.USER_REGION_COPROCESSOR_CONF_KEY,<a name="line.132"></a>
+<span class="sourceLineNo">133</span>        CoprocessorCounter.class.getName());<a name="line.133"></a>
+<span class="sourceLineNo">134</span>    table = TableDescriptorBuilder.newBuilder(tableName)<a name="line.134"></a>
+<span class="sourceLineNo">135</span>        .addColumnFamily(ColumnFamilyDescriptorBuilder.newBuilder(famName)<a name="line.135"></a>
+<span class="sourceLineNo">136</span>            .setScope(HConstants.REPLICATION_SCOPE_GLOBAL).build())<a name="line.136"></a>
+<span class="sourceLineNo">137</span>        .addColumnFamily(ColumnFamilyDescriptorBuilder.newBuilder(famName1)<a name="line.137"></a>
+<span class="sourceLineNo">138</span>            .setScope(HConstants.REPLICATION_SCOPE_GLOBAL).build())<a name="line.138"></a>
+<span class="sourceLineNo">139</span>        .addColumnFamily(ColumnFamilyDescriptorBuilder.of(noRepfamName)).build();<a name="line.139"></a>
+<span class="sourceLineNo">140</span>  }<a name="line.140"></a>
+<span class="sourceLineNo">141</span><a name="line.141"></a>
+<span class="sourceLineNo">142</span>  /**<a name="line.142"></a>
+<span class="sourceLineNo">143</span>   * It tests the replication scenario involving 0 -&gt; 1 -&gt; 0. It does it by<a name="line.143"></a>
+<span class="sourceLineNo">144</span>   * adding and deleting a row to a table in each cluster, checking if it's<a name="line.144"></a>
+<span class="sourceLineNo">145</span>   * replicated. It also tests that the puts and deletes are not replicated back<a name="line.145"></a>
+<span class="sourceLineNo">146</span>   * to the originating cluster.<a name="line.146"></a>
+<span class="sourceLineNo">147</span>   */<a name="line.147"></a>
+<span class="sourceLineNo">148</span>  @Test(timeout = 300000)<a name="line.148"></a>
+<span class="sourceLineNo">149</span>  public void testCyclicReplication1() throws Exception {<a name="line.149"></a>
+<span class="sourceLineNo">150</span>    LOG.info("testSimplePutDelete");<a name="line.150"></a>
+<span class="sourceLineNo">151</span>    int numClusters = 2;<a name="line.151"></a>
+<span class="sourceLineNo">152</span>    Table[] htables = null;<a name="line.152"></a>
+<span class="sourceLineNo">153</span>    try {<a name="line.153"></a>
+<span class="sourceLineNo">154</span>      htables = setUpClusterTablesAndPeers(numClusters);<a name="line.154"></a>
+<span class="sourceLineNo">155</span><a name="line.155"></a>
+<span class="sourceLineNo">156</span>      int[] expectedCounts = new int[] { 2, 2 };<a name="line.156"></a>
+<span class="sourceLineNo">157</span><a name="line.157"></a>
+<span class="sourceLineNo">158</span>      // add rows to both clusters,<a name="line.158"></a>
+<span class="sourceLineNo">159</span>      // make sure they are both replication<a name="line.159"></a>
+<span class="sourceLineNo">160</span>      putAndWait(row, famName, htables[0], htables[1]);<a name="line.160"></a>
+<span class="sourceLineNo">161</span>      putAndWait(row1, famName, htables[1], htables[0]);<a name="line.161"></a>
+<span class="sourceLineNo">162</span>      validateCounts(htables, put, expectedCounts);<a name="line.162"></a>
+<span class="sourceLineNo">163</span><a name="line.163"></a>
+<span class="sourceLineNo">164</span>      deleteAndWait(row, htables[0], htables[1]);<a name="line.164"></a>
+<span class="sourceLineNo">165</span>      deleteAndWait(row1, htables[1], htables[0]);<a name="line.165"></a>
+<span class="sourceLineNo">166</span>      validateCounts(htables, delete, expectedCounts);<a name="line.166"></a>
+<span class="sourceLineNo">167</span>    } finally {<a name="line.167"></a>
+<span class="sourceLineNo">168</span>      close(htables);<a name="line.168"></a>
+<span class="sourceLineNo">169</span>      shutDownMiniClusters();<a name="line.169"></a>
+<span class="sourceLineNo">170</span>    }<a name="line.170"></a>
+<span class="sourceLineNo">171</span>  }<a name="line.171"></a>
+<span class="sourceLineNo">172</span><a name="line.172"></a>
+<span class="sourceLineNo">173</span>  /**<a name="line.173"></a>
+<span class="sourceLineNo">174</span>   * Tests the replication scenario 0 -&gt; 0. By default<a name="line.174"></a>
+<span class="sourceLineNo">175</span>   * {@link BaseReplicationEndpoint#canReplicateToSameCluster()} returns false, so the<a name="line.175"></a>
+<span class="sourceLineNo">176</span>   * ReplicationSource should terminate, and no further logs should get enqueued<a name="line.176"></a>
+<span class="sourceLineNo">177</span>   */<a name="line.177"></a>
+<span class="sourceLineNo">178</span>  @Test(timeout = 300000)<a name="line.178"></a>
+<span class="sourceLineNo">179</span>  public void testLoopedReplication() throws Exception {<a name="line.179"></a>
+<span class="sourceLineNo">180</span>    LOG.info("testLoopedReplication");<a name="line.180"></a>
+<span class="sourceLineNo">181</span>    startMiniClusters(1);<a name="line.181"></a>
+<span class="sourceLineNo">182</span>    createTableOnClusters(table);<a name="line.182"></a>
+<span class="sourceLineNo">183</span>    addPeer("1", 0, 0);<a name="line.183"></a>
+<span class="sourceLineNo">184</span>    Thread.sleep(SLEEP_TIME);<a name="line.184"></a>
+<span class="sourceLineNo">185</span><a name="line.185"></a>
+<span class="sourceLineNo">186</span>    // wait for source to terminate<a name="line.186"></a>
+<span class="sourceLineNo">187</span>    final ServerName rsName = utilities[0].getHBaseCluster().getRegionServer(0).getServerName();<a name="line.187"></a>
+<span class="sourceLineNo">188</span>    Waiter.waitFor(baseConfiguration, 10000, new Waiter.Predicate&lt;Exception&gt;() {<a name="line.188"></a>
+<span class="sourceLineNo">189</span>      @Override<a name="line.189"></a>
+<span class="sourceLineNo">190</span>      public boolean evaluate() throws Exception {<a name="line.190"></a>
+<span class="sourceLineNo">191</span>        ClusterStatus clusterStatus = utilities[0].getAdmin()<a name="line.191"></a>
+<span class="sourceLineNo">192</span>            .getClusterStatus(EnumSet.of(Option.LIVE_SERVERS));<a name="line.192"></a>
+<span class="sourceLineNo">193</span>        ServerLoad serverLoad = clusterStatus.getLoad(rsName);<a name="line.193"></a>
+<span class="sourceLineNo">194</span>        List&lt;ReplicationLoadSource&gt; replicationLoadSourceList =<a name="line.194"></a>
+<span class="sourceLineNo">195</span>            serverLoad.getReplicationLoadSourceList();<a name="line.195"></a>
+<span class="sourceLineNo">196</span>        return replicationLoadSourceList.isEmpty();<a name="line.196"></a>
+<span class="sourceLineNo">197</span>      }<a name="line.197"></a>
+<span class="sourceLineNo">198</span>    });<a name="line.198"></a>
+<span class="sourceLineNo">199</span><a name="line.199"></a>
+<span class="sourceLineNo">200</span>    Table[] htables = getHTablesOnClusters(tableName);<a name="line.200"></a>
+<span class="sourceLineNo">201</span>    putAndWait(row, famName, htables[0], htables[0]);<a name="line.201"></a>
+<span class="sourceLineNo">202</span>    rollWALAndWait(utilities[0], table.getTableName(), row);<a name="line.202"></a>
+<span class="sourceLineNo">203</span>    ZKWatcher zkw = utilities[0].getZooKeeperWatcher();<a name="line.203"></a>
+<span class="sourceLineNo">204</span>    String queuesZnode = ZNodePaths.joinZNode(zkw.getZNodePaths().baseZNode,<a name="line.204"></a>
+<span class="sourceLineNo">205</span>      ZNodePaths.joinZNode("replication", "rs"));<a name="line.205"></a>
+<span class="sourceLineNo">206</span>    List&lt;String&gt; listChildrenNoWatch =<a name="line.206"></a>
+<span class="sourceLineNo">207</span>        ZKUtil.listChildrenNoWatch(zkw, ZNodePaths.joinZNode(queuesZnode, rsName.toString()));<a name="line.207"></a>
+<span class="sourceLineNo">208</span>    assertEquals(0, listChildrenNoWatch.size());<a name="line.208"></a>
+<span class="sourceLineNo">209</span>  }<a name="line.209"></a>
+<span class="sourceLineNo">210</span><a name="line.210"></a>
+<span class="sourceLineNo">211</span>  /**<a name="line.211"></a>
+<span class="sourceLineNo">212</span>   * It tests the replication scenario involving 0 -&gt; 1 -&gt; 0. It does it by bulk loading a set of<a name="line.212"></a>
+<span class="sourceLineNo">213</span>   * HFiles to a table in each cluster, checking if it's replicated.<a name="line.213"></a>
+<span class="sourceLineNo">214</span>   */<a name="line.214"></a>
+<span class="sourceLineNo">215</span>  @Test(timeout = 300000)<a name="line.215"></a>
+<span class="sourceLineNo">216</span>  public void testHFileCyclicReplication() throws Exception {<a name="line.216"></a>
+<span class="sourceLineNo">217</span>    LOG.info("testHFileCyclicReplication");<a name="line.217"></a>
+<span class="sourceLineNo">218</span>    int numClusters = 2;<a name="line.218"></a>
+<span class="sourceLineNo">219</span>    Table[] htables = null;<a name="line.219"></a>
+<span class="sourceLineNo">220</span>    try {<a name="line.220"></a>
+<span class="sourceLineNo">221</span>      htables = setUpClusterTablesAndPeers(numClusters);<a name="line.221"></a>
+<span class="sourceLineNo">222</span><a name="line.222"></a>
+<span class="sourceLineNo">223</span>      // Load 100 rows for each hfile range in cluster '0' and validate whether its been replicated<a name="line.223"></a>
+<span class="sourceLineNo">224</span>      // to cluster '1'.<a name="line.224"></a>
+<span class="sourceLineNo">225</span>      byte[][][] hfileRanges =<a name="line.225"></a>
+<span class="sourceLineNo">226</span>          new byte[][][] { new byte[][] { Bytes.toBytes("aaaa"), Bytes.toBytes("cccc") },<a name="line.226"></a>
+<span class="sourceLineNo">227</span>              new byte[][] { Bytes.toBytes("ddd"), Bytes.toBytes("fff") }, };<a name="line.227"></a>
+<span class="sourceLineNo">228</span>      int numOfRows = 100;<a name="line.228"></a>
+<span class="sourceLineNo">229</span>      int[] expectedCounts =<a name="line.229"></a>
+<span class="sourceLineNo">230</span>          new int[] { hfileRanges.length * numOfRows, hfileRanges.length * numOfRows };<a name="line.230"></a>
+<span class="sourceLineNo">231</span><a name="line.231"></a>
+<span class="sourceLineNo">232</span>      loadAndValidateHFileReplication("testHFileCyclicReplication_01", 0, new int[] { 1 }, row,<a name="line.232"></a>
+<span class="sourceLineNo">233</span>        famName, htables, hfileRanges, numOfRows, expectedCounts, true);<a name="line.233"></a>
 <span class="sourceLineNo">234</span><a name="line.234"></a>
-<span class="sourceLineNo">235</span>      loadAndValidateHFileReplication("testHFileCyclicReplication_01", 0, new int[] { 1 }, row,<a name="line.235"></a>
-<span class="sourceLineNo">236</span>        famName, htables, hfileRanges, numOfRows, expectedCounts, true);<a name="line.236"></a>
-<span class="sourceLineNo">237</span><a name="line.237"></a>
-<span class="sourceLineNo">238</span>      // Load 200 rows for each hfile range in cluster '1' and validate whether its been replicated<a name="line.238"></a>
-<span class="sourceLineNo">239</span>      // to cluster '0'.<a name="line.239"></a>
-<span class="sourceLineNo">240</span>      hfileRanges = new byte[][][] { new byte[][] { Bytes.toBytes("gggg"), Bytes.toBytes("iiii") },<a name="line.240"></a>
-<span class="sourceLineNo">241</span>          new byte[][] { Bytes.toBytes("jjj"), Bytes.toBytes("lll") }, };<a name="line.241"></a>
-<span class="sourceLineNo">242</span>      numOfRows = 200;<a name="line.242"></a>
-<span class="sourceLineNo">243</span>      int[] newExpectedCounts = new int[] { hfileRanges.length * numOfRows + expectedCounts[0],<a name="line.243"></a>
-<span class="sourceLineNo">244</span>          hfileRanges.length * numOfRows + expectedCounts[1] };<a name="line.244"></a>
+<span class="sourceLineNo">235</span>      // Load 200 rows for each hfile range in cluster '1' and validate whether its been replicated<a name="line.235"></a>
+<span class="sourceLineNo">236</span>      // to cluster '0'.<a name="line.236"></a>
+<span class="sourceLineNo">237</span>      hfileRanges = new byte[][][] { new byte[][] { Bytes.toBytes("gggg"), Bytes.toBytes("iiii") },<a name="line.237"></a>
+<span class="sourceLineNo">238</span>          new byte[][] { Bytes.toBytes("jjj"), Bytes.toBytes("lll") }, };<a name="line.238"></a>
+<span class="sourceLineNo">239</span>      numOfRows = 200;<a name="line.239"></a>
+<span class="sourceLineNo">240</span>      int[] newExpectedCounts = new int[] { hfileRanges.length * numOfRows + expectedCounts[0],<a name="line.240"></a>
+<span class="sourceLineNo">241</span>          hfileRanges.length * numOfRows + expectedCounts[1] };<a name="line.241"></a>
+<span class="sourceLineNo">242</span><a name="line.242"></a>
+<span class="sourceLineNo">243</span>      loadAndValidateHFileReplication("testHFileCyclicReplication_10", 1, new int[] { 0 }, row,<a name="line.243"></a>
+<span class="sourceLineNo">244</span>        famName, htables, hfileRanges, numOfRows, newExpectedCounts, true);<a name="line.244"></a>
 <span class="sourceLineNo">245</span><a name="line.245"></a>
-<span class="sourceLineNo">246</span>      loadAndValidateHFileReplication("testHFileCyclicReplication_10", 1, new int[] { 0 }, row,<a name="line.246"></a>
-<span class="sourceLineNo">247</span>        famName, htables, hfileRanges, numOfRows, newExpectedCounts, true);<a name="line.247"></a>
-<span class="sourceLineNo">248</span><a name="line.248"></a>
-<span class="sourceLineNo">249</span>    } finally {<a name="line.249"></a>
-<span class="sourceLineNo">250</span>      close(htables);<a name="line.250"></a>
-<span class="sourceLineNo">251</span>      shutDownMiniClusters();<a name="line.251"></a>
-<span class="sourceLineNo">252</span>    }<a name="line.252"></a>
-<span class="sourceLineNo">253</span>  }<a name="line.253"></a>
-<span class="sourceLineNo">254</span><a name="line.254"></a>
-<span class="sourceLineNo">255</span>  private Table[] setUpClusterTablesAndPeers(int numClusters) throws Exception {<a name="line.255"></a>
-<span class="sourceLineNo">256</span>    Table[] htables;<a name="line.256"></a>
-<span class="sourceLineNo">257</span>    startMiniClusters(numClusters);<a name="line.257"></a>
-<span class="sourceLineNo">258</span>    createTableOnClusters(table);<a name="line.258"></a>
-<span class="sourceLineNo">259</span><a name="line.259"></a>
-<span class="sourceLineNo">260</span>    htables = getHTablesOnClusters(tableName);<a name="line.260"></a>
-<span class="sourceLineNo">261</span>    // Test the replication scenarios of 0 -&gt; 1 -&gt; 0<a name="line.261"></a>
-<span class="sourceLineNo">262</span>    addPeer("1", 0, 1);<a name="line.262"></a>
-<span class="sourceLineNo">263</span>    addPeer("1", 1, 0);<a name="line.263"></a>
-<span class="sourceLineNo">264</span>    return htables;<a name="line.264"></a>
-<span class="sourceLineNo">265</span>  }<a name="line.265"></a>
-<span class="sourceLineNo">266</span><a name="line.266"></a>
-<span class="sourceLineNo">267</span>  /**<a name="line.267"></a>
-<span class="sourceLineNo">268</span>   * Tests the cyclic replication scenario of 0 -&gt; 1 -&gt; 2 -&gt; 0 by adding and deleting rows to a<a name="line.268"></a>
-<span class="sourceLineNo">269</span>   * table in each clusters and ensuring that the each of these clusters get the appropriate<a name="line.269"></a>
-<span class="sourceLineNo">270</span>   * mutations. It also tests the grouping scenario where a cluster needs to replicate the edits<a name="line.270"></a>
-<span class="sourceLineNo">271</span>   * originating from itself and also the edits that it received using replication from a different<a name="line.271"></a>
-<span class="sourceLineNo">272</span>   * cluster. The scenario is explained in HBASE-9158<a name="line.272"></a>
-<span class="sourceLineNo">273</span>   */<a name="line.273"></a>
-<span class="sourceLineNo">274</span>  @Test(timeout = 300000)<a name="line.274"></a>
-<span class="sourceLineNo">275</span>  public void testCyclicReplication2() throws Exception {<a name="line.275"></a>
-<span class="sourceLineNo">276</span>    LOG.info("testCyclicReplication1");<a name="line.276"></a>
-<span class="sourceLineNo">277</span>    int numClusters = 3;<a name="line.277"></a>
-<span class="sourceLineNo">278</span>    Table[] htables = null;<a name="line.278"></a>
-<span class="sourceLineNo">279</span>    try {<a name="line.279"></a>
-<span class="sourceLineNo">280</span>      startMiniClusters(numClusters);<a name="line.280"></a>
-<span class="sourceLineNo">281</span>      createTableOnClusters(table);<a name="line.281"></a>
-<span class="sourceLineNo">282</span><a name="line.282"></a>
-<span class="sourceLineNo">283</span>      // Test the replication scenario of 0 -&gt; 1 -&gt; 2 -&gt; 0<a name="line.283"></a>
-<span class="sourceLineNo">284</span>      addPeer("1", 0, 1);<a name="line.284"></a>
-<span class="sourceLineNo">285</span>      addPeer("1", 1, 2);<a name="line.285"></a>
-<span class="sourceLineNo">286</span>      addPeer("1", 2, 0);<a name="line.286"></a>
-<span class="sourceLineNo">287</span><a name="line.287"></a>
-<span class="sourceLineNo">288</span>      htables = getHTablesOnClusters(tableName);<a name="line.288"></a>
-<span class="sourceLineNo">289</span><a name="line.289"></a>
-<span class="sourceLineNo">290</span>      // put "row" and wait 'til it got around<a name="line.290"></a>
-<span class="sourceLineNo">291</span>      putAndWait(row, famName, htables[0], htables[2]);<a name="line.291"></a>
-<span class="sourceLineNo">292</span>      putAndWait(row1, famName, htables[1], htables[0]);<a name="line.292"></a>
-<span class="sourceLineNo">293</span>      putAndWait(row2, famName, htables[2], htables[1]);<a name="line.293"></a>
-<span class="sourceLineNo">294</span><a name="line.294"></a>
-<span class="sourceLineNo">295</span>      deleteAndWait(row, htables[0], htables[2]);<a name="line.295"></a>
-<span class="sourceLineNo">296</span>      deleteAndWait(row1, htables[1], htables[0]);<a name="line.296"></a>
-<span class="sourceLineNo">297</span>      deleteAndWait(row2, htables[2], htables[1]);<a name="line.297"></a>
-<span class="sourceLineNo">298</span><a name="line.298"></a>
-<span class="sourceLineNo">299</span>      int[] expectedCounts = new int[] { 3, 3, 3 };<a name="line.299"></a>
-<span class="sourceLineNo">300</span>      validateCounts(htables, put, expectedCounts);<a name="line.300"></a>
-<span class="sourceLineNo">301</span>      validateCounts(htables, delete, expectedCounts);<a name="line.301"></a>
-<span class="sourceLineNo">302</span><a name="line.302"></a>
-<span class="sourceLineNo">303</span>      // Test HBASE-9158<a name="line.303"></a>
-<span class="sourceLineNo">304</span>      disablePeer("1", 2);<a name="line.304"></a>
-<span class="sourceLineNo">305</span>      // we now have an edit that was replicated into cluster originating from<a name="line.305"></a>
-<span class="sourceLineNo">306</span>      // cluster 0<a name="line.306"></a>
-<span class="sourceLineNo">307</span>      putAndWait(row3, famName, htables[0], htables[1]);<a name="line.307"></a>
-<span class="sourceLineNo">308</span>      // now add a local edit to cluster 1<a name="line.308"></a>
-<span class="sourceLineNo">309</span>      htables[1].put(new Put(row4).addColumn(famName, row4, row4));<a name="line.309"></a>
-<span class="sourceLineNo">310</span>      // re-enable replication from cluster 2 to cluster 0<a name="line.310"></a>
-<span class="sourceLineNo">311</span>      enablePeer("1", 2);<a name="line.311"></a>
-<span class="sourceLineNo">312</span>      // without HBASE-9158 the edit for row4 would have been marked with<a name="line.312"></a>
-<span class="sourceLineNo">313</span>      // cluster 0's id<a name="line.313"></a>
-<span class="sourceLineNo">314</span>      // and hence not replicated to cluster 0<a name="line.314"></a>
-<span class="sourceLineNo">315</span>      wait(row4, htables[0], true);<a name="line.315"></a>
-<span class="sourceLineNo">316</span>    } finally {<a name="line.316"></a>
-<span class="sourceLineNo">317</span>      close(htables);<a name="line.317"></a>
-<span class="sourceLineNo">318</span>      shutDownMiniClusters();<a name="line.318"></a>
-<span class="sourceLineNo">319</span>    }<a name="line.319"></a>
-<span class="sourceLineNo">320</span>  }<a name="line.320"></a>
-<span class="sourceLineNo">321</span><a name="line.321"></a>
-<span class="sourceLineNo">322</span>  /**<a name="line.322"></a>
-<span class="sourceLineNo">323</span>   * It tests the multi slave hfile replication scenario involving 0 -&gt; 1, 2. It does it by bulk<a name="line.323"></a>
-<span class="sourceLineNo">324</span>   * loading a set of HFiles to a table in master cluster, checking if it's replicated in its peers.<a name="line.324"></a>
-<span class="sourceLineNo">325</span>   */<a name="line.325"></a>
-<span class="sourceLineNo">326</span>  @Test(timeout = 300000)<a name="line.326"></a>
-<span class="sourceLineNo">327</span>  public void testHFileMultiSlaveReplication() throws Exception {<a name="line.327"></a>
-<span class="sourceLineNo">328</span>    LOG.info("testHFileMultiSlaveReplication");<a name="line.328"></a>
-<span class="sourceLineNo">329</span>    int numClusters = 3;<a name="line.329"></a>
-<span class="sourceLineNo">330</span>    Table[] htables = null;<a name="line.330"></a>
-<span class="sourceLineNo">331</span>    try {<a name="line.331"></a>
-<span class="sourceLineNo">332</span>      startMiniClusters(numClusters);<a name="line.332"></a>
-<span class="sourceLineNo">333</span>      createTableOnClusters(table);<a name="line.333"></a>
+<span class="sourceLineNo">246</span>    } finally {<a name="line.246"></a>
+<span class="sourceLineNo">247</span>      close(htables);<a name="line.247"></a>
+<span class="sourceLineNo">248</span>      shutDownMiniClusters();<a name="line.248"></a>
+<span class="sourceLineNo">249</span>    }<a name="line.249"></a>
+<span class="sourceLineNo">250</span>  }<a name="line.250"></a>
+<span class="sourceLineNo">251</span><a name="line.251"></a>
+<span class="sourceLineNo">252</span>  private Table[] setUpClusterTablesAndPeers(int numClusters) throws Exception {<a name="line.252"></a>
+<span class="sourceLineNo">253</span>    Table[] htables;<a name="line.253"></a>
+<span class="sourceLineNo">254</span>    startMiniClusters(numClusters);<a name="line.254"></a>
+<span class="sourceLineNo">255</span>    createTableOnClusters(table);<a name="line.255"></a>
+<span class="sourceLineNo">256</span><a name="line.256"></a>
+<span class="sourceLineNo">257</span>    htables = getHTablesOnClusters(tableName);<a name="line.257"></a>
+<span class="sourceLineNo">258</span>    // Test the replication scenarios of 0 -&gt; 1 -&gt; 0<a name="line.258"></a>
+<span class="sourceLineNo">259</span>    addPeer("1", 0, 1);<a name="line.259"></a>
+<span class="sourceLineNo">260</span>    addPeer("1", 1, 0);<a name="line.260"></a>
+<span class="sourceLineNo">261</span>    return htables;<a name="line.261"></a>
+<span class="sourceLineNo">262</span>  }<a name="line.262"></a>
+<span class="sourceLineNo">263</span><a name="line.263"></a>
+<span class="sourceLineNo">264</span>  /**<a name="line.264"></a>
+<span class="sourceLineNo">265</span>   * Tests the cyclic replication scenario of 0 -&gt; 1 -&gt; 2 -&gt; 0 by adding and deleting rows to a<a name="line.265"></a>
+<span class="sourceLineNo">266</span>   * table in each clusters and ensuring that the each of these clusters get the appropriate<a name="line.266"></a>
+<span class="sourceLineNo">267</span>   * mutations. It also tests the grouping scenario where a cluster needs to replicate the edits<a name="line.267"></a>
+<span class="sourceLineNo">268</span>   * originating from itself and also the edits that it received using replication from a different<a name="line.268"></a>
+<span class="sourceLineNo">269</span>   * cluster. The scenario is explained in HBASE-9158<a name="line.269"></a>
+<span class="sourceLineNo">270</span>   */<a name="line.270"></a>
+<span class="sourceLineNo">271</span>  @Test(timeout = 300000)<a name="line.271"></a>
+<span class="sourceLineNo">272</span>  public void testCyclicReplication2() throws Exception {<a name="line.272"></a>
+<span class="sourceLineNo">273</span>    LOG.info("testCyclicReplication2");<a name="line.273"></a>
+<span class="sourceLineNo">274</span>    int numClusters = 3;<a name="line.274"></a>
+<span class="sourceLineNo">275</span>    Table[] htables = null;<a name="line.275"></a>
+<span class="sourceLineNo">276</span>    try {<a name="line.276"></a>
+<span class="sourceLineNo">277</span>      startMiniClusters(numClusters);<a name="line.277"></a>
+<span class="sourceLineNo">278</span>      createTableOnClusters(table);<a name="line.278"></a>
+<span class="sourceLineNo">279</span><a name="line.279"></a>
+<span class="sourceLineNo">280</span>      // Test the replication scenario of 0 -&gt; 1 -&gt; 2 -&gt; 0<a name="line.280"></a>
+<span class="sourceLineNo">281</span>      addPeer("1", 0, 1);<a name="line.281"></a>
+<span class="sourceLineNo">282</span>      addPeer("1", 1, 2);<a name="line.282"></a>
+<span class="sourceLineNo">283</span>      addPeer("1", 2, 0);<a name="line.283"></a>
+<span class="sourceLineNo">284</span><a name="line.284"></a>
+<span class="sourceLineNo">285</span>      htables = getHTablesOnClusters(tableName);<a name="line.285"></a>
+<span class="sourceLineNo">286</span><a name="line.286"></a>
+<span class="sourceLineNo">287</span>      // put "row" and wait 'til it got around<a name="line.287"></a>
+<span class="sourceLineNo">288</span>      putAndWait(row, famName, htables[0], htables[2]);<a name="line.288"></a>
+<span class="sourceLineNo">289</span>      putAndWait(row1, famName, htables[1], htables[0]);<a name="line.289"></a>
+<span class="sourceLineNo">290</span>      putAndWait(row2, famName, htables[2], htables[1]);<a name="line.290"></a>
+<span class="sourceLineNo">291</span><a name="line.291"></a>
+<span class="sourceLineNo">292</span>      deleteAndWait(row, htables[0], htables[2]);<a name="line.292"></a>
+<span class="sourceLineNo">293</span>      deleteAndWait(row1, htables[1], htables[0]);<a name="line.293"></a>
+<span class="sourceLineNo">294</span>      deleteAndWait(row2, htables[2], htables[1]);<a name="line.294"></a>
+<span class="sourceLineNo">295</span><a name="line.295"></a>
+<span class="sourceLineNo">296</span>      int[] expectedCounts = new int[] { 3, 3, 3 };<a name="line.296"></a>
+<span class="sourceLineNo">297</span>      validateCounts(htables, put, expectedCounts);<a name="line.297"></a>
+<span class="sourceLineNo">298</span>      validateCounts(htables, delete, expectedCounts);<a name="line.298"></a>
+<span class="sourceLineNo">299</span><a name="line.299"></a>
+<span class="sourceLineNo">300</span>      // Test HBASE-9158<a name="line.300"></a>
+<span class="sourceLineNo">301</span>      disablePeer("1", 2);<a name="line.301"></a>
+<span class="sourceLineNo">302</span>      // we now have an edit that was replicated into cluster originating from<a name="line.302"></a>
+<span class="sourceLineNo">303</span>      // cluster 0<a name="line.303"></a>
+<span class="sourceLineNo">304</span>      putAndWait(row3, famName, htables[0], htables[1]);<a name="line.304"></a>
+<span class="sourceLineNo">305</span>      // now add a local edit to cluster 1<a name="line.305"></a>
+<span class="sourceLineNo">306</span>      htables[1].put(new Put(row4).addColumn(famName, row4, row4));<a name="line.306"></a>
+<span class="sourceLineNo">307</span>      // re-enable replication from cluster 2 to cluster 0<a name="line.307"></a>
+<span class="sourceLineNo">308</span>      enablePeer("1", 2);<a name="line.308"></a>
+<span class="sourceLineNo">309</span>      // without HBASE-9158 the edit for row4 would have been marked with<a name="line.309"></a>
+<span class="sourceLineNo">310</span>      // cluster 0's id<a name="line.310"></a>
+<span class="sourceLineNo">311</span>      // and hence not replicated to cluster 0<a name="line.311"></a>
+<span class="sourceLineNo">312</span>      wait(row4, htables[0], false);<a name="line.312"></a>
+<span class="sourceLineNo">313</span>    } finally {<a name="line.313"></a>
+<span class="sourceLineNo">314</span>      close(htables);<a name="line.314"></a>
+<span class="sourceLineNo">315</span>      shutDownMiniClusters();<a name="line.315"></a>
+<span class="sourceLineNo">316</span>    }<a name="line.316"></a>
+<span class="sourceLineNo">317</span>  }<a name="line.317"></a>
+<span class="sourceLineNo">318</span><a name="line.318"></a>
+<span class="sourceLineNo">319</span>  /**<a name="line.319"></a>
+<span class="sourceLineNo">320</span>   * It tests the multi slave hfile replication scenario involving 0 -&gt; 1, 2. It does it by bulk<a name="line.320"></a>
+<span class="sourceLineNo">321</span>   * loading a set of HFiles to a table in master cluster, checking if it's replicated in its peers.<a name="line.321"></a>
+<span class="sourceLineNo">322</span>   */<a name="line.322"></a>
+<span class="sourceLineNo">323</span>  @Test(timeout = 300000)<a name="line.323"></a>
+<span class="sourceLineNo">324</span>  public void testHFileMultiSlaveReplication() throws Exception {<a name="line.324"></a>
+<span class="sourceLineNo">325</span>    LOG.info("testHFileMultiSlaveReplication");<a name="line.325"></a>
+<span class="sourceLineNo">326</span>    int numClusters = 3;<a name="line.326"></a>
+<span class="sourceLineNo">327</span>    Table[] htables = null;<a name="line.327"></a>
+<span class="sourceLineNo">328</span>    try {<a name="line.328"></a>
+<span class="sourceLineNo">329</span>      startMiniClusters(numClusters);<a name="line.329"></a>
+<span class="sourceLineNo">330</span>      createTableOnClusters(table);<a name="line.330"></a>
+<span class="sourceLineNo">331</span><a name="line.331"></a>
+<span class="sourceLineNo">332</span>      // Add a slave, 0 -&gt; 1<a name="line.332"></a>
+<span class="sourceLineNo">333</span>      addPeer("1", 0, 1);<a name="line.333"></a>
 <span class="sourceLineNo">334</span><a name="line.334"></a>
-<span class="sourceLineNo">335</span>      // Add a slave, 0 -&gt; 1<a name="line.335"></a>
-<span class="sourceLineNo">336</span>      addPeer("1", 0, 1);<a name="line.336"></a>
-<span class="sourceLineNo">337</span><a name="line.337"></a>
-<span class="sourceLineNo">338</span>      htables = getHTablesOnClusters(tableName);<a name="line.338"></a>
-<span class="sourceLineNo">339</span><a name="line.339"></a>
-<span class="sourceLineNo">340</span>      // Load 100 rows for each hfile range in cluster '0' and validate whether its been replicated<a name="line.340"></a>
-<span class="sourceLineNo">341</span>      // to cluster '1'.<a name="line.341"></a>
-<span class="sourceLineNo">342</span>      byte[][][] hfileRanges =<a name="line.342"></a>
-<span class="sourceLineNo">343</span>          new byte[][][] { new byte[][] { Bytes.toBytes("mmmm"), Bytes.toBytes("oooo") },<a name="line.343"></a>
-<span class="sourceLineNo">344</span>              new byte[][] { Bytes.toBytes("ppp"), Bytes.toBytes("rrr") }, };<a name="line.344"></a>
-<span class="sourceLineNo">345</span>      int numOfRows = 100;<a name="line.345"></a>
+<span class="sourceLineNo">335</span>      htables = getHTablesOnClusters(tableName);<a name="line.335"></a>
+<span class="sourceLineNo">336</span><a name="line.336"></a>
+<span class="sourceLineNo">337</span>      // Load 100 rows for each hfile range in cluster '0' and validate whether its been replicated<a name="line.337"></a>
+<span class="sourceLineNo">338</span>      // to cluster '1'.<a name="line.338"></a>
+<span class="sourceLineNo">339</span>      byte[][][] hfileRanges =<a name="line.339"></a>
+<span class="sourceLineNo">340</span>          new byte[][][] { new byte[][] { Bytes.toBytes("mmmm"), Bytes.toBytes("oooo") },<a name="line.340"></a>
+<span class="sourceLineNo">341</span>              new byte[][] { Bytes.toBytes("ppp"), Bytes.toBytes("rrr") }, };<a name="line.341"></a>
+<span class="sourceLineNo">342</span>      int numOfRows = 100;<a name="line.342"></a>
+<span class="sourceLineNo">343</span><a name="line.343"></a>
+<span class="sourceLineNo">344</span>      int[] expectedCounts =<a name="line.344"></a>
+<span class="sourceLineNo">345</span>          new int[] { hfileRanges.length * numOfRows, hfileRanges.length * numOfRows };<a name="line.345"></a>
 <span class="sourceLineNo">346</span><a name="line.346"></a>
-<span class="sourceLineNo">347</span>      int[] expectedCounts =<a name="line.347"></a>
-<span class="sourceLineNo">348</span>          new int[] { hfileRanges.length * numOfRows, hfileRanges.length * numOfRows };<a name="line.348"></a>
+<span class="sourceLineNo">347</span>      loadAndValidateHFileReplication("testHFileCyclicReplication_0", 0, new int[] { 1 }, row,<a name="line.347"></a>
+<span class="sourceLineNo">348</span>        famName, htables, hfileRanges, numOfRows, expectedCounts, true);<a name="line.348"></a>
 <span class="sourceLineNo">349</span><a name="line.349"></a>
-<span class="sourceLineNo">350</span>      loadAndValidateHFileReplication("testHFileCyclicReplication_0", 0, new int[] { 1 }, row,<a name="line.350"></a>
-<span class="sourceLineNo">351</span>        famName, htables, hfileRanges, numOfRows, expectedCounts, true);<a name="line.351"></a>
+<span class="sourceLineNo">350</span>      // Validate data is not replicated to cluster '2'.<a name="line.350"></a>
+<span class="sourceLineNo">351</span>      assertEquals(0, utilities[2].countRows(htables[2]));<a name="line.351"></a>
 <span class="sourceLineNo">352</span><a name="line.352"></a>
-<span class="sourceLineNo">353</span>      // Validate data is not replicated to cluster '2'.<a name="line.353"></a>
-<span class="sourceLineNo">354</span>      assertEquals(0, utilities[2].countRows(htables[2]));<a name="line.354"></a>
-<span class="sourceLineNo">355</span><a name="line.355"></a>
-<span class="sourceLineNo">356</span>      rollWALAndWait(utilities[0], htables[0].getName(), row);<a name="line.356"></a>
+<span class="sourceLineNo">353</span>      rollWALAndWait(utilities[0], htables[0].getName(), row);<a name="line.353"></a>
+<span class="sourceLineNo">354</span><a name="line.354"></a>
+<span class="sourceLineNo">355</span>      // Add one more slave, 0 -&gt; 2<a name="line.355"></a>
+<span class="sourceLineNo">356</span>      addPeer("2", 0, 2);<a name="line.356"></a>
 <span class="sourceLineNo">357</span><a name="line.357"></a>
-<span class="sourceLineNo">358</span>      // Add one more slave, 0 -&gt; 2<a name="line.358"></a>
-<span class="sourceLineNo">359</span>      addPeer("2", 0, 2);<a name="line.359"></a>
-<span class="sourceLineNo">360</span><a name="line.360"></a>
-<span class="sourceLineNo">361</span>      // Load 200 rows for each hfile range in cluster '0' and validate whether its been replicated<a name="line.361"></a>
-<span class="sourceLineNo">362</span>      // to cluster '1' and '2'. Previous data should be replicated to cluster '2'.<a name="line.362"></a>
-<span class="sourceLineNo">363</span>      hfileRanges = new byte[][][] { new byte[][] { Bytes.toBytes("ssss"), Bytes.toBytes("uuuu") },<a name="line.363"></a>
-<span class="sourceLineNo">364</span>          new byte[][] { Bytes.toBytes("vvv"), Bytes.toBytes("xxx") }, };<a name="line.364"></a>
-<span class="sourceLineNo">365</span>      numOfRows = 200;<a name="line.365"></a>
+<span class="sourceLineNo">358</span>      // Load 200 rows for each hfile range in cluster '0' and validate whether its been replicated<a name="line.358"></a>
+<span class="sourceLineNo">359</span>      // to cluster '1' and '2'. Previous data should be replicated to cluster '2'.<a name="line.359"></a>
+<span class="sourceLineNo">360</span>      hfileRanges = new byte[][][] { new byte[][] { Bytes.toBytes("ssss"), Bytes.toBytes("uuuu") },<a name="line.360"></a>
+<span class="sourceLineNo">361</span>          new byte[][] { Bytes.toBytes("vvv"), Bytes.toBytes("xxx") }, };<a name="line.361"></a>
+<span class="sourceLineNo">362</span>      numOfRows = 200;<a name="line.362"></a>
+<span class="sourceLineNo">363</span><a name="line.363"></a>
+<span class="sourceLineNo">364</span>      int[] newExpectedCounts = new int[] { hfileRanges.length * numOfRows + expectedCounts[0],<a name="line.364"></a>
+<span class="sourceLineNo">365</span>          hfileRanges.length * numOfRows + expectedCounts[1], hfileRanges.length * numOfRows };<a name="line.365"></a>
 <span class="sourceLineNo">366</span><a name="line.366"></a>
-<span class="sourceLineNo">367</span>      int[] newExpectedCounts = new int[] { hfileRanges.length * numOfRows + expectedCounts[0],<a name="line.367"></a>
-<span class="sourceLineNo">368</span>          hfileRanges.length * numOfRows + expectedCounts[1], hfileRanges.length * numOfRows };<a name="line.368"></a>
+<span class="sourceLineNo">367</span>      loadAndValidateHFileReplication("testHFileCyclicReplication_1", 0, new int[] { 1, 2 }, row,<a name="line.367"></a>
+<span class="sourceLineNo">368</span>        famName, htables, hfileRanges, numOfRows, newExpectedCounts, true);<a name="line.368"></a>
 <span class="sourceLineNo">369</span><a name="line.369"></a>
-<span class="sourceLineNo">370</span>      loadAndValidateHFileReplication("testHFileCyclicReplication_1", 0, new int[] { 1, 2 }, row,<a name="line.370"></a>
-<span class="sourceLineNo">371</span>        famName, htables, hfileRanges, numOfRows, newExpectedCounts, true);<a name="line.371"></a>
-<span class="sourceLineNo">372</span><a name="line.372"></a>
-<span class="sourceLineNo">373</span>    } finally {<a name="line.373"></a>
-<span class="sourceLineNo">374</span>      close(htables);<a name="line.374"></a>
-<span class="sourceLineNo">375</span>      shutDownMiniClusters();<a name="line.375"></a>
-<span class="sourceLineNo">376</span>    }<a name="line.376"></a>
-<span class="sourceLineNo">377</span>  }<a name="line.377"></a>
-<span class="sourceLineNo">378</span><a name="line.378"></a>
-<span class="sourceLineNo">379</span>  /**<a name="line.379"></a>
-<span class="sourceLineNo">380</span>   * It tests the bulk loaded hfile replication scenario to only explicitly specified table column<a name="line.380"></a>
-<span class="sourceLineNo">381</span>   * families. It does it by bulk loading a set of HFiles belonging to both the CFs of table and set<a name="line.381"></a>
-<span class="sourceLineNo">382</span>   * only one CF data to replicate.<a name="line.382"></a>
-<span class="sourceLineNo">383</span>   */<a name="line.383"></a>
-<span class="sourceLineNo">384</span>  @Test(timeout = 300000)<a name="line.384"></a>
-<span class="sourceLineNo">385</span>  public void testHFileReplicationForConfiguredTableCfs() throws Exception {<a name="line.385"></a>
-<span class="sourceLineNo">386</span>    LOG.info("testHFileReplicationForConfiguredTableCfs");<a name="line.386"></a>
-<span class="sourceLineNo">387</span>    int numClusters = 2;<a name="line.387"></a>
-<span class="sourceLineNo">388</span>    Table[] htables = null;<a name="line.388"></a>
-<span class="sourceLineNo">389</span>    try {<a name="line.389"></a>
-<span class="sourceLineNo">390</span>      startMiniClusters(numClusters);<a name="line.390"></a>
-<span class="sourceLineNo">391</span>      createTableOnClusters(table);<a name="line.391"></a>
-<span class="sourceLineNo">392</span><a name="line.392"></a>
-<span class="sourceLineNo">393</span>      htables = getHTablesOnClusters(tableName);<a name="line.393"></a>
-<span class="sourceLineNo">394</span>      // Test the replication scenarios only 'f' is configured for table data replication not 'f1'<a name="line.394"></a>
-<span class="sourceLineNo">395</span>      addPeer("1", 0, 1, tableName.getNameAsString() + ":" + Bytes.toString(famName));<a name="line.395"></a>
-<span class="sourceLineNo">396</span><a name="line.396"></a>
-<span class="sourceLineNo">397</span>      // Load 100 rows for each hfile range in cluster '0' for table CF 'f'<a name="line.397"></a>
-<span class="sourceLineNo">398</span>      byte[][][] hfileRanges =<a name="line.398"></a>
-<span class="sourceLineNo">399</span>          new byte[][][] { new byte[][] { Bytes.toBytes("aaaa"), Bytes.toBytes("cccc") },<a name="line.399"></a>
-<span class="sourceLineNo">400</span>              new byte[][] { Bytes.toBytes("ddd"), Bytes.toBytes("fff") }, };<a name="line.400"></a>
-<span class="sourceLineNo">401</span>      int numOfRows = 100;<a name="line.401"></a>
-<span class="sourceLineNo">402</span>      int[] expectedCounts =<a name="line.402"></a>
-<span class="sourceLineNo">403</span>          new int[] { hfileRanges.length * numOfRows, hfileRanges.length * numOfRows };<a name="line.403"></a>
+<span class="sourceLineNo">370</span>    } finally {<a name="line.370"></a>
+<span class="sourceLineNo">371</span>      close(htables);<a name="line.371"></a>
+<span class="sourceLineNo">372</span>      shutDownMiniClusters();<a name="line.372"></a>
+<span class="sourceLineNo">373</span>    }<a name="line.373"></a>
+<span class="sourceLineNo">374</span>  }<a name="line.374"></a>
+<span class="sourceLineNo">375</span><a name="line.375"></a>
+<span class="sourceLineNo">376</span>  /**<a name="line.376"></a>
+<span class="sourceLineNo">377</span>   * It tests the bulk loaded hfile replication scenario to only explicitly specified table column<a name="line.377"></a>
+<span class="sourceLineNo">378</span>   * families. It does it by bulk loading a set of HFiles belonging to both the CFs of table and set<a name="line.378"></a>
+<span class="sourceLineNo">379</span>   * only one CF data to replicate.<a name="line.379"></a>
+<span class="sourceLineNo">380</span>   */<a name="line.380"></a>
+<span class="sourceLineNo">381</span>  @Test(timeout = 300000)<a name="line.381"></a>
+<span class="sourceLineNo">382</span>  public void testHFileReplicationForConfiguredTableCfs() throws Exception {<a name="line.382"></a>
+<span class="sourceLineNo">383</span>    LOG.info("testHFileReplicationForConfiguredTableCfs");<a name="line.383"></a>
+<span class="sourceLineNo">384</span>    int numClusters = 2;<a name="line.384"></a>
+<span class="sourceLineNo">385</span>    Table[] htables = null;<a name="line.385"></a>
+<span class="sourceLineNo">386</span>    try {<a name="line.386"></a>
+<span class="sourceLineNo">387</span>      startMiniClusters(numClusters);<a name="line.387"></a>
+<span class="sourceLineNo">388</span>      createTableOnClusters(table);<a name="line.388"></a>
+<span class="sourceLineNo">389</span><a name="line.389"></a>
+<span class="sourceLineNo">390</span>      htables = getHTablesOnClusters(tableName);<a name="line.390"></a>
+<span class="sourceLineNo">391</span>      // Test the replication scenarios only 'f' is configured for table data replication not 'f1'<a name="line.391"></a>
+<span class="sourceLineNo">392</span>      addPeer("1", 0, 1, tableName.getNameAsString() + ":" + Bytes.toString(famName));<a name="line.392"></a>
+<span class="sourceLineNo">393</span><a name="line.393"></a>
+<span class="sourceLineNo">394</span>      // Load 100 rows for each hfile range in cluster '0' for table CF 'f'<a name="line.394"></a>
+<span class="sourceLineNo">395</span>      byte[][][] hfileRanges =<a name="line.395"></a>
+<span class="sourceLineNo">396</span>          new byte[][][] { new byte[][] { Bytes.toBytes("aaaa"), Bytes.toBytes("cccc") },<a name="line.396"></a>
+<span class="sourceLineNo">397</span>              new byte[][] { Bytes.toBytes("ddd"), Bytes.toBytes("fff") }, };<a name="line.397"></a>
+<span class="sourceLineNo">398</span>      int numOfRows = 100;<a name="line.398"></a>
+<span class="sourceLineNo">399</span>      int[] expectedCounts =<a name="line.399"></a>
+<span class="sourceLineNo">400</span>          new int[] { hfileRanges.length * numOfRows, hfileRanges.length * numOfRows };<a name="line.400"></a>
+<span class="sourceLineNo">401</span><a name="line.401"></a>
+<span class="sourceLineNo">402</span>      loadAndValidateHFileReplication("load_f", 0, new int[] { 1 }, row, famName, htables,<a name="line.402"></a>
+<span class="sourceLineNo">403</span>        hfileRanges, numOfRows, expectedCounts, true);<a name="line.403"></a>
 <span class="sourceLineNo">404</span><a name="line.404"></a>
-<span class="sourceLineNo">405</span>      loadAndValidateHFileReplication("load_f", 0, new int[] { 1 }, row, famName, htables,<a name="line.405"></a>
-<span class="sourceLineNo">406</span>        hfileRanges, numOfRows, expectedCounts, true);<a name="line.406"></a>
-<span class="sourceLineNo">407</span><a name="line.407"></a>
-<span class="sourceLineNo">408</span>      // Load 100 rows for each hfile range in cluster '0' for table CF 'f1'<a name="line.408"></a>
-<span class="sourceLineNo">409</span>      hfileRanges = new byte[][][] { new byte[][] { Bytes.toBytes("gggg"), Bytes.toBytes("iiii") },<a name="line.409"></a>
-<span class="sourceLineNo">410</span>          new byte[][] { Bytes.toBytes("jjj"), Bytes.toBytes("lll") }, };<a name="line.410"></a>
-<span class="sourceLineNo">411</span>      numOfRows = 100;<a name="line.411"></a>
+<span class="sourceLineNo">405</span>      // Load 100 rows for each hfile range in cluster '0' for table CF 'f1'<a name="line.405"></a>
+<span class="sourceLineNo">406</span>      hfileRanges = new byte[][][] { new byte[][] { Bytes.toBytes("gggg"), Bytes.toBytes("iiii") },<a name="line.406"></a>
+<span class="sourceLineNo">407</span>          new byte[][] { Bytes.toBytes("jjj"), Bytes.toBytes("lll") }, };<a name="line.407"></a>
+<span class="sourceLineNo">408</span>      numOfRows = 100;<a name="line.408"></a>
+<span class="sourceLineNo">409</span><a name="line.409"></a>
+<span class="sourceLineNo">410</span>      int[] newExpectedCounts =<a name="line.410"></a>
+<span class="sourceLineNo">411</span>          new int[] { hfileRanges.length * numOfRows + expectedCounts[0], expectedCounts[1] };<a name="line.411"></a>
 <span class="sourceLineNo">412</span><a name="line.412"></a>
-<span class="sourceLineNo">413</span>      int[] newExpectedCounts =<a name="line.413"></a>
-<span class="sourceLineNo">414</span>          new int[] { hfileRanges.length * numOfRows + expectedCounts[0], expectedCounts[1] };<a name="line.414"></a>
+<span class="sourceLineNo">413</span>      loadAndValidateHFileReplication("load_f1", 0, new int[] { 1 }, row, famName1, htables,<a name="line.413"></a>
+<span class="sourceLineNo">414</span>        hfileRanges, numOfRows, newExpectedCounts, false);<a name="line.414"></a>
 <span class="sourceLineNo">415</span><a name="line.415"></a>
-<span class="sourceLineNo">416</span>      loadAndValidateHFileReplication("load_f1", 0, new int[] { 1 }, row, famName1, htables,<a name="line.416"></a>
-<span class="sourceLineNo">417</span>        hfileRanges, numOfRows, newExpectedCounts, false);<a name="line.417"></a>
-<span class="sourceLineNo">418</span><a name="line.418"></a>
-<span class="sourceLineNo">419</span>      // Validate data replication for CF 'f1'<a name="line.419"></a>
+<span class="sourceLineNo">416</span>      // Validate data replication for CF 'f1'<a name="line.416"></a>
+<span class="sourceLineNo">417</span><a name="line.417"></a>
+<span class="sourceLineNo">418</span>      // Source cluster table should contain data for the families<a name="line.418"></a>
+<span class="sourceLineNo">419</span>      wait(0, htables[0], hfileRanges.length * numOfRows + expectedCounts[0]);<a name="line.419"></a>
 <span class="sourceLineNo">420</span><a name="line.420"></a>
-<span class="sourceLineNo">421</span>      // Source cluster table should contain data for the families<a name="line.421"></a>
-<span class="sourceLineNo">422</span>      wait(0, htables[0], hfileRanges.length * numOfRows + expectedCounts[0]);<a name="line.422"></a>
-<span class="sourceLineNo">423</span><a name="line.423"></a>
-<span class="sourceLineNo">424</span>      // Sleep for enough time so that the data is still not replicated for the CF which is not<a name="line.424"></a>
-<span class="sourceLineNo">425</span>      // configured for replication<a name="line.425"></a>
-<span class="sourceLineNo">426</span>      Thread.sleep((NB_RETRIES / 2) * SLEEP_TIME);<a name="line.426"></a>
-<span class="sourceLineNo">427</span>      // Peer cluster should have only configured CF data<a name="line.427"></a>
-<span class="sourceLineNo">428</span>      wait(1, htables[1], expectedCounts[1]);<a name="line.428"></a>
-<span class="sourceLineNo">429</span>    } finally {<a name="line.429"></a>
-<span class="sourceLineNo">430</span>      close(htables);<a name="line.430"></a>
-<span class="sourceLineNo">431</span>      shutDownMiniClusters();<a name="line.431"></a>
-<span class="sourceLineNo">432</span>    }<a name="line.432"></a>
-<span class="sourceLineNo">433</span>  }<a name="line.433"></a>
-<span class="sourceLineNo">434</span><a name="line.434"></a>
-<span class="sourceLineNo">435</span>  /**<a name="line.435"></a>
-<span class="sourceLineNo">436</span>   * Tests cyclic replication scenario of 0 -&gt; 1 -&gt; 2 -&gt; 1.<a name="line.436"></a>
-<span class="sourceLineNo">437</span>   */<a name="line.437"></a>
-<span class="sourceLineNo">438</span>  @Test(timeout = 300000)<a name="line.438"></a>
-<span class="sourceLineNo">439</span>  public void testCyclicReplication3() throws Exception {<a name="line.439"></a>
-<span class="sourceLineNo">440</span>    LOG.info("testCyclicReplication2");<a name="line.440"></a>
-<span class="sourceLineNo">441</span>    int numClusters = 3;<a name="line.441"></a>
-<span class="sourceLineNo">442</span>    Table[] htables = null;<a name="line.442"></a>
-<span class="sourceLineNo">443</span>    try {<a name="line.443"></a>
-<span class="sourceLineNo">444</span>      startMiniClusters(numClusters);<a name="line.444"></a>
-<span class="sourceLineNo">445</span>      createTableOnClusters(table);<a name="line.445"></a>
-<span class="sourceLineNo">446</span><a name="line.446"></a>
-<span class="sourceLineNo">447</span>      // Test the replication scenario of 0 -&gt; 1 -&gt; 2 -&gt; 1<a name="line.447"></a>
-<span class="sourceLineNo">448</span>      addPeer("1", 0, 1);<a name="line.448"></a>
-<span class="sourceLineNo">449</span>      addPeer("1", 1, 2);<a name="line.449"></a>
-<span class="sourceLineNo">450</span>      addPeer("1", 2, 1);<a name="line.450"></a>
-<span class="sourceLineNo">451</span><a name="line.451"></a>
-<span class="sourceLineNo">452</span>      htables = getHTablesOnClusters(tableName);<a name="line.452"></a>
-<span class="sourceLineNo">453</span><a name="line.453"></a>
-<span class="sourceLineNo">454</span>      // put "row" and wait 'til it got around<a name="line.454"></a>
-<span class="sourceLineNo">455</span>      putAndWait(row, famName, htables[0], htables[2]);<a name="line.455"></a>
-<span class="sourceLineNo">456</span>      putAndWait(row1, famName, htables[1], htables[2]);<a name="line.456"></a>
-<span class="sourceLineNo">457</span>      putAndWait(row2, famName, htables[2], htables[1]);<a name="line.457"></a>
-<span class="sourceLineNo">458</span><a name="line.458"></a>
-<span class="sourceLineNo">459</span>      deleteAndWait(row, htables[0], htables[2]);<a name="line.459"></a>
-<span class="sourceLineNo">460</span>      deleteAndWait(row1, htables[1], htables[2]);<a name="line.460"></a>
-<span class="sourceLineNo">461</span>      deleteAndWait(row2, htables[2], htables[1]);<a name="line.461"></a>
-<span class="sourceLineNo">462</span><a name="line.462"></a>
-<span class="sourceLineNo">463</span>      int[] expectedCounts = new int[] { 1, 3, 3 };<a name="line.463"></a>
-<span class="sourceLineNo">464</span>      validateCounts(htables, put, expectedCounts);<a name="line.464"></a>
-<span class="sourceLineNo">465</span>      validateCounts(htables, delete, expectedCounts);<a name="line.465"></a>
-<span class="sourceLineNo">466</span>    } finally {<a name="line.466"></a>
-<span class="sourceLineNo">467</span>      close(htables);<a name="line.467"></a>
-<span class="sourceLineNo">468</span>      shutDownMiniClusters();<a name="line.468"></a>
-<span class="sourceLineNo">469</span>    }<a name="line.469"></a>
-<span class="sourceLineNo">470</span>  }<a name="line.470"></a>
-<span class="sourceLineNo">471</span><a name="line.471"></a>
-<span class="sourceLineNo">472</span>  @After<a name="line.472"></a>
-<span class="sourceLineNo">473</span>  public void tearDown() throws IOException {<a name="line.473"></a>
-<span class="sourceLineNo">474</span>    configurations = null;<a name="line.474"></a>
-<span class="sourceLineNo">475</span>    utilities = null;<a name="line.475"></a>
-<span class="sourceLineNo">476</span>  }<a name="line.476"></a>
-<span class="sourceLineNo">477</span><a name="line.477"></a>
-<span class="sourceLineNo">478</span>  @SuppressWarnings("resource")<a name="line.478"></a>
-<span class="sourceLineNo">479</span>  private void startMiniClusters(int numClusters) throws Exception {<a name="line.479"></a>
-<span class="sourceLineNo">480</span>    Random random = new Random();<a name="line.480"></a>
-<span class="sourceLineNo">481</span>    utilities = new HBaseTestingUtility[numClusters];<a name="line.481"></a>
-<span class="sourceLineNo">482</span>    configurations = new Configuration[numClusters];<a name="line.482"></a>
-<span class="sourceLineNo">483</span>    for (int i = 0; i &lt; numClusters; i++) {<a name="line.483"></a>
-<span class="sourceLineNo">484</span>      Configuration conf = new Configuration(baseConfiguration);<a name="line.484"></a>
-<span class="sourceLineNo">485</span>      conf.set(HConstants.ZOOKEEPER_ZNODE_PARENT, "/" + i + random.nextInt());<a name="line.485"></a>
-<span class="sourceLineNo">486</span>      HBaseTestingUtility utility = new HBaseTestingUtility(conf);<a name="line.486"></a>
-<span class="sourceLineNo">487</span>      if (i == 0) {<a name="line.487"></a>
-<span class="sourceLineNo">488</span>        utility.startMiniZKCluster();<a name="line.488"></a>
-<span class="sourceLineNo">489</span>        miniZK = utility.getZkCluster();<a name="line.489"></a>
-<span class="sourceLineNo">490</span>      } else {<a name="line.490"></a>
-<span class="sourceLineNo">491</span>        utility.setZkCluster(miniZK);<a name="line.491"></a>
-<span class="sourceLineNo">492</span>      }<a name="line.492"></a>
-<span class="sourceLineNo">493</span>      utility.startMiniCluster();<a name="line.493"></a>
-<span class="sourceLineNo">494</span>      utilities[i] = utility;<a name="line.494"></a>
-<span class="sourceLineNo">495</span>      configurations[i] = conf;<a name="line.495"></a>
-<span class="sourceLineNo">496</span>      new ZKWatcher(conf, "cluster" + i, null, true);<a name="line.496"></a>
-<span class="sourceLineNo">497</span>    }<a name="line.497"></a>
-<span class="sourceLineNo">498</span>  }<a name="line.498"></a>
-<span class="sourceLineNo">499</span><a name="line.499"></a>
-<span class="sourceLineNo">500</span>  private void shutDownMiniClusters() throws Exception {<a name="line.500"></a>
-<span class="sourceLineNo">501</span>    int numClusters = utilities.length;<a name="line.501"></a>
-<span class="sourceLineNo">502</span>    for (int i = numClusters - 1; i &gt;= 0; i--) {<a name="line.502"></a>
-<span class="sourceLineNo">503</span>      if (utilities[i] != null) {<a name="line.503"></a>
-<span class="sourceLineNo">504</span>        utilities[i].shutdownMiniCluster();<a name="line.504"></a>
-<span class="sourceLineNo">505</span>      }<a name="line.505"></a>
-<span class="sourceLineNo">506</span>    }<a name="line.506"></a>
-<span class="sourceLineNo">507</span>    miniZK.shutdown();<a name="line.507"></a>
-<span class="sourceLineNo">508</span>  }<a name="line.508"></a>
-<span class="sourceLineNo">509</span><a name="line.509"></a>
-<span class="sourceLineNo">510</span>  private void createTableOnClusters(HTableDescriptor table) throws Exception {<a name="line.510"></a>
-<span class="sourceLineNo">511</span>    for (HBaseTestingUtility utility : utilities) {<a name="line.511"></a>
-<span class="sourceLineNo">512</span>      utility.getAdmin().createTable(table);<a name="line.512"></a>
-<span class="sourceLineNo">513</span>    }<a name="line.513"></a>
-<span class="sourceLineNo">514</span>  }<a name="line.514"></a>
-<span class="sourceLineNo">515</span><a name="line.515"></a>
-<span class="sourceLineNo">516</span>  private void addPeer(String id, int masterClusterNumber,<a name="line.516"></a>
-<span class="sourceLineNo">517</span>      int slaveClusterNumber) throws Exception {<a name="line.517"></a>
-<span class="sourceLineNo">518</span>    try (Admin admin = ConnectionFactory.createConnection(configurations[masterClusterNumber])<a name="line.518"></a>
-<span class="sourceLineNo">519</span>        .getAdmin()) {<a name="line.519"></a>
-<span class="sourceLineNo">520</span>      admin.addReplicationPeer(id,<a name="line.520"></a>
-<span class="sourceLineNo">521</span>        new ReplicationPeerConfig().setClusterKey(utilities[slaveClusterNumber].getClusterKey()));<a name="line.521"></a>
-<span class="sourceLineNo">522</span>    }<a name="line.522"></a>
-<span class="sourceLineNo">523</span>  }<a name="line.523"></a>
-<span class="sourceLineNo">524</span><a name="line.524"></a>
-<span class="sourceLineNo">525</span>  private void addPeer(String id, int masterClusterNumber, int slaveClusterNumber, String tableCfs)<a name="line.525"></a>
-<span class="sourceLineNo">526</span>      throws Exception {<a name="line.526"></a>
-<span class="sourceLineNo">527</span>    try (Admin admin =<a name="line.527"></a>
-<span class="sourceLineNo">528</span>        ConnectionFactory.createConnection(configurations[masterClusterNumber]).getAdmin()) {<a name="line.528"></a>
-<span class="sourceLineNo">529</span>      admin.addReplicationPeer(<a name="line.529"></a>
-<span class="sourceLineNo">530</span>        id,<a name="line.530"></a>
-<span class="sourceLineNo">531</span>        new ReplicationPeerConfig().setClusterKey(utilities[slaveClusterNumber].getClusterKey())<a name="line.531"></a>
-<span class="sourceLineNo">532</span>            .setReplicateAllUserTables(false)<a name="line.532"></a>
-<span class="sourceLineNo">533</span>            .setTableCFsMap(ReplicationPeerConfigUtil.parseTableCFsFromConfig(tableCfs)));<

<TRUNCATED>

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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/apache_hbase_reference_guide.pdf
----------------------------------------------------------------------
diff --git a/apache_hbase_reference_guide.pdf b/apache_hbase_reference_guide.pdf
index aec7aa8..7c00102 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:20171217144715+00'00')
-/CreationDate (D:20171217144715+00'00')
+/ModDate (D:20171218144716+00'00')
+/CreationDate (D:20171218144716+00'00')
 >>
 endobj
 2 0 obj
@@ -27974,7 +27974,7 @@ endobj
 endobj
 136 0 obj
 << /Limits [(__anchor-top) (adding.new.node)]
-/Names [(__anchor-top) 25 0 R (__indexterm-7345738) 3431 0 R (__indexterm-7347988) 3433 0 R (__indexterm-7350050) 3434 0 R (__indexterm-7351924) 3435 0 R (acid) 908 0 R (add-metric-name-and-function-to-hadoop-compat-interface) 3530 0 R (add-the-implementation-to-both-hadoop-1-and-hadoop-2-compat-modules) 3531 0 R (add.metrics) 3528 0 R (adding-a-new-chapter-to-the-hbase-reference-guide) 3772 0 R (adding.new.node) 3011 0 R]
+/Names [(__anchor-top) 25 0 R (__indexterm-7346126) 3431 0 R (__indexterm-7348376) 3433 0 R (__indexterm-7350438) 3434 0 R (__indexterm-7352312) 3435 0 R (acid) 908 0 R (add-metric-name-and-function-to-hadoop-compat-interface) 3530 0 R (add-the-implementation-to-both-hadoop-1-and-hadoop-2-compat-modules) 3531 0 R (add.metrics) 3528 0 R (adding-a-new-chapter-to-the-hbase-reference-guide) 3772 0 R (adding.new.node) 3011 0 R]
 >>
 endobj
 137 0 obj
@@ -28016,7 +28016,7 @@ endobj
 >>
 endobj
 141 0 obj
-<< /Length 39516
+<< /Length 39470
 >>
 stream
 q
@@ -28335,23 +28335,23 @@ f
 f
 0.0 0.0 0.0 scn
 1.0 1.0 1.0 scn
-48.24 443.85 99.76 34.56 re
+48.24 458.13 99.76 20.28 re
 f
 0.0 0.0 0.0 scn
 1.0 1.0 1.0 scn
-148.0 443.85 99.76 34.56 re
+148.0 458.13 99.76 20.28 re
 f
 0.0 0.0 0.0 scn
 1.0 1.0 1.0 scn
-247.76 443.85 99.76 34.56 re
+247.76 458.13 99.76 20.28 re
 f
 0.0 0.0 0.0 scn
 1.0 1.0 1.0 scn
-347.52 443.85 99.76 34.56 re
+347.52 458.13 99.76 20.28 re
 f
 0.0 0.0 0.0 scn
 1.0 1.0 1.0 scn
-447.28 443.85 99.76 34.56 re
+447.28 458.13 99.76 20.28 re
 f
 0.0 0.0 0.0 scn
 0.5 w
@@ -30637,20 +30637,20 @@ S
 [] 0 d
 0.5 w
 0.8667 0.8667 0.8667 SCN
-48.24 443.85 m
-148.0 443.85 l
+48.24 458.13 m
+148.0 458.13 l
 S
 [] 0 d
 0.5 w
 0.8667 0.8667 0.8667 SCN
 48.24 478.66 m
-48.24 443.6 l
+48.24 457.88 l
 S
 [] 0 d
 0.5 w
 0.8667 0.8667 0.8667 SCN
 148.0 478.66 m
-148.0 443.6 l
+148.0 457.88 l
 S
 [] 0 d
 1 w
@@ -30660,14 +30660,7 @@ S
 BT
 51.24 464.196 Td
 /F1.0 10.5 Tf
-<4861646f6f702d332e302e302d> Tj
-ET
-
-
-BT
-51.24 449.916 Td
-/F1.0 10.5 Tf
-<616c70686178> Tj
+<4861646f6f702d332e302e30> Tj
 ET
 
 0.0 0.0 0.0 scn
@@ -30679,20 +30672,20 @@ S
 [] 0 d
 0.5 w
 0.8667 0.8667 0.8667 SCN
-148.0 443.85 m
-247.76 443.85 l
+148.0 458.13 m
+247.76 458.13 l
 S
 [] 0 d
 0.5 w
 0.8667 0.8667 0.8667 SCN
 148.0 478.66 m
-148.0 443.6 l
+148.0 457.88 l
 S
 [] 0 d
 0.5 w
 0.8667 0.8667 0.8667 SCN
 247.76 478.66 m
-247.76 443.6 l
+247.76 457.88 l
 S
 [] 0 d
 1 w
@@ -30714,20 +30707,20 @@ S
 [] 0 d
 0.5 w
 0.8667 0.8667 0.8667 SCN
-247.76 443.85 m
-347.52 443.85 l
+247.76 458.13 m
+347.52 458.13 l
 S
 [] 0 d
 0.5 w
 0.8667 0.8667 0.8667 SCN
 247.76 478.66 m
-247.76 443.6 l
+247.76 457.88 l
 S
 [] 0 d
 0.5 w
 0.8667 0.8667 0.8667 SCN
 347.52 478.66 m
-347.52 443.6 l
+347.52 457.88 l
 S
 [] 0 d
 1 w
@@ -30749,20 +30742,20 @@ S
 [] 0 d
 0.5 w
 0.8667 0.8667 0.8667 SCN
-347.52 443.85 m
-447.28 443.85 l
+347.52 458.13 m
+447.28 458.13 l
 S
 [] 0 d
 0.5 w
 0.8667 0.8667 0.8667 SCN
 347.52 478.66 m
-347.52 443.6 l
+347.52 457.88 l
 S
 [] 0 d
 0.5 w
 0.8667 0.8667 0.8667 SCN
 447.28 478.66 m
-447.28 443.6 l
+447.28 457.88 l
 S
 [] 0 d
 1 w
@@ -30784,20 +30777,20 @@ S
 [] 0 d
 0.5 w
 0.8667 0.8667 0.8667 SCN
-447.28 443.85 m
-547.04 443.85 l
+447.28 458.13 m
+547.04 458.13 l
 S
 [] 0 d
 0.5 w
 0.8667 0.8667 0.8667 SCN
 447.28 478.66 m
-447.28 443.6 l
+447.28 457.88 l
 S
 [] 0 d
 0.5 w
 0.8667 0.8667 0.8667 SCN
 547.04 478.66 m
-547.04 443.6 l
+547.04 457.88 l
 S
 [] 0 d
 1 w
@@ -30814,15 +30807,15 @@ ET
 q
 0.5 w
 0.9333 0.9333 0.9333 SCN
-108.24 431.85 m
-108.24 341.739 l
+108.24 446.13 m
+108.24 356.019 l
 S
 Q
 0.0667 0.0667 0.0667 scn
 0.0667 0.0667 0.0667 SCN
 
 BT
-71.388 378.2265 Td
+71.388 392.5065 Td
 /F5.1 24 Tf
 <22> Tj
 ET
@@ -30833,7 +30826,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-120.24 416.4842 Td
+120.24 430.7642 Td
 /F3.0 9.975 Tf
 [<4861646f6f70205072652d322e362e3120616e64204a444b20312e38204b> 20.0195 <65726265726f73>] TJ
 ET
@@ -30846,7 +30839,7 @@ ET
 1.9222 Tw
 
 BT
-120.24 396.895 Td
+120.24 411.175 Td
 /F1.0 10.5 Tf
 [<5768656e207573696e67207072652d322e362e31204861646f6f702076657273696f6e7320616e64204a444b20312e3820696e2061204b> 20.0195 <65726265726f7320656e7669726f6e6d656e742c>] TJ
 ET
@@ -30861,7 +30854,7 @@ ET
 0.3197 Tw
 
 BT
-120.24 381.115 Td
+120.24 395.395 Td
 /F1.0 10.5 Tf
 [<4842617365207365727665722063616e206661696c20616e642061626f72742064756520746f204b> 20.0195 <65726265726f73206b> 20.0195 <65797461622072656c6f67696e206572726f722e204c6174652076657273696f6e>] TJ
 ET
@@ -30876,7 +30869,7 @@ ET
 1.4593 Tw
 
 BT
-120.24 365.335 Td
+120.24 379.615 Td
 /F1.0 10.5 Tf
 <6f66204a444b20312e372028312e372e305f38302920686173207468652070726f626c656d20746f6f2e20526566657220746f20> Tj
 ET
@@ -30891,7 +30884,7 @@ ET
 1.4593 Tw
 
 BT
-382.7694 365.335 Td
+382.7694 379.615 Td
 /F1.0 10.5 Tf
 <4841444f4f502d3130373836> Tj
 ET
@@ -30906,7 +30899,7 @@ ET
 1.4593 Tw
 
 BT
-460.6479 365.335 Td
+460.6479 379.615 Td
 /F1.0 10.5 Tf
 <20666f72206164646974696f6e616c> Tj
 ET
@@ -30919,7 +30912,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-120.24 349.555 Td
+120.24 363.835 Td
 /F1.0 10.5 Tf
 [<64657461696c732e20436f6e73696465722075706772> 20.0195 <6164696e6720746f204861646f6f7020322e362e312b20696e207468697320636173652e>] TJ
 ET
@@ -30929,15 +30922,15 @@ ET
 q
 0.5 w
 0.9333 0.9333 0.9333 SCN
-108.24 329.739 m
-108.24 239.628 l
+108.24 344.019 m
+108.24 253.908 l
 S
 Q
 0.0667 0.0667 0.0667 scn
 0.0667 0.0667 0.0667 SCN
 
 BT
-71.388 276.1155 Td
+71.388 290.3955 Td
 /F5.1 24 Tf
 <22> Tj
 ET
@@ -30948,7 +30941,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-120.24 314.3732 Td
+120.24 328.6532 Td
 /F3.0 9.975 Tf
 <4861646f6f7020322e362e78> Tj
 ET
@@ -30961,7 +30954,7 @@ ET
 0.7271 Tw
 
 BT
-120.24 294.784 Td
+120.24 309.064 Td
 /F1.0 10.5 Tf
 <4861646f6f7020646973747269627574696f6e73206261736564206f6e2074686520322e362e78206c696e6520> Tj
 ET
@@ -30976,7 +30969,7 @@ ET
 0.7271 Tw
 
 BT
-347.7725 294.784 Td
+347.7725 309.064 Td
 /F2.0 10.5 Tf
 <6d757374> Tj
 ET
@@ -30991,7 +30984,7 @@ ET
 0.7271 Tw
 
 BT
-374.4635 294.784 Td
+374.4635 309.064 Td
 /F1.0 10.5 Tf
 <206861766520> Tj
 ET
@@ -31006,7 +30999,7 @@ ET
 0.7271 Tw
 
 BT
-405.6117 294.784 Td
+405.6117 309.064 Td
 /F1.0 10.5 Tf
 <4841444f4f502d3131373130> Tj
 ET
@@ -31021,7 +31014,7 @@ ET
 0.7271 Tw
 
 BT
-483.4902 294.784 Td
+483.4902 309.064 Td
 /F1.0 10.5 Tf
 <206170706c696564206966> Tj
 ET
@@ -31036,7 +31029,7 @@ ET
 1.3058 Tw
 
 BT
-120.24 279.004 Td
+120.24 293.284 Td
 /F1.0 10.5 Tf
 [<796f7520706c616e20746f2072756e204842617365206f6e20746f70206f6620616e204844465320456e6372797074696f6e205a6f6e652e2046> 40.0391 <61696c75726520746f20646f20736f2077696c6c>] TJ
 ET
@@ -31051,7 +31044,7 @@ ET
 2.2193 Tw
 
 BT
-120.24 263.224 Td
+120.24 277.504 Td
 /F1.0 10.5 Tf
 <726573756c7420696e20636c7573746572206661696c75726520616e642064617461206c6f73732e20546869732070617463682069732070726573656e7420696e20417061636865204861646f6f70> Tj
 ET
@@ -31064,7 +31057,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-120.24 247.444 Td
+120.24 261.724 Td
 /F1.0 10.5 Tf
 <72656c656173657320322e362e312b2e> Tj
 ET
@@ -31074,15 +31067,15 @@ ET
 q
 0.5 w
 0.9333 0.9333 0.9333 SCN
-108.24 227.628 m
-108.24 153.297 l
+108.24 241.908 m
+108.24 167.577 l
 S
 Q
 0.0667 0.0667 0.0667 scn
 0.0667 0.0667 0.0667 SCN
 
 BT
-71.388 181.8945 Td
+71.388 196.1745 Td
 /F5.1 24 Tf
 <22> Tj
 ET
@@ -31093,7 +31086,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-120.24 212.2622 Td
+120.24 226.5422 Td
 /F3.0 9.975 Tf
 <4861646f6f7020322e372e78> Tj
 ET
@@ -31106,7 +31099,7 @@ ET
 0.8883 Tw
 
 BT
-120.24 192.673 Td
+120.24 206.953 Td
 /F1.0 10.5 Tf
 <4861646f6f702076657273696f6e20322e372e30206973206e6f7420746573746564206f7220737570706f7274656420617320746865204861646f6f7020504d4320686173206578706c696369746c79> Tj
 ET
@@ -31121,7 +31114,7 @@ ET
 1.3514 Tw
 
 BT
-120.24 176.893 Td
+120.24 191.173 Td
 /F1.0 10.5 Tf
 <6c6162656c656420746861742072656c65617365206173206e6f74206265696e6720737461626c652e20287265666572656e63652074686520> Tj
 ET
@@ -31136,7 +31129,7 @@ ET
 1.3514 Tw
 
 BT
-404.0692 176.893 Td
+404.0692 191.173 Td
 /F1.0 10.5 Tf
 <616e6e6f756e63656d656e74206f6620417061636865> Tj
 ET
@@ -31149,7 +31142,7 @@ ET
 0.2588 0.5451 0.7922 SCN
 
 BT
-120.24 161.113 Td
+120.24 175.393 Td
 /F1.0 10.5 Tf
 <4861646f6f7020322e372e30> Tj
 ET
@@ -31160,7 +31153,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-185.025 161.113 Td
+185.025 175.393 Td
 /F1.0 10.5 Tf
 <2e29> Tj
 ET
@@ -31170,15 +31163,15 @@ ET
 q
 0.5 w
 0.9333 0.9333 0.9333 SCN
-108.24 141.297 m
-108.24 66.966 l
+108.24 155.577 m
+108.24 81.246 l
 S
 Q
 0.0667 0.0667 0.0667 scn
 0.0667 0.0667 0.0667 SCN
 
 BT
-71.388 95.5635 Td
+71.388 109.8435 Td
 /F5.1 24 Tf
 <22> Tj
 ET
@@ -31189,7 +31182,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-120.24 125.9312 Td
+120.24 140.2112 Td
 /F3.0 9.975 Tf
 <4861646f6f7020322e382e78> Tj
 ET
@@ -31202,7 +31195,7 @@ ET
 0.3283 Tw
 
 BT
-120.24 106.342 Td
+120.24 120.622 Td
 /F1.0 10.5 Tf
 <4861646f6f702076657273696f6e20322e382e3020616e6420322e382e3120617265206e6f7420746573746564206f7220737570706f7274656420617320746865204861646f6f7020504d4320686173> Tj
 ET
@@ -31217,7 +31210,7 @@ ET
 0.1086 Tw
 
 BT
-120.24 90.562 Td
+120.24 104.842 Td
 /F1.0 10.5 Tf
 <6578706c696369746c79206c6162656c656420746861742072656c6561736573206173206e6f74206265696e6720737461626c652e20287265666572656e63652074686520> Tj
 ET
@@ -31232,7 +31225,7 @@ ET
 0.1086 Tw
 
 BT
-446.5634 90.562 Td
+446.5634 104.842 Td
 /F1.0 10.5 Tf
 <616e6e6f756e63656d656e74206f66> Tj
 ET
@@ -31245,7 +31238,7 @@ ET
 0.2588 0.5451 0.7922 SCN
 
 BT
-120.24 74.782 Td
+120.24 89.062 Td
 /F1.0 10.5 Tf
 <417061636865204861646f6f7020322e382e30> Tj
 ET
@@ -31256,7 +31249,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-224.925 74.782 Td
+224.925 89.062 Td
 /F1.0 10.5 Tf
 <20616e6420> Tj
 ET
@@ -31267,7 +31260,7 @@ ET
 0.2588 0.5451 0.7922 SCN
 
 BT
-249.474 74.782 Td
+249.474 89.062 Td
 /F1.0 10.5 Tf
 <616e6e6f756e63656d656e74206f6620417061636865204861646f6f7020322e382e31> Tj
 ET
@@ -31278,7 +31271,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-445.2465 74.782 Td
+445.2465 89.062 Td
 /F1.0 10.5 Tf
 <2e29> Tj
 ET
@@ -31337,7 +31330,7 @@ endobj
 /URI (https://issues.apache.org/jira/browse/HADOOP-10786)
 >>
 /Subtype /Link
-/Rect [382.7694 362.269 460.6479 376.549]
+/Rect [382.7694 376.549 460.6479 390.829]
 /Type /Annot
 >>
 endobj
@@ -31348,7 +31341,7 @@ endobj
 /URI (https://issues.apache.org/jira/browse/HADOOP-11710)
 >>
 /Subtype /Link
-/Rect [405.6117 291.718 483.4902 305.998]
+/Rect [405.6117 305.998 483.4902 320.278]
 /Type /Annot
 >>
 endobj
@@ -31359,7 +31352,7 @@ endobj
 /URI (https://s.apache.org/hadoop-2.7.0-announcement)
 >>
 /Subtype /Link
-/Rect [404.0692 173.827 535.04 188.107]
+/Rect [404.0692 188.107 535.04 202.387]
 /Type /Annot
 >>
 endobj
@@ -31370,7 +31363,7 @@ endobj
 /URI (https://s.apache.org/hadoop-2.7.0-announcement)
 >>
 /Subtype /Link
-/Rect [120.24 158.047 185.025 172.327]
+/Rect [120.24 172.327 185.025 186.607]
 /Type /Annot
 >>
 endobj
@@ -31381,7 +31374,7 @@ endobj
 /URI (https://s.apache.org/hadoop-2.8.0-announcement)
 >>
 /Subtype /Link
-/Rect [446.5634 87.496 535.04 101.776]
+/Rect [446.5634 101.776 535.04 116.056]
 /Type /Annot
 >>
 endobj
@@ -31392,7 +31385,7 @@ endobj
 /URI (https://s.apache.org/hadoop-2.8.0-announcement)
 >>
 /Subtype /Link
-/Rect [120.24 71.716 224.925 85.996]
+/Rect [120.24 85.996 224.925 100.276]
 /Type /Annot
 >>
 endobj
@@ -31403,7 +31396,7 @@ endobj
 /URI (https://s.apache.org/hadoop-2.8.1-announcement)
 >>
 /Subtype /Link
-/Rect [249.474 71.716 445.2465 85.996]
+/Rect [249.474 85.996 445.2465 100.276]
 /Type /Annot
 >>
 endobj
@@ -641959,7 +641952,7 @@ endobj
 [3327 0 R /XYZ 0 152.519 null]
 endobj
 3338 0 obj
-<< /Length 12162
+<< /Length 11796
 >>
 stream
 q
@@ -642374,21 +642367,40 @@ ET
 0.2 0.2 0.2 scn
 0.2 0.2 0.2 SCN
 
+2.748 Tw
+
 BT
 48.24 330.386 Td
 /F1.0 10.5 Tf
-[<54> 29.7852 <6f207069636b206120706172746963756c6172204861646f6f7020332e792072656c656173652c20796f75d5642073657420652e672e20>] TJ
+[<54> 29.7852 <6f207069636b206120706172746963756c6172204861646f6f7020332e792072656c656173652c20796f75d56420736574206861646f6f702d74687265652e76657273696f6e2070726f706572747920652e672e20>] TJ
+ET
+
+
+0.0 Tw
+0.0 0.0 0.0 SCN
+0.0 0.0 0.0 scn
+0.6941 0.1294 0.2745 scn
+0.6941 0.1294 0.2745 SCN
+
+2.748 Tw
+
+BT
+505.04 330.386 Td
+/F4.0 10.5 Tf
+<2d446861646f6f70> Tj
 ET
 
+
+0.0 Tw
 0.0 0.0 0.0 SCN
 0.0 0.0 0.0 scn
 0.6941 0.1294 0.2745 scn
 0.6941 0.1294 0.2745 SCN
 
 BT
-315.0473 330.386 Td
+48.24 314.606 Td
 /F4.0 10.5 Tf
-<2d446861646f6f702d74687265652e76657273696f6e3d332e302e302d616c70686131> Tj
+<2d74687265652e76657273696f6e3d332e302e30> Tj
 ET
 
 0.0 0.0 0.0 SCN
@@ -642397,7 +642409,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-498.7973 330.386 Td
+153.24 314.606 Td
 /F1.0 10.5 Tf
 <2e> Tj
 ET
@@ -642408,7 +642420,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-48.24 295.886 Td
+48.24 280.106 Td
 /F2.0 13 Tf
 <3136312e312e342e204275696c642050726f746f627566> Tj
 ET
@@ -642421,7 +642433,7 @@ ET
 0.5604 Tw
 
 BT
-48.24 269.326 Td
+48.24 253.546 Td
 /F1.0 10.5 Tf
 [<59> 69.8242 <6f75206d61> 20.0195 <79206e65656420746f206368616e6765207468652070726f746f62756620646566696e6974696f6e7320746861742072657369646520696e2074686520>] TJ
 ET
@@ -642436,7 +642448,7 @@ ET
 0.5604 Tw
 
 BT
-388.5202 269.326 Td
+388.5202 253.546 Td
 /F3.0 10.5 Tf
 <68626173652d70726f746f636f6c> Tj
 ET
@@ -642451,7 +642463,7 @@ ET
 0.5604 Tw
 
 BT
-461.2852 269.326 Td
+461.2852 253.546 Td
 /F1.0 10.5 Tf
 <206d6f64756c65206f72206f74686572> Tj
 ET
@@ -642464,7 +642476,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-48.24 253.546 Td
+48.24 237.766 Td
 /F1.0 10.5 Tf
 <6d6f64756c65732e> Tj
 ET
@@ -642477,7 +642489,7 @@ ET
 0.7703 Tw
 
 BT
-48.24 225.766 Td
+48.24 209.986 Td
 /F1.0 10.5 Tf
 <50726576696f757320746f2068626173652d322e302e302c2070726f746f62756620646566696e6974696f6e2066696c6573207765726520737072696e6b6c6564206163726f737320616c6c206862617365206d6f64756c657320627574206e6f77> Tj
 ET
@@ -642492,7 +642504,7 @@ ET
 1.8826 Tw
 
 BT
-48.24 209.986 Td
+48.24 194.206 Td
 /F1.0 10.5 Tf
 <616c6c20746f20646f20776974682070726f746f627566206d7573742072657369646520696e207468652068626173652d70726f746f636f6c206d6f64756c653b2077652061726520747279696e6720746f20636f6e7461696e206f7572> Tj
 ET
@@ -642507,7 +642519,7 @@ ET
 1.4076 Tw
 
 BT
-48.24 194.206 Td
+48.24 178.426 Td
 /F1.0 10.5 Tf
 [<70726f746f6275662075736520736f2077652063616e20667265656c79206368616e67652076657273696f6e7320776974686f757420757073657474696e6720616e> 20.0195 <7920646f776e73747265616d2070726f6a65637420757365206f66>] TJ
 ET
@@ -642520,7 +642532,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-48.24 178.426 Td
+48.24 162.646 Td
 /F1.0 10.5 Tf
 <70726f746f6275662e> Tj
 ET
@@ -642533,7 +642545,7 @@ ET
 1.4366 Tw
 
 BT
-48.24 150.646 Td
+48.24 134.866 Td
 /F1.0 10.5 Tf
 <5468652070726f746f6275662066696c657320617265206c6f636174656420696e20> Tj
 ET
@@ -642548,7 +642560,7 @@ ET
 1.4366 Tw
 
 BT
-219.5885 150.646 Td
+219.5885 134.866 Td
 /F3.0 10.5 Tf
 <68626173652d70726f746f636f6c2f7372632f6d61696e2f70726f746f627566> Tj
 ET
@@ -642563,7 +642575,7 @@ ET
 1.4366 Tw
 
 BT
-383.651 150.646 Td
+383.651 134.866 Td
 /F1.0 10.5 Tf
 [<2e2046> 40.0391 <6f7220746865206368616e676520746f206265206566666563746976652c>] TJ
 ET
@@ -642576,7 +642588,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-48.24 134.866 Td
+48.24 119.086 Td
 /F1.0 10.5 Tf
 [<796f752077696c6c206e65656420746f20726567656e6572> 20.0195 <6174652074686520636c61737365732e2059> 69.8242 <6f752063616e20757365206d6176656e2070726f66696c6520>] TJ
 ET
@@ -642587,7 +642599,7 @@ ET
 0.6941 0.1294 0.2745 SCN
 
 BT
-380.7346 134.866 Td
+380.7346 119.086 Td
 /F4.0 10.5 Tf
 <636f6d70696c652d70726f746f627566> Tj
 ET
@@ -642598,7 +642610,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-464.7346 134.866 Td
+464.7346 119.086 Td
 /F1.0 10.5 Tf
 <20746f20646f20746869732e> Tj
 ET
@@ -642607,28 +642619,28 @@ ET
 0.0 0.0 0.0 scn
 q
 0.9608 0.9608 0.9608 scn
-52.24 119.05 m
-543.04 119.05 l
-545.2491 119.05 547.04 117.2591 547.04 115.05 c
-547.04 86.31 l
-547.04 84.1009 545.2491 82.31 543.04 82.31 c
-52.24 82.31 l
-50.0309 82.31 48.24 84.1009 48.24 86.31 c
-48.24 115.05 l
-48.24 117.2591 50.0309 119.05 52.24 119.05 c
+52.24 103.27 m
+543.04 103.27 l
+545.2491 103.27 547.04 101.4791 547.04 99.27 c
+547.04 70.53 l
+547.04 68.3209 545.2491 66.53 543.04 66.53 c
+52.24 66.53 l
+50.0309 66.53 48.24 68.3209 48.24 70.53 c
+48.24 99.27 l
+48.24 101.4791 50.0309 103.27 52.24 103.27 c
 h
 f
 0.8 0.8 0.8 SCN
 0.75 w
-52.24 119.05 m
-543.04 119.05 l
-545.2491 119.05 547.04 117.2591 547.04 115.05 c
-547.04 86.31 l
-547.04 84.1009 545.2491 82.31 543.04 82.31 c
-52.24 82.31 l
-50.0309 82.31 48.24 84.1009 48.24 86.31 c
-48.24 115.05 l
-48.24 117.2591 50.0309 119.05 52.24 119.05 c
+52.24 103.27 m
+543.04 103.27 l
+545.2491 103.27 547.04 101.4791 547.04 99.27 c
+547.04 70.53 l
+547.04 68.3209 545.2491 66.53 543.04 66.53 c
+52.24 66.53 l
+50.0309 66.53 48.24 68.3209 48.24 70.53 c
+48.24 99.27 l
+48.24 101.4791 50.0309 103.27 52.24 103.27 c
 h
 S
 Q
@@ -642636,46 +642648,13 @@ Q
 0.2 0.2 0.2 SCN
 
 BT
-59.24 96.225 Td
+59.24 80.445 Td
 /F4.0 11 Tf
 <6d766e20636f6d70696c65202d50636f6d70696c652d70726f746f627566> Tj
 ET
 
 0.0 0.0 0.0 SCN
 0.0 0.0 0.0 scn
-0.2 0.2 0.2 scn
-0.2 0.2 0.2 SCN
-
-BT
-48.24 58.346 Td
-/F1.0 10.5 Tf
-[<59> 69.8242 <6f75206d61> 20.0195 <7920616c736f2077616e7420746f20646566696e6520>] TJ
-ET
-
-0.0 0.0 0.0 SCN
-0.0 0.0 0.0 scn
-0.6941 0.1294 0.2745 scn
-0.6941 0.1294 0.2745 SCN
-
-BT
-191.4091 58.346 Td
-/F4.0 10.5 Tf
-<70726f746f632e70617468> Tj
-ET
-
-0.0 0.0 0.0 SCN
-0.0 0.0 0.0 scn
-0.2 0.2 0.2 scn
-0.2 0.2 0.2 SCN
-
-BT
-249.1591 58.346 Td
-/F1.0 10.5 Tf
-[<20666f72207468652070726f746f632062696e617279> 89.8438 <2c207573696e672074686520666f6c6c6f77696e6720636f6d6d616e643a>] TJ
-ET
-
-0.0 0.0 0.0 SCN
-0.0 0.0 0.0 scn
 q
 0.0 0.0 0.0 scn
 0.0 0.0 0.0 SCN
@@ -642744,49 +642723,80 @@ endobj
 [3339 0 R /XYZ 0 647.35 null]
 endobj
 3344 0 obj
-[3339 0 R /XYZ 0 314.57 null]
+[3339 0 R /XYZ 0 298.79 null]
 endobj
 3345 0 obj
-<< /Length 11267
+<< /Length 11785
 >>
 stream
 q
-q
 /DeviceRGB cs
+0.2 0.2 0.2 scn
+/DeviceRGB CS
+0.2 0.2 0.2 SCN
+
+BT
+48.24 794.676 Td
+/F1.0 10.5 Tf
+[<59> 69.8242 <6f75206d61> 20.0195 <7920616c736f2077616e7420746f20646566696e6520>] TJ
+ET
+
+0.0 0.0 0.0 SCN
+0.0 0.0 0.0 scn
+0.6941 0.1294 0.2745 scn
+0.6941 0.1294 0.2745 SCN
+
+BT
+191.4091 794.676 Td
+/F4.0 10.5 Tf
+<70726f746f632e70617468> Tj
+ET
+
+0.0 0.0 0.0 SCN
+0.0 0.0 0.0 scn
+0.2 0.2 0.2 scn
+0.2 0.2 0.2 SCN
+
+BT
+249.1591 794.676 Td
+/F1.0 10.5 Tf
+[<20666f72207468652070726f746f632062696e617279> 89.8438 <2c207573696e672074686520666f6c6c6f77696e6720636f6d6d616e643a>] TJ
+ET
+
+0.0 0.0 0.0 SCN
+0.0 0.0 0.0 scn
+q
 0.9608 0.9608 0.9608 scn
-52.24 805.89 m
-543.04 805.89 l
-545.2491 805.89 547.04 804.0991 547.04 801.89 c
-547.04 773.15 l
-547.04 770.9409 545.2491 769.15 543.04 769.15 c
-52.24 769.15 l
-50.0309 769.15 48.24 770.9409 48.24 773.15 c
-48.24 801.89 l
-48.24 804.0991 50.0309 805.89 52.24 805.89 c
+52.24 778.86 m
+543.04 778.86 l
+545.2491 778.86 547.04 777.0691 547.04 774.86 c
+547.04 746.12 l
+547.04 743.9109 545.2491 742.12 543.04 742.12 c
+52.24 742.12 l
+50.0309 742.12 48.24 743.9109 48.24 746.12 c
+48.24 774.86 l
+48.24 777.0691 50.0309 778.86 52.24 778.86 c
 h
 f
-/DeviceRGB CS
 0.8 0.8 0.8 SCN
 0.75 w
-52.24 805.89 m
-543.04 805.89 l
-545.2491 805.89 547.04 804.0991 547.04 801.89 c
-547.04 773.15 l
-547.04 770.9409 545.2491 769.15 543.04 769.15 c
-52.24 769.15 l
-50.0309 769.15 48.24 770.9409 48.24 773.15 c
-48.24 801.89 l
-48.24 804.0991 50.0309 805.89 52.24 805.89 c
+52.24 778.86 m
+543.04 778.86 l
+545.2491 778.86 547.04 777.0691 547.04 774.86 c
+547.04 746.12 l
+547.04 743.9109 545.2491 742.12 543.04 742.12 c
+52.24 742.12 l
+50.0309 742.12 48.24 743.9109 48.24 746.12 c
+48.24 774.86 l
+48.24 777.0691 50.0309 778.86 52.24 778.86 c
 h
 S
 Q
-/DeviceRGB cs
 0.2 0.2 0.2 scn
-/DeviceRGB CS
 0.2 0.2 0.2 SCN
 
 BT
-59.24 783.065 Td
+59.24 756.035 Td
 /F4.0 11 Tf
 <6d766e20636f6d70696c65202d50636f6d70696c652d70726f746f627566202d4470726f746f632e706174683d2f6f70742f6c6f63616c2f62696e2f70726f746f63> Tj
 ET
@@ -642797,7 +642807,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-48.24 745.186 Td
+48.24 718.156 Td
 /F1.0 10.5 Tf
 <526561642074686520> Tj
 ET
@@ -642808,7 +642818,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-94.482 745.186 Td
+94.482 718.156 Td
 /F3.0 10.5 Tf
 <68626173652d70726f746f636f6c2f524541444d452e747874> Tj
 ET
@@ -642819,7 +642829,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-231.255 745.186 Td
+231.255 718.156 Td
 /F1.0 10.5 Tf
 <20666f72206d6f72652064657461696c732e> Tj
 ET
@@ -642830,7 +642840,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-48.24 710.686 Td
+48.24 683.656 Td
 /F2.0 13 Tf
 <3136312e312e352e204275696c6420546872696674> Tj
 ET
@@ -642843,7 +642853,7 @@ ET
 2.8074 Tw
 
 BT
-48.24 684.126 Td
+48.24 657.096 Td
 /F1.0 10.5 Tf
 [<59> 69.8242 <6f75206d61> 20.0195 <79206e65656420746f206368616e6765207468652074687269667420646566696e6974696f6e7320746861742072657369646520696e2074686520>] TJ
 ET
@@ -642858,7 +642868,7 @@ ET
 2.8074 Tw
 
 BT
-397.5397 684.126 Td
+397.5397 657.096 Td
 /F3.0 10.5 Tf
 <68626173652d746872696674> Tj
 ET
@@ -642873,7 +642883,7 @@ ET
 2.8074 Tw
 
 BT
-454.5442 684.126 Td
+454.5442 657.096 Td
 /F1.0 10.5 Tf
 <206d6f64756c65206f72206f74686572> Tj
 ET
@@ -642886,7 +642896,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-48.24 668.346 Td
+48.24 641.316 Td
 /F1.0 10.5 Tf
 <6d6f64756c65732e> Tj
 ET
@@ -642899,7 +642909,7 @@ ET
 0.2189 Tw
 
 BT
-48.24 640.566 Td
+48.24 613.536 Td
 /F1.0 10.5 Tf
 <546865207468726966742066696c657320617265206c6f636174656420696e20> Tj
 ET
@@ -642914,7 +642924,7 @@ ET
 0.2189 Tw
 
 BT
-194.3376 640.566 Td
+194.3376 613.536 Td
 /F3.0 10.5 Tf
 <68626173652d7468726966742f7372632f6d61696e2f7265736f7572636573> Tj
 ET
@@ -642929,7 +642939,7 @@ ET
 0.2189 Tw
 
 BT
-347.5431 640.566 Td
+347.5431 613.536 Td
 /F1.0 10.5 Tf
 [<2e2046> 40.0391 <6f7220746865206368616e676520746f206265206566666563746976652c20796f752077696c6c>] TJ
 ET
@@ -642942,7 +642952,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-48.24 624.786 Td
+48.24 597.756 Td
 /F1.0 10.5 Tf
 [<6e65656420746f20726567656e6572> 20.0195 <6174652074686520636c61737365732e2059> 69.8242 <6f752063616e20757365206d6176656e2070726f66696c6520>] TJ
 ET
@@ -642953,7 +642963,7 @@ ET
 0.6941 0.1294 0.2745 SCN
 
 BT
-337.7581 624.786 Td
+337.7581 597.756 Td
 /F4.0 10.5 Tf
 <636f6d70696c652d746872696674> Tj
 ET
@@ -642964,7 +642974,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-411.2581 624.786 Td
+411.2581 597.756 Td
 /F1.0 10.5 Tf
 <20746f20646f20746869732e> Tj
 ET
@@ -642973,28 +642983,28 @@ ET
 0.0 0.0 0.0 scn
 q
 0.9608 0.9608 0.9608 scn
-52.24 608.97 m
-543.04 608.97 l
-545.2491 608.97 547.04 607.1791 547.04 604.97 c
-547.04 576.23 l
-547.04 574.0209 545.2491 572.23 543.04 572.23 c
-52.24 572.23 l
-50.0309 572.23 48.24 574.0209 48.24 576.23 c
-48.24 604.97 l
-48.24 607.1791 50.0309 608.97 52.24 608.97 c
+52.24 581.94 m
+543.04 581.94 l
+545.2491 581.94 547.04 580.1491 547.04 577.94 c
+547.04 549.2 l
+547.04 546.9909 545.2491 545.2 543.04 545.2 c
+52.24 545.2 l
+50.0309 545.2 48.24 546.9909 48.24 549.2 c
+48.24 577.94 l
+48.24 580.1491 50.0309 581.94 52.24 581.94 c
 h
 f
 0.8 0.8 0.8 SCN
 0.75 w
-52.24 608.97 m
-543.04 608.97 l
-545.2491 608.97 547.04 607.1791 547.04 604.97 c
-547.04 576.23 l
-547.04 574.0209 545.2491 572.23 543.04 572.23 c
-52.24 572.23 l
-50.0309 572.23 48.24 574.0209 48.24 576.23 c
-48.24 604.97 l
-48.24 607.1791 50.0309 608.97 52.24 608.97 c
+52.24 581.94 m
+543.04 581.94 l
+545.2491 581.94 547.04 580.1491 547.04 577.94 c
+547.04 549.2 l
+547.04 546.9909 545.2491 545.2 543.04 545.2 c
+52.24 545.2 l
+50.0309 545.2 48.24 546.9909 48.24 549.2 c
+48.24 577.94 l
+48.24 580.1491 50.0309 581.94 52.24 581.94 c
 h
 S
 Q
@@ -643002,7 +643012,7 @@ Q
 0.2 0.2 0.2 SCN
 
 BT
-59.24 586.145 Td
+59.24 559.115 Td
 /F4.0 11 Tf
 <6d766e20636f6d70696c65202d50636f6d70696c652d746872696674> Tj
 ET
@@ -643013,7 +643023,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-48.24 548.266 Td
+48.24 521.236 Td
 /F1.0 10.5 Tf
 [<59> 69.8242 <6f75206d61> 20.0195 <7920616c736f2077616e7420746f20646566696e6520>] TJ
 ET
@@ -643024,7 +643034,7 @@ ET
 0.6941 0.1294 0.2745 SCN
 
 BT
-191.4091 548.266 Td
+191.4091 521.236 Td
 /F4.0 10.5 Tf
 <7468726966742e70617468> Tj
 ET
@@ -643035,7 +643045,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-249.1591 548.266 Td
+249.1591 521.236 Td
 /F1.0 10.5 Tf
 [<20666f7220746865207468726966742062696e617279> 89.8438 <2c207573696e672074686520666f6c6c6f77696e6720636f6d6d616e643a>] TJ
 ET
@@ -643044,28 +643054,28 @@ ET
 0.0 0.0 0.0 scn
 q
 0.9608 0.9608 0.9608 scn
-52.24 532.45 m
-543.04 532.45 l
-545.2491 532.45 547.04 530.6591 547.04 528.45 c
-547.04 499.71 l
-547.04 497.5009 545.2491 495.71 543.04 495.71 c
-52.24 495.71 l
-50.0309 495.71 48.24 497.5009 48.24 499.71 c
-48.24 528.45 l
-48.24 530.6591 50.0309 532.45 52.24 532.45 c
+52.24 505.42 m
+543.04 505.42 l
+545.2491 505.42 547.04 503.6291 547.04 501.42 c
+547.04 472.68 l
+547.04 470.4709 545.2491 468.68 543.04 468.68 c
+52.24 468.68 l
+50.0309 468.68 48.24 470.4709 48.24 472.68 c
+48.24 501.42 l
+48.24 503.6291 50.0309 505.42 52.24 505.42 c
 h
 f
 0.8 0.8 0.8 SCN
 0.75 w
-52.24 532.45 m
-543.04 532.45 l
-545.2491 532.45 547.04 530.6591 547.04 528.45 c
-547.04 499.71 l
-547.04 497.5009 545.2491 495.71 543.04 495.71 c
-52.24 495.71 l
-50.0309 495.71 48.24 497.5009 48.24 499.71 c
-48.24 528.45 l
-48.24 530.6591 50.0309 532.45 52.24 532.45 c
+52.24 505.42 m
+543.04 505.42 l
+545.2491 505.42 547.04 503.6291 547.04 501.42 c
+547.04 472.68 l
+547.04 470.4709 545.2491 468.68 543.04 468.68 c
+52.24 468.68 l
+50.0309 468.68 48.24 470.4709 48.24 472.68 c
+48.24 501.42 l
+48.24 503.6291 50.0309 505.42 52.24 505.42 c
 h
 S
 Q
@@ -643073,7 +643083,7 @@ Q
 0.2 0.2 0.2 SCN
 
 BT
-59.24 509.625 Td
+59.24 482.595 Td
 /F4.0 11 Tf
 <ca20202020202020202020202020202020206d766e20636f6d70696c65202d50636f6d70696c652d746872696674202d447468726966742e706174683d2f6f70742f6c6f63616c2f62696e2f746872696674> Tj
 ET
@@ -643084,7 +643094,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-48.24 465.026 Td
+48.24 437.996 Td
 /F2.0 13 Tf
 [<3136312e312e362e204275696c6420612054> 29.7852 <617262616c6c>] TJ
 ET
@@ -643097,7 +643107,7 @@ ET
 3.0807 Tw
 
 BT
-48.24 438.466 Td
+48.24 411.436 Td
 /F1.0 10.5 Tf
 [<59> 69.8242 <6f752063616e206275696c6420612074617262616c6c20776974686f757420676f696e67207468726f756768207468652072656c656173652070726f636573732064657363726962656420696e20>] TJ
 ET
@@ -643112,7 +643122,7 @@ ET
 3.0807 Tw
 
 BT
-480.6235 438.466 Td
+480.6235 411.436 Td
 /F1.0 10.5 Tf
 <72656c656173696e67> Tj
 ET
@@ -643127,7 +643137,7 @@ ET
 3.0807 Tw
 
 BT
-526.4665 438.466 Td
+526.4665 411.436 Td
 /F1.0 10.5 Tf
 [<2c2062> 20.0195 <79>] TJ
 ET
@@ -643140,7 +643150,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-48.24 422.686 Td
+48.24 395.656 Td
 /F1.0 10.5 Tf
 <72756e6e696e672074686520666f6c6c6f77696e6720636f6d6d616e643a> Tj
 ET
@@ -643149,28 +643159,28 @@ ET
 0.0 0.0 0.0 scn
 q
 0.9608 0.9608 0.9608 scn
-52.24 406.87 m
-543.04 406.87 l
-545.2491 406.87 547.04 405.0791 547.04 402.87 c
-547.04 374.13 l
-547.04 371.9209 545.2491 370.13 543.04 370.13 c
-52.24 370.13 l
-50.0309 370.13 48.24 371.9209 48.24 374.13 c
-48.24 402.87 l
-48.24 405.0791 50.0309 406.87 52.24 406.87 c
+52.24 379.84 m
+543.04 379.84 l
+545.2491 379.84 547.04 378.0491 547.04 375.84 c
+547.04 347.1 l
+547.04 344.8909 545.2491 343.1 543.04 343.1 c
+52.24 343.1 l
+50.0309 343.1 48.24 344.8909 48.24 347.1 c
+48.24 375.84 l
+48.24 378.0491 50.0309 379.84 52.24 379.84 c
 h
 f
 0.8 0.8 0.8 SCN
 0.75 w
-52.24 406.87 m
-543.04 406.87 l
-545.2491 406.87 547.04 405.0791 547.04 402.87 c
-547.04 374.13 l
-547.04 371.9209 545.2491 370.13 543.04 370.13 c
-52.24 370.13 l
-50.0309 370.13 48.24 371.9209 48.24 374.13 c
-48.24 402.87 l
-48.24 405.0791 50.0309 406.87 52.24 406.87 c
+52.24 379.84 m
+543.04 379.84 l
+545.2491 379.84 547.04 378.0491 547.04 375.84 c
+547.04 347.1 l
+547.04 344.8909 545.2491 343.1 543.04 343.1 c
+52.24 343.1 l
+50.0309 343.1 48.24 344.8909 48.24 347.1 c
+48.24 375.84 l
+48.24 378.0491 50.0309 379.84 52.24 379.84 c
 h
 S
 Q
@@ -643178,7 +643188,7 @@ Q
 0.2 0.2 0.2 SCN
 
 BT
-59.24 384.045 Td
+59.24 357.015 Td
 /F4.0 11 Tf
 <6d766e202d44736b6970546573747320636c65616e20696e7374616c6c202626206d766e202d44736b69705465737473207061636b61676520617373656d626c793a73696e676c65> Tj
 ET
@@ -643189,7 +643199,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-48.24 346.166 Td
+48.24 319.136 Td
 /F1.0 10.5 Tf
 <54686520646973747269627574696f6e2074617262616c6c206973206275696c7420696e20> Tj
 ET
@@ -643200,7 +643210,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-217.731 346.166 Td
+217.731 319.136 Td
 /F3.0 10.5 Tf
 <68626173652d617373656d626c792f7461726765742f68626173652d3c76657273696f6e3e2d62696e2e7461722e677a> Tj
 ET
@@ -643211,7 +643221,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-459.4095 346.166 Td
+459.4095 319.136 Td
 /F1.0 10.5 Tf
 <2e> Tj
 ET
@@ -643224,7 +643234,7 @@ ET
 0.8509 Tw
 
 BT
-48.24 318.386 Td
+48.24 291.356 Td
 /F1.0 10.5 Tf
 [<59> 69.8242 <6f752063616e20696e7374616c6c206f72206465706c6f> 20.0195 <79207468652074617262616c6c2062> 20.0195 <7920686176696e672074686520617373656d626c793a73696e676c6520676f616c206265666f726520696e7374616c6c206f72206465706c6f> 20.0195 <7920696e>] TJ
 ET
@@ -643237,7 +643247,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-48.24 302.606 Td
+48.24 275.576 Td
 /F1.0 10.5 Tf
 <746865206d6176656e20636f6d6d616e643a> Tj
 ET
@@ -643246,28 +643256,28 @@ ET
 0.0 0.0 0.0 scn
 q
 0.9608 0.9608 0.9608 scn
-52.24 286.79 m
-543.04 286.79 l
-545.2491 286.79 547.04 284.9991 547.04 282.79 c
-547.04 254.05 l
-547.04 251.8409 545.2491 250.05 543.04 250.05 c
-52.24 250.05 l
-50.0309 250.05 48.24 251.8409 48.24 254.05 c
-48.24 282.79 l
-48.24 284.9991 50.0309 286.79 52.24 286.79 c
+52.24 259.76 m
+543.04 259.76 l
+545.2491 259.76 547.04 257.9691 547.04 255.76 c
+547.04 227.02 l
+547.04 224.8109 545.2491 223.02 543.04 223.02 c
+52.24 223.02 l
+50.0309 223.02 48.24 224.8109 48.24 227.02 c
+48.24 255.76 l
+48.24 257.9691 50.0309 259.76 52.24 259.76 c
 h
 f
 0.8 0.8 0.8 SCN
 0.75 w
-52.24 286.79 m
-543.04 286.79 l
-545.2491 286.79 547.04 284.9991 547.04 282.79 c
-547.04 254.05 l
-547.04 251.8409 545.2491 250.05 543.04 250.05 c
-52.24 250.05 l
-50.0309 250.05 48.24 251.8409 48.24 254.05 c
-48.24 282.79 l
-48.24 284.9991 50.0309 286.79 52.24 286.79 c
+52.24 259.76 m
+543.04 259.76 l
+545.2491 259.76 547.04 257.9691 547.04 255.76 c
+547.04 227.02 l
+547.04 224.8109 545.2491 223.02 543.04 223.02 c
+52.24 223.02 l
+50.0309 223.02 48.24 224.8109 48.24 227.02 c
+48.24 255.76 l
+48.24 257.9691 50.0309 259.76 52.24 259.76 c
 h
 S
 Q
@@ -643275,7 +643285,7 @@ Q
 0.2 0.2 0.2 SCN
 
 BT
-59.24 263.965 Td
+59.24 236.935 Td
 /F4.0 11 Tf
 <6d766e202d44736b69705465737473207061636b61676520617373656d626c793a73696e676c6520696e7374616c6c> Tj
 ET
@@ -643284,28 +643294,28 @@ ET
 0.0 0.0 0.0 scn
 q
 0.9608 0.9608 0.9608 scn
-52.24 238.05 m
-543.04 238.05 l
-545.2491 238.05 547.04 236.2591 547.04 234.05 c
-547.04 205.31 l
-547.04 203.1009 545.2491 201.31 543.04 201.31 c
-52.24 201.31 l
-50.0309 201.31 48.24 203.1009 48.24 205.31 c
-48.24 234.05 l
-48.24 236.2591 50.0309 238.05 52.24 238.05 c
+52.24 211.02 m
+543.04 211.02 l
+545.2491 211.02 547.04 209.2291 547.04 207.02 c
+547.04 178.28 l
+547.04 176.0709 545.2491 174.28 543.04 174.28 c
+52.24 174.28 l
+50.0309 174.28 48.24 176.0709 48.24 178.28 c
+48.24 207.02 l
+48.24 209.2291 50.0309 211.02 52.24 211.02 c
 h
 f
 0.8 0.8 0.8 SCN
 0.75 w
-52.24 238.05 m
-543.04 238.05 l
-545.2491 238.05 547.04 236.2591 547.04 234.05 c
-547.04 205.31 l
-547.04 203.1009 545.2491 201.31 543.04 201.31 c
-52.24 201.31 l
-50.0309 201.31 48.24 203.1009 48.24 205.31 c
-48.24 234.05 l
-48.24 236.2591 50.0309 238.05 52.24 238.05 c
+52.24 211.02 m
+543.04 211.02 l
+545.2491 211.02 547.04 209.2291 547.04 207.02 c
+547.04 178.28 l
+547.04 176.0709 545.2491 174.28 543.04 174.28 c
+52.24 174.28 l
+50.0309 174.28 48.24 176.0709 48.24 178.28 c
+48.24 207.02 l
+48.24 209.2291 50.0309 211.02 52.24 211.02 c
 h
 S
 Q
@@ -643313,7 +643323,7 @@ Q
 0.2 0.2 0.2 SCN
 
 BT
-59.24 215.225 Td
+59.24 188.195 Td
 /F4.0 11 Tf
 <6d766e202d44736b69705465737473207061636b61676520617373656d626c793a73696e676c65206465706c6f79> Tj
 ET
@@ -643324,7 +643334,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-48.24 170.626 Td
+48.24 143.596 Td
 /F2.0 13 Tf
 <3136312e312e372e204275696c6420476f7463686173> Tj
 ET
@@ -643337,7 +643347,7 @@ ET
 0.2971 Tw
 
 BT
-48.24 144.066 Td
+48.24 117.036 Td
 /F1.0 10.5 Tf
 <496620796f752073656520> Tj
 ET
@@ -643352,7 +643362,7 @@ ET
 0.2971 Tw
 
 BT
-99.6259 144.066 Td
+99.6259 117.036 Td
 /F4.0 10.5 Tf
 <556e61626c6520746f2066696e64207265736f757263652027564d5f676c6f62616c5f6c6962726172792e766d27> Tj
 ET
@@ -643367,7 +643377,7 @@ ET
 0.2971 Tw
 
 BT
-342.3144 144.066 Td
+342.3144 117.036 Td
 /F1.0 10.5 Tf
 <2c2069676e6f72652069742e204974d573206e6f7420616e206572726f722e20497420697320> Tj
 ET
@@ -643382,7 +643392,7 @@ ET
 0.2971 Tw
 
 BT
-503.0345 144.066 Td
+503.0345 117.036 Td
 /F1.0 10.5 Tf
 <6f6666696369616c6c79> Tj
 ET
@@ -643395,7 +643405,7 @@ ET
 0.2588 0.5451 0.7922 SCN
 
 BT
-48.24 128.286 Td
+48.24 101.256 Td
 /F1.0 10.5 Tf
 <75676c79> Tj
 ET
@@ -643406,7 +643416,7 @@ ET
 0.2 0.2 0.2 SCN
 
 BT
-69.723 128.286 Td
+69.723 101.256 Td
 /F1.0 10.5 Tf
 <2074686f7567682e> Tj
 ET
@@ -643447,8 +643457,8 @@ endobj
 /ArtBox [0 0 595.28 841.89]
 /Contents 3345 0 R
 /Resources << /ProcSet [/PDF /Text /ImageB /ImageC /ImageI]
-/Font << /F4.0 35 0 R
-/F1.0 10 0 R
+/Font << /F1.0 10 0 R
+/F4.0 35 0 R
 /F3.0 33 0 R
 /F2.0 29 0 R
 >>
@@ -643459,21 +643469,21 @@ endobj
 >>
 endobj
 3347 0 obj
-[3346 0 R /XYZ 0 729.37 null]
+[3346 0 R /XYZ 0 702.34 null]
 endobj
 3348 0 obj
-[3346 0 R /XYZ 0 483.71 null]
+[3346 0 R /XYZ 0 456.68 null]
 endobj
 3349 0 obj
 << /Border [0 0 0]
 /Dest (releasing)
 /Subtype /Link
-/Rect [480.6235 435.4 526.4665 449.68]
+/Rect [480.6235 408.37 526.4665 422.65]
 /Type /Annot
 >>
 endobj
 3350 0 obj
-[3346 0 R /XYZ 0 189.31 null]
+[3346 0 R /XYZ 0 162.28 null]
 endobj
 3351 0 obj
 << /Limits [(bundled-hbase-mapreduce-jobs) (casestudies)]
@@ -643487,7 +643497,7 @@ endobj
 /URI (https://issues.apache.org/jira/browse/MSITE-286)
 >>
 /Subtype /Link
-/Rect [503.0345 141.0 547.04 155.28]
+/Rect [503.0345 113.97 547.04 128.25]
 /Type /Annot
 >>
 endobj
@@ -643498,7 +643508,7 @@ endobj
 /URI (https://issues.apache.org/jira/browse/MSITE-286)
 >>
 /Subtype /Link
-/Rect [48.24 125.22 69.723 139.5]
+/Rect [48.24 98.19 69.723 112.47]
 /Type /Annot
 >>
 endobj
@@ -784416,4660 +784426,4660 @@ xref
 0000464271 00000 n 
 0000464490 00000 n 
 0000464707 00000 n 
-0000504278 00000 n 
-0000504716 00000 n 
-0000504914 00000 n 
-0000505112 00000 n 
-0000505304 00000 n 
-0000505495 00000 n 
-0000505686 00000 n 
-0000505875 00000 n 
-0000506066 00000 n 
-0000519942 00000 n 
-0000520385 00000 n 
-0000520432 00000 n 
-0000520581 00000 n 
-0000520801 00000 n 
-0000520848 00000 n 
-0000521040 00000 n 
-0000521234 00000 n 
-0000521428 00000 n 
-0000521619 00000 n 
-0000536809 00000 n 
-0000537228 00000 n 
-0000537274 00000 n 
-0000537399 00000 n 
-0000537525 00000 n 
-0000537571 00000 n 
-0000537695 00000 n 
-0000537741 00000 n 
-0000537787 00000 n 
-0000549031 00000 n 
-0000549482 00000 n 
-0000549666 00000 n 
-0000549898 00000 n 
-0000550128 00000 n 
-0000550174 00000 n 
-0000550302 00000 n 
-0000550436 00000 n 
-0000550483 00000 n 
-0000550629 00000 n 
-0000550754 00000 n 
-0000569417 00000 n 
-0000569802 00000 n 
-0000569932 00000 n 
-0000570076 00000 n 
-0000574763 00000 n 
-0000575122 00000 n 
-0000585152 00000 n 
-0000585542 00000 n 
-0000585588 00000 n 
-0000585719 00000 n 
-0000596148 00000 n 
-0000596551 00000 n 
-0000596597 00000 n 
-0000596643 00000 n 
-0000596785 00000 n 
-0000596831 00000 n 
-0000596877 00000 n 
-0000596924 00000 n 
-0000596971 00000 n 
-0000597017 00000 n 
-0000597621 00000 n 
-0000605840 00000 n 
-0000606199 00000 n 
-0000606246 00000 n 
-0000606293 00000 n 
-0000606340 00000 n 
-0000606387 00000 n 
-0000606432 00000 n 
-0000614719 00000 n 
-0000615078 00000 n 
-0000615125 00000 n 
-0000615172 00000 n 
-0000615218 00000 n 
-0000615265 00000 n 
-0000615312 00000 n 
-0000615358 00000 n 
-0000616031 00000 n 
-0000623122 00000 n 
-0000623481 00000 n 
-0000623528 00000 n 
-0000623575 00000 n 
-0000623622 00000 n 
-0000623669 00000 n 
-0000623715 00000 n 
-0000623761 00000 n 
-0000634701 00000 n 
-0000635060 00000 n 
-0000635107 00000 n 
-0000635154 00000 n 
-0000635201 00000 n 
-0000643825 00000 n 
-0000644184 00000 n 
-0000644230 00000 n 
-0000644277 00000 n 
-0000644324 00000 n 
-0000644371 00000 n 
-0000645029 00000 n 
-0000645076 00000 n 
-0000645122 00000 n 
-0000653371 00000 n 
-0000653730 00000 n 
-0000653777 00000 n 
-0000653824 00000 n 
-0000653871 00000 n 
-0000653918 00000 n 
-0000653965 00000 n 
-0000654012 00000 n 
-0000663009 00000 n 
-0000663394 00000 n 
-0000663441 00000 n 
-0000663674 00000 n 
-0000663906 00000 n 
-0000663953 00000 n 
-0000664000 00000 n 
-0000664047 00000 n 
-0000664094 00000 n 
-0000671817 00000 n 
-0000672218 00000 n 
-0000672264 00000 n 
-0000672508 00000 n 
-0000672751 00000 n 
-0000672798 00000 n 
-0000673042 00000 n 
-0000673285 00000 n 
-0000673332 00000 n 
-0000673379 00000 n 
-0000673969 00000 n 
-0000674016 00000 n 
-0000674062 00000 n 
-0000674108 00000 n 
-0000683065 00000 n 
-0000683437 00000 n 
-0000683484 00000 n 
-0000683531 00000 n 
-0000683578 00000 n 
-0000683625 00000 n 
-0000683671 00000 n 
-0000693523 00000 n 
-0000693908 00000 n 
-0000693955 00000 n 
-0000694002 00000 n 
-0000694049 00000 n 
-0000694614 00000 n 
-0000694809 00000 n 
-0000695002 00000 n 
-0000695049 00000 n 
-0000702838 00000 n 
-0000703197 00000 n 
-0000703245 00000 n 
-0000703293 00000 n 
-0000703341 00000 n 
-0000703389 00000 n 
-0000703437 00000 n 
-0000703485 00000 n 
-0000703532 00000 n 
-0000711019 00000 n 
-0000711378 00000 n 
-0000711425 00000 n 
-0000711472 00000 n 
-0000711519 00000 n 
-0000711566 00000 n 
-0000711612 00000 n 
-0000711658 00000 n 
-0000720811 00000 n 
-0000721170 00000 n 
-0000721217 00000 n 
-0000721264 00000 n 
-0000721311 00000 n 
-0000721358 00000 n 
-0000721404 00000 n 
-0000730488 00000 n 
-0000730847 00000 n 
-0000730894 00000 n 
-0000730941 00000 n 
-0000731583 00000 n 
-0000731630 00000 n 
-0000731677 00000 n 
-0000731723 00000 n 
-0000741847 00000 n 
-0000742206 00000 n 
-0000742253 00000 n 
-0000742300 00000 n 
-0000742347 00000 n 
-0000742393 00000 n 
-0000752846 00000 n 
-0000753205 00000 n 
-0000753252 00000 n 
-0000753299 00000 n 
-0000753346 00000 n 
-0000753963 00000 n 
-0000754009 00000 n 
-0000762781 00000 n 
-0000763140 00000 n 
-0000763187 00000 n 
-0000763234 00000 n 
-0000763281 00000 n 
-0000763328 00000 n 
-0000763375 00000 n 
-0000770985 00000 n 
-0000771344 00000 n 
-0000771391 00000 n 
-0000771438 00000 n 
-0000771485 00000 n 
-0000771532 00000 n 
-0000771579 00000 n 
-0000771626 00000 n 
-0000779920 00000 n 
-0000780305 00000 n 
-0000780503 00000 n 
-0000780550 00000 n 
-0000780597 00000 n 
-0000780644 00000 n 
-0000780832 00000 n 
-0000780879 00000 n 
-0000780926 00000 n 
-0000789701 00000 n 
-0000790060 00000 n 
-0000790106 00000 n 
-0000790153 00000 n 
-0000790200 00000 n 
-0000790247 00000 n 
-0000790840 00000 n 
-0000790887 00000 n 
-0000791530 00000 n 
-0000791575 00000 n 
-0000800331 00000 n 
-0000800740 00000 n 
-0000800967 00000 n 
-0000801193 00000 n 
-0000801240 00000 n 
-0000801437 00000 n 
-0000801484 00000 n 
-0000801679 00000 n 
-0000801873 00000 n 
-0000801920 00000 n 
-0000801967 00000 n 
-0000802012 00000 n 
-0000802828 00000 n 
-0000810252 00000 n 
-0000810611 00000 n 
-0000810658 00000 n 
-0000810705 00000 n 
-0000810752 00000 n 
-0000810799 00000 n 
-0000810846 00000 n 
-0000810892 00000 n 
-0000819607 00000 n 
-0000819966 00000 n 
-0000820013 00000 n 
-0000820060 00000 n 
-0000820107 00000 n 
-0000820154 00000 n 
-0000820199 00000 n 
-0000828078 00000 n 
-0000828437 00000 n 
-0000828485 00000 n 
-0000828533 00000 n 
-0000828581 00000 n 
-0000828629 00000 n 
-0000828677 00000 n 
-0000837380 00000 n 
-0000837739 00000 n 
-0000837785 00000 n 
-0000837832 00000 n 
-0000837879 00000 n 
-0000837926 00000 n 
-0000837973 00000 n 
-0000838018 00000 n 
-0000845656 00000 n 
-0000846015 00000 n 
-0000846062 00000 n 
-0000846109 00000 n 
-0000846156 00000 n 
-0000846203 00000 n 
-0000846250 00000 n 
-0000846297 00000 n 
-0000853513 00000 n 
-0000853872 00000 n 
-0000853919 00000 n 
-0000854268 00000 n 
-0000854315 00000 n 
-0000854362 00000 n 
-0000854409 00000 n 
-0000854456 00000 n 
-0000854503 00000 n 
-0000855076 00000 n 
-0000863583 00000 n 
-0000863942 00000 n 
-0000863988 00000 n 
-0000864035 00000 n 
-0000864082 00000 n 
-0000864129 00000 n 
-0000864176 00000 n 
-0000864222 00000 n 
-0000873219 00000 n 
-0000873578 00000 n 
-0000873625 00000 n 
-0000874406 00000 n 
-0000874453 00000 n 
-0000874500 00000 n 
-0000874547 00000 n 
-0000874594 00000 n 
-0000882239 00000 n 
-0000882598 00000 n 
-0000882645 00000 n 
-0000882692 00000 n 
-0000882739 00000 n 
-0000882786 00000 n 
-0000882833 00000 n 
-0000882880 00000 n 
-0000891223 00000 n 
-0000891624 00000 n 
-0000891672 00000 n 
-0000891720 00000 n 
-0000891768 00000 n 
-0000891816 00000 n 
-0000892065 00000 n 
-0000892314 00000 n 
-0000892362 00000 n 
-0000892613 00000 n 
-0000892864 00000 n 
-0000892912 00000 n 
-0000903793 00000 n 
-0000904166 00000 n 
-0000904214 00000 n 
-0000904908 00000 n 
-0000905084 00000 n 
-0000905131 00000 n 
-0000905178 00000 n 
-0000905225 00000 n 
-0000914592 00000 n 
-0000914951 00000 n 
-0000914998 00000 n 
-0000915045 00000 n 
-0000915092 00000 n 
-0000915139 00000 n 
-0000923944 00000 n 
-0000924303 00000 n 
-0000924349 00000 n 
-0000924396 00000 n 
-0000925007 00000 n 
-0000925054 00000 n 
-0000925101 00000 n 
-0000925148 00000 n 
-0000925193 00000 n 
-0000933250 00000 n 
-0000933609 00000 n 
-0000933657 00000 n 
-0000933705 00000 n 
-0000933753 00000 n 
-0000933801 00000 n 
-0000933849 00000 n 
-0000941468 00000 n 
-0000941827 00000 n 
-0000941873 00000 n 
-0000941920 00000 n 
-0000942327 00000 n 
-0000942374 00000 n 
-0000942421 00000 n 
-0000942468 00000 n 
-0000942514 00000 n 
-0000950976 00000 n 
-0000951348 00000 n 
-0000951394 00000 n 
-0000951441 00000 n 
-0000951488 00000 n 
-0000951535 00000 n 
-0000951582 00000 n 
-0000952065 00000 n 
-0000952112 00000 n 
-0000971597 00000 n 
-0000971995 00000 n 
-0000972041 00000 n 
-0000972262 00000 n 
-0000972479 00000 n 
-0000990487 00000 n 
-0000990872 00000 n 
-0000990918 00000 n 
-0000990964 00000 n 
-0000991010 00000 n 
-0000997918 00000 n 
-0000998290 00000 n 
-0000998336 00000 n 
-0000998382 00000 n 
-0001008898 00000 n 
-0001009341 00000 n 
-0001009387 00000 n 
-0001009433 00000 n 
-0001009550 00000 n 
-0001009671 00000 n 
-0001009717 00000 n 
-0001009908 00000 n 
-0001010096 00000 n 
-0001010287 00000 n 
-0001010333 00000 n 
-0001010379 00000 n 
-0001010425 00000 n 
-0001010471 00000 n 
-0001010593 00000 n 
-0001010638 00000 n 
-0001022412 00000 n 
-0001022831 00000 n 
-0001022877 00000 n 
-0001022923 00000 n 
-0001023050 00000 n 
-0001023096 00000 n 
-0001023142 00000 n 
-0001023267 00000 n 
-0001023313 00000 n 
-0001023432 00000 n 
-0001037937 00000 n 
-0001038340 00000 n 
-0001038386 00000 n 
-0001039030 00000 n 
-0001039176 00000 n 
-0001050978 00000 n 
-0001051421 00000 n 
-0001051467 00000 n 
-0001051601 00000 n 
-0001051871 00000 n 
-0001051999 00000 n 
-0001052046 00000 n 
-0001052093 00000 n 
-0001052140 00000 n 
-0001052285 00000 n 
-0001052332 00000 n 
-0001052379 00000 n 
-0001052571 00000 n 
-0001052863 00000 n 
-0001062978 00000 n 
-0001063384 00000 n 
-0001063578 00000 n 
-0001063624 00000 n 
-0001063846 00000 n 
-0001064039 00000 n 
-0001082406 00000 n 
-0001082804 00000 n 
-0001082850 00000 n 
-0001083069 00000 n 
-0001083263 00000 n 
-0001094646 00000 n 
-0001095018 00000 n 
-0001106187 00000 n 
-0001106559 00000 n 
-0001124949 00000 n 
-0001125321 00000 n 
-0001125367 00000 n 
-0001145376 00000 n 
-0001145722 00000 n 
-0001147542 00000 n 
-0001147888 00000 n 
-0001151349 00000 n 
-0001151771 00000 n 
-0001151817 00000 n 
-0001151945 00000 n 
-0001152116 00000 n 
-0001152238 00000 n 
-0001152386 00000 n 
-0001152533 00000 n 
-0001162613 00000 n 
-0001162990 00000 n 
-0001163036 00000 n 
-0001163082 00000 n 
-0001163246 00000 n 
-0001163293 00000 n 
-0001176741 00000 n 
-0001177147 00000 n 
-0001177352 00000 n 
-0001177558 00000 n 
-0001177761 00000 n 
-0001207143 00000 n 
-0001207554 00000 n 
-0001207601 00000 n 
-0001207818 00000 n 
-0001208088 00000 n 
-0001222007 00000 n 
-0001222455 00000 n 
-0001222724 00000 n 
-0001222770 00000 n 
-0001222816 00000 n 
-0001222862 00000 n 
-0001222908 00000 n 
-0001223103 00000 n 
-0001223299 00000 n 
-0001223479 00000 n 
-0001223717 00000 n 
-0001236706 00000 n 
-0001237128 00000 n 
-0001237174 00000 n 
-0001237221 00000 n 
-0001237268 00000 n 
-0001237404 00000 n 
-0001237540 00000 n 
-0001237662 00000 n 
-0001237709 00000 n 
-0001237843 00000 n 
-0001237976 00000 n 
-0001240311 00000 n 
-0001240678 00000 n 
-0001240815 00000 n 
-0001240954 00000 n 
-0001241093 00000 n 
-0001253860 00000 n 
-0001254237 00000 n 
-0001254283 00000 n 
-0001254865 00000 n 
-0001255042 00000 n 
-0001255293 00000 n 
-0001255339 00000 n 
-0001255485 00000 n 
-0001265406 00000 n 
-0001265765 00000 n 
-0001265811 00000 n 
-0001265858 00000 n 
-0001276621 00000 n 
-0001277011 00000 n 
-0001277058 00000 n 
-0001277270 00000 n 
-0001284435 00000 n 
-0001284794 00000 n 
-0001297664 00000 n 
-0001298107 00000 n 
-0001298153 00000 n 
-0001298199 00000 n 
-0001298245 00000 n 
-0001298291 00000 n 
-0001298429 00000 n 
-0001298476 00000 n 
-0001298523 00000 n 
-0001298718 00000 n 
-0001298910 00000 n 
-0001299104 00000 n 
-0001299151 00000 n 
-0001299345 00000 n 
-0001299537 00000 n 
-0001313143 00000 n 
-0001313615 00000 n 
-0001313663 00000 n 
-0001313804 00000 n 
-0001314114 00000 n 
-0001314424 00000 n 
-0001314622 00000 n 
-0001314762 00000 n 
-0001314810 00000 n 
-0001315007 00000 n 
-0001315055 00000 n 
-0001315201 00000 n 
-0001315249 00000 n 
-0001315375 00000 n 
-0001326612 00000 n 
-0001327037 00000 n 
-0001327083 00000 n 
-0001327210 00000 n 
-0001327337 00000 n 
-0001327383 00000 n 
-0001327914 00000 n 
-0001327960 00000 n 
-0001328006 00000 n 
-0001328185 00000 n 
-0001339858 00000 n 
-0001340230 00000 n 
-0001351193 00000 n 
-0001351565 00000 n 
-0001364589 00000 n 
-0001365001 00000 n 
-0001365047 00000 n 
-0001365093 00000 n 
-0001365272 00000 n 
-0001365319 00000 n 
-0001365366 00000 n 
-0001365560 00000 n 
-0001365753 00000 n 
-0001381310 00000 n 
-0001381774 00000 n 
-0001381820 00000 n 
-0001381866 00000 n 
-0001381989 00000 n 
-0001382111 00000 n 
-0001382265 00000 n 
-0001382390 00000 n 
-0001382437 00000 n 
-0001382633 00000 n 
-0001382837 00000 n 
-0001382961 00000 n 
-0001395250 00000 n 
-0001395670 00000 n 
-0001395797 00000 n 
-0001395969 00000 n 
-0001396092 00000 n 
-0001396293 00000 n 
-0001396441 00000 n 
-0001396635 00000 n 
-0001396827 00000 n 
-0001396950 00000 n 
-0001408374 00000 n 
-0001408809 00000 n 
-0001409001 00000 n 
-0001409192 00000 n 
-0001409238 00000 n 
-0001409381 00000 n 
-0001409573 00000 n 
-0001409763 00000 n 
-0001414621 00000 n 
-0001415014 00000 n 
-0001415060 00000 n 
-0001415220 00000 n 
-0001415348 00000 n 
-0001415556 00000 n 
-0001417737 00000 n 
-0001418109 00000 n 
-0001418155 00000 n 
-0001421352 00000 n 
-0001421729 00000 n 
-0001421775 00000 n 
-0001421969 00000 n 
-0001431699 00000 n 
-0001432102 00000 n 
-0001432148 00000 n 
-0001432289 00000 n 
-0001440692 00000 n 
-0001441064 00000 n 
-0001441111 00000 n 
-0001445102 00000 n 
-0001445474 00000 n 
-0001445520 00000 n 
-0001453093 00000 n 
-0001453452 00000 n 
-0001457548 00000 n 
-0001457920 00000 n 
-0001457966 00000 n 
-0001466023 00000 n 
-0001466396 00000 n 
-0001466442 00000 n 
-0001466488 00000 n 
-0001476598 00000 n 
-0001476958 00000 n 
-0001486673 00000 n 
-0001487077 00000 n 
-0001487123 00000 n 
-0001487169 00000 n 
-0001487388 00000 n 
-0001503643 00000 n 
-0001504002 00000 n 
-0001504048 00000 n 
-0001504094 00000 n 
-0001559795 00000 n 
-0001560167 00000 n 
-0001560213 00000 n 
-0001560259 00000 n 
-0001560305 00000 n 
-0001564941 00000 n 
-0001565300 00000 n 
-0001565346 00000 n 
-0001565392 00000 n 
-0001575581 00000 n 
-0001575953 00000 n 
-0001575999 00000 n 
-0001576714 00000 n 
-0001608553 00000 n 
-0001608972 00000 n 
-0001609018 00000 n 
-0001609201 00000 n 
-0001609452 00000 n 
-0001609646 00000 n 
-0001639773 00000 n 
-0001640119 00000 n 
-0001658847 00000 n 
-0001659237 00000 n 
-0001659283 00000 n 
-0001659413 00000 n 
-0001671358 00000 n 
-0001671764 00000 n 
-0001671810 00000 n 
-0001672365 00000 n 
-0001672559 00000 n 
-0001672751 00000 n 
-0001672944 00000 n 
-0001672990 00000 n 
-0001673037 00000 n 
-0001675349 00000 n 
-0001675708 00000 n 
-0001676356 00000 n 
-0001676702 00000 n 
-0001676748 00000 n 
-0001677987 00000 n 
-0001678333 00000 n 
-0001678379 00000 n 
-0001679022 00000 n 
-0001684509 00000 n 
-0001684881 00000 n 
-0001684927 00000 n 
-0001686134 00000 n 
-0001686506 00000 n 
-0001686552 00000 n 
-0001711100 00000 n 
-0001711533 00000 n 
-0001711579 00000 n 
-0001711795 00000 n 
-0001711841 00000 n 
-0001712052 00000 n 
-0001712311 00000 n 
-0001712357 00000 n 
-0001712570 00000 n 
-0001712829 00000 n 
-0001713089 00000 n 
-0001713135 00000 n 
-0001713348 00000 n 
-0001713579 00000 n 
-0001716411 00000 n 
-0001716812 00000 n 
-0001716858 00000 n 
-0001717074 00000 n 
-0001717339 00000 n 
-0001717468 00000 n 
-0001717594 00000 n 
-0001731403 00000 n 
-0001731837 00000 n 
-0001731883 00000 n 
-0001732076 00000 n 
-0001732266 00000 n 
-0001732312 00000 n 
-0001732539 00000 n 
-0001732718 00000 n 
-0001755566 00000 n 
-0001756024 00000 n 
-0001756248 00000 n 
-0001756386 00000 n 
-0001756433 00000 n 
-0001756480 00000 n 
-0001756700 00000 n 
-0001756920 00000 n 
-0001757157 00000 n 
-0001757400 00000 n 
-0001757447 00000 n 
-0001799610 00000 n 
-0001799969 00000 n 
-0001800015 00000 n 
-0001800061 00000 n 
-0001800107 00000 n 
-0001800153 00000 n 
-0001814768 00000 n 
-0001815232 00000 n 
-0001815278 00000 n 
-0001815487 00000 n 
-0001815695 00000 n 
-0001815902 00000 n 
-0001816024 00000 n 
-0001816155 00000 n 
-0001816350 00000 n 
-0001816395 00000 n 
-0001816441 00000 n 
-0001816632 00000 n 
-0001821524 00000 n 
-0001821914 00000 n 
-0001821959 00000 n 
-0001822150 00000 n 
-0001823422 00000 n 
-0001823768 00000 n 
-0001823814 00000 n 
-0001826282 00000 n 
-0001826646 00000 n 
-0001826692 00000 n 
-0001826816 00000 n 
-0001830463 00000 n 
-0001830809 00000 n 
-0001830855 00000 n 
-0001832037 00000 n 
-0001832409 00000 n 
-0001832455 00000 n 
-0001832619 00000 n 
-0001832824 00000 n 
-0001838544 00000 n 
-0001838961 00000 n 
-0001839007 00000 n 
-0001839218 00000 n 
-0001839428 00000 n 
-0001839551 00000 n 
-0001839684 00000 n 
-0001839882 00000 n 
-0001840099 00000 n 
-0001856152 00000 n 
-0001856566 00000 n 
-0001856612 00000 n 
-0001856733 00000 n 
-0001856953 00000 n 
-0001857085 00000 n 
-0001857131 00000 n 
-0001857248 00000 n 
-0001864702 00000 n 
-0001865066 00000 n 
-0001865112 00000 n 
-0001865236 00000 n 
-0001868177 00000 n 
-0001868541 00000 n 
-0001868587 00000 n 
-0001868811 00000 n 
-0001874207 00000 n 
-0001874571 00000 n 
-0001874617 00000 n 
-0001874743 00000 n 
-0001874789 00000 n 
-0001882242 00000 n 
-0001882601 00000 n 
-0001882647 00000 n 
-0001882693 00000 n 
-0001894131 00000 n 
-0001894490 00000 n 
-0001909763 00000 n 
-0001910233 00000 n 
-0001910494 00000 n 
-0001910755 00000 n 
-0001910940 00000 n 
-0001911137 00000 n 
-0001911184 00000 n 
-0001911372 00000 n 
-0001911612 00000 n 
-0001911780 00000 n 
-0001911959 00000 n 
-0001912093 00000 n 
-0001912140 00000 n 
-0001912444 00000 n 
-0001912563 00000 n 
-0001921330 00000 n 
-0001921739 00000 n 
-0001921856 00000 n 
-0001922105 00000 n 
-0001922227 00000 n 
-0001922273 00000 n 
-0001922395 00000 n 
-0001922440 00000 n 
-0001922562 00000 n 
-0001922608 00000 n 
-0001922654 00000 n 
-0001961357 00000 n 
-0001961768 00000 n 
-0001961814 00000 n 
-0001962008 00000 n 
-0001962249 00000 n 
-0001974835 00000 n 
-0001975225 00000 n 
-0001975356 00000 n 
-0001975402 00000 n 
-0001975447 00000 n 
-0001976288 00000 n 
-0001976334 00000 n 
-0002017726 00000 n 
-0002018103 00000 n 
-0002018273 00000 n 
-0002025286 00000 n 
-0002025679 00000 n 
-0002025725 00000 n 
-0002025771 00000 n 
-0002026252 00000 n 
-0002026474 00000 n 
-0002026597 00000 n 
-0002026643 00000 n 
-0002026868 00000 n 
-0002031778 00000 n 
-0002032183 00000 n 
-0002032229 00000 n 
-0002032828 00000 n 
-0002033047 00000 n 
-0002033269 00000 n 
-0002033395 00000 n 
-0002033442 00000 n 
-0002033718 00000 n 
-0002034677 00000 n 
-0002035044 00000 n 
-0002035092 00000 n 
-0002035212 00000 n 
-0002041230 00000 n 
-0002041632 00000 n 
-0002041680 00000 n 
-0002041904 00000 n 
-0002042100 00000 n 
-0002052417 00000 n 
-0002052847 00000 n 
-0002052895 00000 n 
-0002053114 00000 n 
-0002053334 00000 n 
-0002112974 00000 n 
-0002113322 00000 n 
-0002173364 00000 n 
-0002173712 00000 n 
-0002185328 00000 n 
-0002185689 00000 n 
-0002196599 00000 n 
-0002197015 00000 n 
-0002197063 00000 n 
-0002197190 00000 n 
-0002197410 00000 n 
-0002197630 00000 n 
-0002197678 00000 n 
-0002197807 00000 n 
-0002197855 00000 n 
-0002197994 00000 n 
-0002201761 00000 n 
-0002202146 00000 n 
-0002202194 00000 n 
-0002202334 00000 n 
-0002202382 00000 n 
-0002202521 00000 n 
-0002202569 00000 n 
-0002202683 00000 n 
-0002205270 00000 n 
-0002205637 00000 n 
-0002205685 00000 n 
-0002205915 00000 n 
-0002216627 00000 n 
-0002217016 00000 n 
-0002217064 00000 n 
-0002217186 00000 n 
-0002217234 00000 n 
-0002217282 00000 n 
-0002217408 00000 n 
-0002231070 00000 n 
-0002231499 00000 n 
-0002231547 00000 n 
-0002231595 00000 n 
-0002231790 00000 n 
-0002232033 00000 n 
-0002232082 00000 n 
-0002242188 00000 n 
-0002242595 00000 n 
-0002242860 00000 n 
-0002242908 00000 n 
-0002243082 00000 n 
-0002243256 00000 n 
-0002243457 00000 n 
-0002243505 00000 n 
-0002253317 00000 n 
-0002253710 00000 n 
-0002253859 00000 n 
-0002253907 00000 n 
-0002254517 00000 n 
-0002263730 00000 n 
-0002264110 00000 n 
-0002264158 00000 n 
-0002264206 00000 n 
-0002264351 00000 n 
-0002274870 00000 n 
-0002275250 00000 n 
-0002275298 00000 n 
-0002275442 00000 n 
-0002275490 00000 n 
-0002285692 00000 n 
-0002286059 00000 n 
-0002286107 00000 n 
-0002286251 00000 n 
-0002286299 00000 n 
-0002286347 00000 n 
-0002286395 00000 n 
-0002286443 00000 n 
-0002306918 00000 n 
-0002307311 00000 n 
-0002307459 00000 n 
-0002307507 00000 n 
-0002321084 00000 n 
-0002321482 00000 n 
-0002321677 00000 n 
-0002321862 00000 n 
-0002322046 00000 n 
-0002324210 00000 n 
-0002324545 00000 n 
-0002338791 00000 n 
-0002339165 00000 n 
-0002339213 00000 n 
-0002339752 00000 n 
-0002339800 00000 n 
-0002339848 00000 n 
-0002339896 00000 n 
-0002354202 00000 n 
-0002354576 00000 n 
-0002354623 00000 n 
-0002354671 00000 n 
-0002354719 00000 n 
-0002354767 00000 n 
-0002356536 00000 n 
-0002356884 00000 n 
-0002368195 00000 n 
-0002368602 00000 n 
-0002368650 00000 n 
-0002368698 00000 n 
-0002368746 00000 n 
-0002368794 00000 n 
-0002368922 00000 n 
-0002376256 00000 n 
-0002376707 00000 n 
-0002376755 00000 n 
-0002377172 00000 n 
-0002377342 00000 n 
-0002377600 00000 n 
-0002377855 00000 n 
-0002378067 00000 n 
-0002378193 00000 n 
-0002378365 00000 n 
-0002393212 00000 n 
-0002393618 00000 n 
-0002393666 00000 n 
-0002393895 00000 n 
-0002404554 00000 n 
-0002404902 00000 n 
-0002410324 00000 n 
-0002410698 00000 n 
-0002421973 00000 n 
-0002422349 00000 n 
-0002422543 00000 n 
-0002422681 00000 n 
-0002429404 00000 n 
-0002429771 00000 n 
-0002429967 00000 n 
-0002437546 00000 n 
-0002437948 00000 n 
-0002437996 00000 n 
-0002438191 00000 n 
-0002438411 00000 n 
-0002443270 00000 n 
-0002443631 00000 n 
-0002443679 00000 n 
-0002454745 00000 n 
-0002455197 00000 n 
-0002455245 00000 n 
-0002455479 00000 n 
-0002455714 00000 n 
-0002455952 00000 n 
-0002456182 00000 n 
-0002456412 00000 n 
-0002456647 00000 n 
-0002456886 00000 n 
-0002457108 00000 n 
-0002457344 00000 n 
-0002459137 00000 n 
-0002459504 00000 n 
-0002459552 00000 n 
-0002459683 00000 n 
-0002463665 00000 n 
-0002464063 00000 n 
-0002464111 00000 n 
-0002464340 00000 n 
-0002464480 00000 n 
-0002464618 00000 n 
-0002467680 00000 n 
-0002468069 00000 n 
-0002468117 00000 n 
-0002468165 00000 n 
-0002468399 00000 n 
-0002468447 00000 n 
-0002468928 00000 n 
-0002469164 00000 n 
-0002497175 00000 n 
-0002497555 00000 n 
-0002497603 00000 n 
-0002497651 00000 n 
-0002497879 00000 n 
-0002523223 00000 n 
-0002523603 00000 n 
-0002523651 00000 n 
-0002523884 00000 n 
-0002545314 00000 n 
-0002545675 00000 n 
-0002545723 00000 n 
-0002545771 00000 n 
-0002588963 00000 n 
-0002589311 00000 n 
-0002613262 00000 n 
-0002613623 00000 n 
-0002613671 00000 n 
-0002651268 00000 n 
-0002651629 00000 n 
-0002651677 00000 n 
-0002671248 00000 n 
-0002671609 00000 n 
-0002671657 00000 n 
-0002684759 00000 n 
-0002685120 00000 n 
-0002685168 00000 n 
-0002685626 00000 n 
-0002685821 00000 n 
-0002687902 00000 n 
-0002688269 00000 n 
-0002688317 00000 n 
-0002688437 00000 n 
-0002725729 00000 n 
-0002726109 00000 n 
-0002726157 00000 n 
-0002726325 00000 n 
-0002731074 00000 n 
-0002731476 00000 n 
-0002731524 00000 n 
-0002731698 00000 n 
-0002731874 00000 n 
-0002740147 00000 n 
-0002740553 00000 n 
-0002740601 00000 n 
-0002740830 00000 n 
-0002748521 00000 n 
-0002748895 00000 n 
-0002748943 00000 n 
-0002749538 00000 n 
-0002760372 00000 n 
-0002760720 00000 n 
-0002772753 00000 n 
-0002773160 00000 n 
-0002773208 00000 n 
-0002773460 00000 n 
-0002773710 00000 n 
-0002773758 00000 n 
-0002773806 00000 n 
-0002773945 00000 n 
-0002773993 00000 n 
-0002774129 00000 n 
-0002794138 00000 n 
-0002794499 00000 n 
-0002794547 00000 n 
-0002810711 00000 n 
-0002811159 00000 n 
-0002811338 00000 n 
-0002811486 00000 n 
-0002811534 00000 n 
-0002811669 00000 n 
-0002811865 00000 n 
-0002812061 00000 n 
-0002827698 00000 n 
-0002828163 00000 n 
-0002828299 00000 n 
-0002828434 00000 n 
-0002828569 00000 n 
-0002828704 00000 n 
-0002828752 00000 n 
-0002828889 00000 n 
-0002829085 00000 n 
-0002845221 00000 n 
-0002845647 00000 n 
-0002845917 00000 n 
-0002845965 00000 n 
-0002846113 00000 n 
-0002846319 00000 n 
-0002860542 00000 n 
-0002860935 00000 n 
-0002861138 00000 n 
-0002861186 00000 n 
-0002872932 00000 n 
-0002873293 00000 n 
-0002878946 00000 n 
-0002879353 00000 n 
-0002879401 00000 n 
-0002879653 00000 n 
-0002879903 00000 n 
-0002879951 00000 n 
-0002880090 00000 n 
-0002880230 00000 n 
-0002880278 00000 n 
-0002880326 00000 n 
-0002895113 00000 n 
-0002895474 00000 n 
-0002895522 00000 n 
-0002910846 00000 n 
-0002911235 00000 n 
-0002911283 00000 n 
-0002911432 00000 n 
-0002911480 00000 n 
-0002911628 00000 n 
-0002924652 00000 n 
-0002925050 00000 n 
-0002925098 00000 n 
-0002925549 00000 n 
-0002925597 00000 n 
-0002925843 00000 n 
-0002925969 00000 n 
-0002926095 00000 n 
-0002926143 00000 n 
-0002929629 00000 n 
-0002930010 00000 n 
-0002930148 00000 n 
-0002943529 00000 n 
-0002943953 00000 n 
-0002944001 00000 n 
-0002944124 00000 n 
-0002944173 00000 n 
-0002944310 00000 n 
-0002944440 00000 n 
-0002956045 00000 n 
-0002956451 00000 n 
-0002956499 00000 n 
-0002956547 00000 n 
-0002956685 00000 n 
-0002956733 00000 n 
-0002956781 00000 n 
-0002956829 00000 n 
-0002973056 00000 n 
-0002973417 00000 n 
-0002995523 00000 n 
-0002995910 00000 n 
-0003009076 00000 n 
-0003009505 00000 n 
-0003009643 00000 n 
-0003009692 00000 n 
-0003009821 00000 n 
-0003009870 00000 n 
-0003010019 00000 n 
-0003010158 00000 n 
-0003010298 00000 n 
-0003019246 00000 n 
-0003019607 00000 n 
-0003035259 00000 n 
-0003035607 00000 n 
-0003049874 00000 n 
-0003050261 00000 n 
-0003050309 00000 n 
-0003061800 00000 n 
-0003062187 00000 n 
-0003067895 00000 n 
-0003068269 00000 n 
-0003104753 00000 n 
-0003105128 00000 n 
-0003137513 00000 n 
-0003137887 00000 n 
-0003171507 00000 n 
-0003171881 00000 n 
-0003171930 00000 n 
-0003188089 00000 n 
-0003188518 00000 n 
-0003188713 00000 n 
-0003188908 00000 n 
-0003202002 00000 n 
-0003202408 00000 n 
-0003202456 00000 n 
-0003202603 00000 n 
-0003202651 00000 n 
-0003227264 00000 n 
-0003227625 00000 n 
-0003257550 00000 n 
-0003257911 00000 n 
-0003263937 00000 n 
-0003264311 00000 n 
-0003297004 00000 n 
-0003297406 00000 n 
-0003297455 00000 n 
-0003297793 00000 n 
-0003298092 00000 n 
-0003331502 00000 n 
-0003331913 00000 n 
-0003331962 00000 n 
-0003332160 00000 n 
-0003332302 00000 n 
-0003332441 00000 n 
-0003332490 00000 n 
-0003346939 00000 n 
-0003347332 00000 n 
-0003347525 00000 n 
-0003347572 00000 n 
-0003347619 00000 n 
-0003348253 00000 n 
-0003362576 00000 n 
-0003362950 00000 n 
-0003362998 00000 n 
-0003376316 00000 n 
-0003376690 00000 n 
-0003389489 00000 n 
-0003389876 00000 n 
-0003389924 00000 n 
-0003401637 00000 n 
-0003402044 00000 n 
-0003402092 00000 n 
-0003402342 00000 n 
-0003406617 00000 n 
-0003406965 00000 n 
-0003422602 00000 n 
-0003422976 00000 n 
-0003423024 00000 n 
-0003438792 00000 n 
-0003439140 00000 n 
-0003454490 00000 n 
-0003454851 00000 n 
-0003455247 00000 n 
-0003455595 00000 n 
-0003455643 00000 n 
-0003466931 00000 n 
-0003467279 00000 n 
-0003467327 00000 n 
-0003467375 00000 n 
-0003467423 00000 n 
-0003472405 00000 n 
-0003472781 00000 n 
-0003472829 00000 n 
-0003473266 00000 n 
-0003473494 00000 n 
-0003473619 00000 n 
-0003485104 00000 n 
-0003485528 00000 n 
-0003485576 00000 n 
-0003485624 00000 n 
-0003485845 00000 n 
-0003486090 00000 n 
-0003486139 00000 n 
-0003486281 00000 n 
-0003506043 00000 n 
-0003506499 00000 n 
-0003506547 00000 n 
-0003506681 00000 n 
-0003506811 00000 n 
-0003507031 00000 n 
-0003507079 00000 n 
-0003507212 00000 n 
-0003507345 00000 n 
-0003507393 00000 n 
-0003507624 00000 n 
-0003507672 00000 n 
-0003507891 00000 n 
-0003508113 00000 n 
-0003533294 00000 n 
-0003533772 00000 n 
-0003534001 00000 n 
-0003534049 00000 n 
-0003534246 00000 n 
-0003534474 00000 n 
-0003534523 00000 n 
-0003534749 00000 n 
-0003534972 00000 n 
-0003535199 00000 n 
-0003535394 00000 n 
-0003535563 00000 n 
-0003535827 00000 n 
-0003535876 00000 n 
-0003554932 00000 n 
-0003555293 00000 n 
-0003555341 00000 n 
-0003560955 00000 n 
-0003561335 00000 n 
-0003561383 00000 n 
-0003561806 00000 n 
-0003561932 00000 n 
-0003581409 00000 n 
-0003581834 00000 n 
-0003581882 00000 n 
-0003582095 00000 n 
-0003582314 00000 n 
-0003582536 00000 n 
-0003582584 00000 n 
-0003582632 00000 n 
-0003582854 00000 n 
-0003582902 00000 n 
-0003582950 00000 n 
-0003583187 00000 n 
-0003583423 00000 n 
-0003604890 00000 n 
-0003605297 00000 n 
-0003605345 00000 n 
-0003605482 00000 n 
-0003605530 00000 n 
-0003605764 00000 n 
-0003605983 00000 n 
-0003606031 00000 n 
-0003606263 00000 n 
-0003611987 00000 n 
-0003612390 00000 n 
-0003612438 00000 n 
-0003612674 00000 n 
-0003612722 00000 n 
-0003613144 00000 n 
-0003613373 00000 n 
-0003613421 00000 n 
-0003613469 00000 n 
-0003613693 00000 n 
-0003613741 00000 n 
-0003613969 00000 n 
-0003614017 00000 n 
-0003614247 00000 n 
-0003661711 00000 n 
-0003662100 00000 n 
-0003662148 00000 n 
-0003662387 00000 n 
-0003662435 00000 n 
-0003662663 00000 n 
-0003690670 00000 n 
-0003691059 00000 n 
-0003691107 00000 n 
-0003691155 00000 n 
-0003691376 00000 n 
-0003691424 00000 n 
-0003691472 00000 n 
-0003691967 00000 n 
-0003692201 00000 n 
-0003703772 00000 n 
-0003704197 00000 n 
-0003704245 00000 n 
-0003704374 00000 n 
-0003704575 00000 n 
-0003704623 00000 n 
-0003704671 00000 n 
-0003704799 00000 n 
-0003704847 00000 n 
-0003704895 00000 n 
-0003704943 00000 n 
-0003705075 00000 n 
-0003705212 00000 n 
-0003705260 00000 n 
-0003705391 00000 n 
-0003714232 00000 n 
-0003714621 00000 n 
-0003714669 00000 n 
-0003714797 00000 n 
-0003714845 00000 n 
-0003714893 00000 n 
-0003714941 00000 n 
-0003714989 00000 n 
-0003715037 00000 n 
-0003715085 00000 n 
-0003715591 00000 n 
-0003715639 00000 n 
-0003715847 00000 n 
-0003715895 00000 n 
-0003730591 00000 n 
-0003731064 00000 n 
-0003731113 00000 n 
-0003731302 00000 n 
-0003731487 00000 n 
-0003731622 00000 n 
-0003731671 00000 n 
-0003731903 00000 n 
-0003732134 00000 n 
-0003732271 00000 n 
-0003732468 00000 n 
-0003732517 00000 n 
-0003751988 00000 n 
-0003752391 00000 n 
-0003752439 00000 n 
-0003752628 00000 n 
-0003752815 00000 n 
-0003766712 00000 n 
-0003767150 00000 n 
-0003767273 00000 n 
-0003767402 00000 n 
-0003767528 00000 n 
-0003767576 00000 n 
-0003789159 00000 n 
-0003789592 00000 n 
-0003789785 00000 n 
-0003789977 00000 n 
-0003790025 00000 n 
-0003790591 00000 n 
-0003790638 00000 n 
-0003790877 00000 n 
-0003791109 00000 n 
-0003791157 00000 n 
-0003791564 00000 n 
-0003804221 00000 n 
-0003804610 00000 n 
-0003804739 00000 n 
-0003804932 00000 n 
-0003804979 00000 n 
-0003805583 00000 n 
-0003821780 00000 n 
-0003822208 00000 n 
-0003822438 00000 n 
-0003822487 00000 n 
-0003822680 00000 n 
-0003836356 00000 n 
-0003836767 00000 n 
-0003836815 00000 n 
-0003836937 00000 n 
-0003837161 00000 n 
-0003837310 00000 n 
-0004102398 00000 n 
-0004104328 00000 n 
-0004113018 00000 n 
-0004113405 00000 n 
-0004113453 00000 n 
-0004131823 00000 n 
-0004132265 00000 n 
-0004132313 00000 n 
-0004132361 00000 n 
-0004132579 00000 n 
-0004132705 00000 n 
-0004132827 00000 n 
-0004133020 00000 n 
-0004133211 00000 n 
-0004144931 00000 n 
-0004145324 00000 n 
-0004145372 00000 n 
-0004145566 00000 n 
-0004145615 00000 n 
-0004145664 00000 n 
-0004146105 00000 n 
-0004158333 00000 n 
-0004158707 00000 n 
-0004158755 00000 n 
-0004174465 00000 n 
-0004174912 00000 n 
-0004175104 00000 n 
-0004175296 00000 n 
-0004175344 00000 n 
-0004175539 00000 n 
-0004175587 00000 n 
-0004175727 00000 n 
-0004175866 00000 n 
-0004175914 00000 n 
-0004175963 00000 n 
-0004176106 00000 n 
-0004176248 00000 n 
-0004186965 00000 n 
-0004187326 00000 n 
-0004200139 00000 n 
-0004200577 00000 n 
-0004200731 00000 n 
-0004200884 00000 n 
-0004201037 00000 n 
-0004201089 00000 n 
-0004215931 00000 n 
-0004216305 00000 n 
-0004216353 00000 n 
-0004216401 00000 n 
-0004217936 00000 n 
-0004218297 00000 n 
-0004230131 00000 n 
-0004230542 00000 n 
-0004230590 00000 n 
-0004230734 00000 n 
-0004230875 00000 n 
-0004230923 00000 n 
-0004230971 00000 n 
-0004231109 00000 n 
-0004244032 00000 n 
-0004244421 00000 n 
-0004244556 00000 n 
-0004244604 00000 n 
-0004244652 00000 n 
-0004244699 00000 n 
-0004244747 00000 n 
-0004244892 00000 n 
-0004253553 00000 n 
-0004253927 00000 n 
-0004253975 00000 n 
-0004349179 00000 n 
-0004355059 00000 n 
-0004355433 00000 n 
-0004378019 00000 n 
-0004378367 00000 n 
-0004390423 00000 n 
-0004390870 00000 n 
-0004390917 00000 n 
-0004391149 00000 n 
-0004391379 00000 n 
-0004391591 00000 n 
-0004391638 00000 n 
-0004391853 00000 n 
-0004391985 00000 n 
-0004392033 00000 n 
-0004392275 00000 n 
-0004392536 00000 n 
-0004418150 00000 n 
-0004418574 00000 n 
-0004418623 00000 n 
-0004418750 00000 n 
-0004418876 00000 n 
-0004419008 00000 n 
-0004432245 00000 n 
-0004432678 00000 n 
-0004432808 00000 n 
-0004432856 00000 n 
-0004433276 00000 n 
-0004433524 00000 n 
-0004433770 00000 n 
-0004434018 00000 n 
-0004434066 00000 n 
-0004447151 00000 n 
-0004447512 00000 n 
-0004447560 00000 n 
-0004447608 00000 n 
-0004447656 00000 n 
-0004447703 00000 n 
-0004460038 00000 n 
-0004460485 00000 n 
-0004460533 00000 n 
-0004460580 00000 n 
-0004460775 00000 n 
-0004461013 00000 n 
-0004461233 00000 n 
-0004461441 00000 n 
-0004461563 00000 n 
-0004461684 00000 n 
-0004461732 00000 n 
-0004461780 00000 n 
-0004461923 00000 n 
-0004461971 00000 n 
-0004472058 00000 n 
-0004472465 00000 n 
-0004472589 00000 n 
-0004472636 00000 n 
-0004472683 00000 n 
-0004489882 00000 n 
-0004490325 00000 n 
-0004490373 00000 n 
-0004490568 00000 n 
-0004490709 00000 n 
-0004490851 00000 n 
-0004490989 00000 n 
-0004491129 00000 n 
-0004491177 00000 n 
-0004505220 00000 n 
-0004505653 00000 n 
-0004505703 00000 n 
-0004505862 00000 n 
-0004506002 00000 n 
-0004506139 00000 n 
-0004506189 00000 n 
-0004506388 00000 n 
-0004520340 00000 n 
-0004520742 00000 n 
-0004520790 00000 n 
-0004520838 00000 n 
-0004520963 00000 n 
-0004521086 00000 n 
-0004537130 00000 n 
-0004537563 00000 n 
-0004537702 00000 n 
-0004537841 00000 n 
-0004537889 00000 n 
-0004538028 00000 n 
-0004538170 00000 n 
-0004554424 00000 n 
-0004554830 00000 n 
-0004554877 00000 n 
-0004555006 00000 n 
-0004568994 00000 n 
-0004569374 00000 n 
-0004569495 00000 n 
-0004582899 00000 n 
-0004583260 00000 n 
-0004595751 00000 n 
-0004596180 00000 n 
-0004596228 00000 n 
-0004596394 00000 n 
-0004596521 00000 n 
-0004596570 00000 n 
-0004597080 00000 n 
-0004609213 00000 n 
-0004609587 00000 n 
-0004609635 00000 n 
-0004609683 00000 n 
-0004620809 00000 n 
-0004621228 00000 n 
-0004621276 00000 n 
-0004621414 00000 n 
-0004621463 00000 n 
-0004621512 00000 n 
-0004658508 00000 n 
-0004658915 00000 n 
-0004658963 00000 n 
-0004659103 00000 n 
-0004679469 00000 n 
-0004679884 00000 n 
-0004679932 00000 n 
-0004679980 00000 n 
-0004680030 00000 n 
-0004680257 00000 n 
-0004680485 00000 n 
-0004680535 00000 n 
-0004705130 00000 n 
-0004705523 00000 n 
-0004705650 00000 n 
-0004705697 00000 n 
-0004705746 00000 n 
-0004721019 00000 n 
-0004721412 00000 n 
-0004721545 00000 n 
-0004721594 00000 n 
-0004722017 00000 n 
-0004722066 00000 n 
-0004737192 00000 n 
-0004737585 00000 n 
-0004737635 00000 n 
-0004737685 00000 n 
-0004737824 00000 n 
-0004740022 00000 n 
-0004740370 00000 n 
-0004752514 00000 n 
-0004752875 00000 n 
-0004752923 00000 n 
-0004752971 00000 n 
-0004753019 00000 n 
-0004753067 00000 n 
-0004753115 00000 n 
-0004753163 00000 n 
-0004753667 00000 n 
-0004753893 00000 n 
-0004762619 00000 n 
-0004763030 00000 n 
-0004763078 00000 n 
-0004763204 00000 n 
-0004763337 00000 n 
-0004763558 00000 n 
-0004763606 00000 n 
-0004766531 00000 n 
-0004766898 00000 n 
-0004766946 00000 n 
-0004767176 00000 n 
-0004767224 00000 n 
-0004767272 00000 n 
-0004779026 00000 n 
-0004779400 00000 n 
-0004779448 00000 n 
-0004779496 00000 n 
-0004779544 00000 n 
-0004789741 00000 n 
-0004790089 00000 n 
-0004852688 00000 n 
-0004854451 00000 n 
-0004860037 00000 n 
-0004860411 00000 n 
-0004860460 00000 n 
-0004871399 00000 n 
-0004871773 00000 n 
-0004871822 00000 n 
-0004871871 00000 n 
-0004871920 00000 n 
-0004886747 00000 n 
-0004887108 00000 n 
-0004887156 00000 n 
-0004887204 00000 n 
-0004887779 00000 n 
-0004887827 00000 n 
-0004900641 00000 n 
-0004901002 00000 n 
-0004901050 00000 n 
-0004901572 00000 n 
-0004901620 00000 n 
-0004901668 00000 n 
-0004901716 00000 n 
-0004917881 00000 n 
-0004918229 00000 n 
-0004933282 00000 n 
-0004933644 00000 n 
-0004950427 00000 n 
-0004950802 00000 n 
-0004950850 00000 n 
-0004972836 00000 n 
-0004973211 00000 n 
-0004973259 00000 n 
-0004973306 00000 n 
-0004973354 00000 n 
-0004973402 00000 n 
-0004973450 00000 n 
-0004973498 00000 n 
-0004997390 00000 n 
-0004997751 00000 n 
-0004997799 00000 n 
-0005003961 00000 n 
-0005004368 00000 n 
-0005004416 00000 n 
-0005004609 00000 n 
-0005004801 00000 n 
-0005005017 00000 n 
-0005005240 00000 n 
-0005022512 00000 n 
-0005022946 00000 n 
-0005022994 00000 n 
-0005023114 00000 n 
-0005023310 00000 n 
-0005023432 00000 n 
-0005023566 00000 n 
-0005023614 00000 n 
-0005023663 00000 n 
-0005029599 00000 n 
-0005029974 00000 n 
-0005030022 00000 n 
-0005043432 00000 n 
-0005043825 00000 n 
-0005043874 00000 n 
-0005043923 00000 n 
-0005044061 00000 n 
-0005047142 00000 n 
-0005047504 00000 n 
-0005047910 00000 n 
-0005048258 00000 n 
-0005048306 00000 n 
-0005054664 00000 n 
-0005055012 00000 n 
-0005055060 00000 n 
-0005059348 00000 n 
-0005059722 00000 n 
-0005059770 00000 n 
-0005068793 00000 n 
-0005069186 00000 n 
-0005069234 00000 n 
-0005069429 00000 n 
-0005069477 00000 n 
-0005069526 00000 n 
-0005069575 00000 n 
-0005081501 00000 n 
-0005081888 00000 n 
-0005081936 00000 n 
-0005081984 00000 n 
-0005082032 00000 n 
-0005082567 00000 n 
-0005113085 00000 n 
-0005113433 00000 n 
-0005126427 00000 n 
-0005126833 00000 n 
-0005126881 00000 n 
-0005127012 00000 n 
-0005127060 00000 n 
-0005127779 00000 n 
-0005127827 00000 n 
-0005127875 00000 n 
-0005140950 00000 n 
-0005141352 00000 n 
-0005141487 00000 n 
-0005141624 00000 n 
-0005141672 00000 n 
-0005141720 00000 n 
-0005141768 00000 n 
-0005155694 00000 n 
-0005156096 00000 n 
-0005156144 00000 n 
-0005156280 00000 n 
-0005156417 00000 n 
-0005156465 00000 n 
-0005156513 00000 n 
-0005169799 00000 n 
-0005170186 00000 n 
-0005170234 00000 n 
-0005170282 00000 n 
-0005170330 00000 n 
-0005170378 00000 n 
-0005181494 00000 n 
-0005181881 00000 n 
-0005181929 00000 n 
-0005181977 00000 n 
-0005182025 00000 n 
-0005188193 00000 n 
-0005188554 00000 n 
-0005200383 00000 n 
-0005200757 00000 n 
-0005200805 00000 n 
-0005200853 00000 n 
-0005200901 00000 n 
-0005201271 00000 n 
-0005201319 00000 n 
-0005201367 00000 n 
-0005201415 00000 n 
-0005213876 00000 n 
-0005214250 00000 n 
-0005214298 00000 n 
-0005214346 00000 n 
-0005214860 00000 n 
-0005214908 00000 n 
-0005214956 00000 n 
-0005215004 00000 n 
-0005215052 00000 n 
-0005215100 00000 n 
-0005225084 00000 n 
-0005225458 00000 n 
-0005225506 00000 n 
-0005225554 00000 n 
-0005225602 00000 n 
-0005225650 00000 n 
-0005225698 00000 n 
-0005225746 00000 n 
-0005225794 00000 n 
-0005225842 00000 n 
-0005238367 00000 n 
-0005238760 00000 n 
-0005238808 00000 n 
-0005238856 00000 n 
-0005238904 00000 n 
-0005239045 00000 n 
-0005249236 00000 n 
-0005249584 00000 n 
-0005249632 00000 n 
-0005250286 00000 n 
-0005250334 00000 n 
-0005250382 00000 n 
-0005250430 00000 n 
-0005250478 00000 n 
-0005251399 00000 n 
-0005251734 00000 n 
-0005270641 00000 n 
-0005271015 00000 n 
-0005271063 00000 n 
-0005282409 00000 n 
-0005282783 00000 n 
-0005287386 00000 n 
-0005287734 00000 n 
-0005287782 00000 n 
-0005292577 00000 n 
-0005292925 00000 n 
-0005292973 00000 n 
-0005299285 00000 n 
-0005299646 00000 n 
-0005299694 00000 n 
-0005315107 00000 n 
-0005315481 00000 n 
-0005315529 00000 n 
-0005315577 00000 n 
-0005315625 00000 n 
-0005320313 00000 n 
-0005320680 00000 n 
-0005320728 00000 n 
-0005320865 00000 n 
-0005333318 00000 n 
-0005333761 00000 n 
-0005333809 00000 n 
-0005334005 00000 n 
-0005334200 00000 n 
-0005334394 00000 n 
-0005334589 00000 n 
-0005334784 00000 n 
-0005334979 00000 n 
-0005335171 00000 n 
-0005335361 00000 n 
-0005336915 00000 n 
-0005337282 00000 n 
-0005337477 00000 n 
-0005340009 00000 n 
-0005340385 00000 n 
-0005340433 00000 n 
-0005340621 00000 n 
-0005340750 00000 n 
-0005377839 00000 n 
-0005378213 00000 n 
-0005378261 00000 n 
-0005422007 00000 n 
-0005422355 00000 n 
-0005424099 00000 n 
-0005424475 00000 n 
-0005424523 00000 n 
-0005424713 00000 n 
-0005424837 00000 n 
-0005437389 00000 n 
-0005437822 00000 n 
-0005437870 00000 n 
-0005438102 00000 n 
-0005438332 00000 n 
-0005438380 00000 n 
-0005438428 00000 n 
-0005438567 00000 n 
-0005438690 00000 n 
-0005438738 00000 n 
-0005469530 00000 n 
-0005469919 00000 n 
-0005495520 00000 n 
-0005495909 00000 n 
-0005508379 00000 n 
-0005508768 00000 n 
-0005521988 00000 n 
-0005522377 00000 n 
-0005557070 00000 n 
-0005557446 00000 n 
-0005557494 00000 n 
-0005604245 00000 n 
-0005604593 00000 n 
-0005656027 00000 n 
-0005656375 00000 n 
-0005734761 00000 n 
-0005735122 00000 n 
-0005735171 00000 n 
-0005853451 00000 n 
-0005853799 00000 n 
-0005928269 00000 n 
-0005928617 00000 n 
-0005929467 00000 n 
-0005929834 00000 n 
-0005929882 00000 n 
-0005930004 00000 n 
-0005931398 00000 n 
-0005931774 00000 n 
-0005931822 00000 n 
-0005932019 00000 n 
-0005932215 00000 n 
-0005948360 00000 n 
-0005948798 00000 n 
-0005948846 00000 n 
-0005949015 00000 n 
-0005949189 00000 n 
-0005949365 00000 n 
-0005949573 00000 n 
-0005949779 00000 n 
-0005949962 00000 n 
-0005994578 00000 n 
-0005994926 00000 n 
-0006032939 00000 n 
-0006033287 00000 n 
-0006041721 00000 n 
-0006042082 00000 n 
-0006042130 00000 n 
-0006042178 00000 n 
-0006042854 00000 n 
-0006042902 00000 n 
-0006042950 00000 n 
-0006047456 00000 n 
-0006047804 00000 n 
-0006054676 00000 n 
-0006055050 00000 n 
-0006055098 00000 n 
-0006055146 00000 n 
-0006055194 00000 n 
-0006062692 00000 n 
-0006063040 00000 n 
-0006067574 00000 n 
-0006067935 00000 n 
-0006071032 00000 n 
-0006071426 00000 n 
-0006071474 00000 n 
-0006071646 00000 n 
-0006071784 00000 n 
-0006071921 00000 n 
-0006072057 00000 n 
-0006081580 00000 n 
-0006081968 00000 n 
-0006082016 00000 n 
-0006082064 00000 n 
-0006082112 00000 n 
-0006099839 00000 n 
-0006100226 00000 n 
-0006100275 00000 n 
-0006100324 00000 n 
-0006110225 00000 n 
-0006110599 00000 n 
-0006110647 00000 n 
-0006110696 00000 n 
-0006138123 00000 n 
-0006138510 00000 n 
-0006138558 00000 n 
-0006138607 00000 n 
-0006148549 00000 n 
-0006148924 00000 n 
-0006154437 00000 n 
-0006154785 00000 n 
-0006158750 00000 n 
-0006159117 00000 n 
-0006159165 00000 n 
-0006159334 00000 n 
-0006167244 00000 n 
-0006167618 00000 n 
-0006167666 00000 n 
-0006209500 00000 n 
-0006209848 00000 n 
-0006211571 00000 n 
-0006211919 00000 n 
-0006217253 00000 n 
-0006217646 00000 n 
-0006217694 00000 n 
-0006217873 00000 n 
-0006224802 00000 n 
-0006225163 00000 n 
-0006229625 00000 n 
-0006229986 00000 n 
-0006230034 00000 n 
-0006239593 00000 n 
-0006239954 00000 n 
-0006248694 00000 n 
-0006249055 00000 n 
-0006257528 00000 n 
-0006257889 00000 n 
-0006267832 00000 n 
-0006268221 00000 n 
-0006268269 00000 n 
-0006268529 00000 n 
-0006268723 00000 n 
-0006268771 00000 n 
-0006268819 00000 n 
-0006278077 00000 n 
-0006278438 00000 n 
-0006278486 00000 n 
-0006291194 00000 n 
-0006291555 00000 n 
-0006291603 00000 n 
-0006291651 00000 n 
-0006291699 00000 n 
-0006302440 00000 n 
-0006302801 00000 n 
-0006306655 00000 n 
-0006307003 00000 n 
-0006316971 00000 n 
-0006317319 00000 n 
-0006330408 00000 n 
-0006330756 00000 n 
-0006337658 00000 n 
-0006338087 00000 n 
-0006338135 00000 n 
-0006338346 00000 n 
-0006338540 00000 n 
-0006338747 00000 n 
-0006338949 00000 n 
-0006339146 00000 n 
-0006351705 00000 n 
-0006352130 00000 n 
-0006352178 00000 n 
-0006352400 00000 n 
-0006352448 00000 n 
-0006352496 00000 n 
-0006352718 00000 n 
-0006352953 00000 n 
-0006353190 00000 n 
-0006353317 00000 n 
-0006353550 00000 n 
-0006366240 00000 n 
-0006366683 00000 n 
-0006366731 00000 n 
-0006366779 00000 n 
-0006367192 00000 n 
-0006367604 00000 n 
-0006367652 00000 n 
-0006367849 00000 n 
-0006367897 00000 n 
-0006368135 00000 n 
-0006368373 00000 n 
-0006368610 00000 n 
-0006368842 00000 n 
-0006368962 00000 n 
-0006377054 00000 n 
-0006377510 00000 n 
-0006377558 00000 n 
-0006377684 00000 n 
-0006377808 00000 n 
-0006378136 00000 n 
-0006378360 00000 n 
-0006378585 00000 n 
-0006378788 00000 n 
-0006378982 00000 n 
-0006379103 00000 n 
-0006391333 00000 n 
-0006391720 00000 n 
-0006391768 00000 n 
-0006391816 00000 n 
-0006406485 00000 n 
-0006406885 00000 n 
-0006406933 00000 n 
-0006406981 00000 n 
-0006407651 00000 n 
-0006407700 00000 n 
-0006416579 00000 n 
-0006416972 00000 n 
-0006417165 00000 n 
-0006417213 00000 n 
-0006465714 00000 n 
-0006466088 00000 n 
-0006466136 00000 n 
-0006495502 00000 n 
-0006495863 00000 n 
-0006495911 00000 n 
-0006495959 00000 n 
-0006496007 00000 n 
-0006518710 00000 n 
-0006519103 00000 n 
-0006519151 00000 n 
-0006519605 00000 n 
-0006519654 00000 n 
-0006519891 00000 n 
-0006558072 00000 n 
-0006558433 00000 n 
-0006591424 00000 n 
-0006591785 00000 n 
-0006591833 00000 n 
-0006627184 00000 n 
-0006627545 00000 n 
-0006654506 00000 n 
-0006654854 00000 n 
-0006692766 00000 n 
-0006693114 00000 n 
-0006704057 00000 n 
-0006704437 00000 n 
-0006704485 00000 n 
-0006704626 00000 n 
-0006743591 00000 n 
-0006743939 00000 n 
-0006759849 00000 n 
-0006760323 00000 n 
-0006760371 00000 n 
-0006760624 00000 n 
-0006760807 00000 n 
-0006760990 00000 n 
-0006761173 00000 n 
-0006761356 00000 n 
-0006761539 00000 n 
-0006761722 00000 n 
-0006761905 00000 n 
-0006762088 00000 n 
-0006762271 00000 n 
-0006762703 00000 n 
-0006763051 00000 n 
-0006763099 00000 n 
-0006765370 00000 n 
-0006765731 00000 n 
-0006765779 00000 n 
-0006765827 00000 n 
-0006765875 00000 n 
-0006765923 00000 n 
-0006765971 00000 n 
-0006766385 00000 n 
-0006776106 00000 n 
-0006776454 00000 n 
-0006776502 00000 n 
-0006776550 00000 n 
-0006776598 00000 n 
-0006776646 00000 n 
-0006784773 00000 n 
-0006785216 00000 n 
-0006785264 00000 n 
-0006785398 00000 n 
-0006785446 00000 n 
-0006785632 00000 n 
-0006785836 00000 n 
-0006786039 00000 n 
-0006786215 00000 n 
-0006786455 00000 n 
-0006786662 00000 n 
-0006786879 00000 n 
-0006800297 00000 n 
-0006800775 00000 n 
-0006800823 00000 n 
-0006800871 00000 n 
-0006800919 00000 n 
-0006801123 00000 n 
-0006801324 00000 n 
-0006801523 00000 n 
-0006801715 00000 n 
-0006801906 00000 n 
-0006802158 00000 n 
-0006802410 00000 n 
-0006802541 00000 n 
-0006802667 00000 n 
-0006810154 00000 n 
-0006810574 00000 n 
-0006810622 00000 n 
-0006810763 00000 n 
-0006810811 00000 n 
-0006810859 00000 n 
-0006810907 00000 n 
-0006811053 00000 n 
-0006811101 00000 n 
-0006811434 00000 n 
-0006811633 00000 n 
-0006811768 00000 n 
-0006811816 00000 n 
-0006812008 00000 n 
-0006827327 00000 n 
-0006827801 00000 n 
-0006828034 00000 n 
-0006828083 00000 n 
-0006828240 00000 n 
-0006828289 00000 n 
-0006828458 00000 n 
-0006828507 00000 n 
-0006828656 00000 n 
-0006828705 00000 n 
-0006828860 00000 n 
-0006828909 00000 n 
-0006829061 00000 n 
-0006829211 00000 n 
-0006829357 00000 n 
-0006829552 00000 n 
-0006829745 00000 n 
-0006853557 00000 n 
-0006853937 00000 n 
-0006853985 00000 n 
-0006854178 00000 n 
-0006859756 00000 n 
-0006860104 00000 n 
-0006861280 00000 n 
-0006861647 00000 n 
-0006861695 00000 n 
-0006861820 00000 n 
-0006873003 00000 n 
-0006873464 00000 n 
-0006873512 00000 n 
-0006873560 00000 n 
-0006873687 00000 n 
-0006873735 00000 n 
-0006873855 00000 n 
-0006873994 00000 n 
-0006874042 00000 n 
-0006874266 00000 n 
-0006874401 00000 n 
-0006874449 00000 n 
-0006874632 00000 n 
-0006874826 00000 n 
-0006875021 00000 n 
-0006875144 00000 n 
-0006875347 00000 n 
-0006875395 00000 n 
-0006891456 00000 n 
-0006891858 00000 n 
-0006891906 00000 n 
-0006892039 00000 n 
-0006892264 00000 n 
-0006892312 00000 n 
-0006909359 00000 n 
-0006909784 00000 n 
-0006909832 00000 n 
-0006910055 00000 n 
-0006910176 00000 n 
-0006910224 00000 n 
-0006910351 00000 n 
-0006910574 00000 n 
-0006910622 00000 n 
-0006910747 00000 n 
-0006910872 00000 n 
-0006910920 00000 n 
-0006912285 00000 n 
-0006912648 00000 n 
-0006912771 00000 n 
-0006912896 00000 n 
-0006932895 00000 n 
-0006933256 00000 n 
-0006933304 00000 n 
-0006933352 00000 n 
-0006968570 00000 n 
-0006968977 00000 n 
-0006969025 00000 n 
-0006969073 00000 n 
-0006969203 00000 n 
-0006969251 00000 n 
-0006969385 00000 n 
-0006969535 00000 n 
-0006969668 00000 n 
-0006981068 00000 n 
-0006981479 00000 n 
-0006981527 00000 n 
-0006981752 00000 n 
-0006981800 00000 n 
-0006981927 00000 n 
-0006981975 00000 n 
-0006982023 00000 n 
-0006982258 00000 n 
-0006982306 00000 n 
-0006985276 00000 n 
-0006985661 00000 n 
-0006985914 00000 n 
-0006986046 00000 n 
-0006986182 00000 n 
-0006997759 00000 n 
-0006998161 00000 n 
-0006998209 00000 n 
-0006998759 00000 n 
-0006998942 00000 n 
-0006998990 00000 n 
-0006999499 00000 n 
-0006999713 00000 n 
-0006999761 00000 n 
-0006999809 00000 n 
-0006999857 00000 n 
-0007024530 00000 n 
-0007024977 00000 n 
-0007025025 00000 n 
-0007025160 00000 n 
-0007025208 00000 n 
-0007025436 00000 n 
-0007025484 00000 n 
-0007025699 00000 n 
-0007025834 00000 n 
-0007025882 00000 n 
-0007026102 00000 n 
-0007026335 00000 n 
-0007026563 00000 n 
-0007040314 00000 n 
-0007040792 00000 n 
-0007040840 00000 n 
-0007040971 00000 n 
-0007041106 00000 n 
-0007041154 00000 n 
-0007041339 00000 n 
-0007041534 00000 n 
-0007041765 00000 n 
-0007041960 00000 n 
-0007042126 00000 n 
-0007042290 00000 n 
-0007042417 00000 n 
-0007042465 00000 n 
-0007042513 00000 n 
-0007042561 00000 n 
-0007042609 00000 n 
-0007042657 00000 n 
-0007053534 00000 n 
-0007053967 00000 n 
-0007054015 00000 n 
-0007054063 00000 n 
-0007054293 00000 n 
-0007054341 00000 n 
-0007054534 00000 n 
-0007054729 00000 n 
-0007054925 00000 n 
-0007062256 00000 n 
-0007062636 00000 n 
-0007062766 00000 n 
-0007067122 00000 n 
-0007067529 00000 n 
-0007067577 00000 n 
-0007067625 00000 n 
-0007067750 00000 n 
-0007067876 00000 n 
-0007068145 00000 n 
-0007068193 00000 n 
-0007068456 00000 n 
-0007083191 00000 n 
-0007083683 00000 n 
-0007083731 00000 n 
-0007083856 00000 n 
-0007083904 00000 n 
-0007084439 00000 n 
-0007084629 00000 n 
-0007084820 00000 n 
-0007084868 00000 n 
-0007085062 00000 n 
-0007085260 00000 n 
-0007085442 00000 n 
-0007085624 00000 n 
-0007085816 00000 n 
-0007086085 00000 n 
-0007086354 00000 n 
-0007086604 00000 n 
-0007086852 00000 n 
-0007095035 00000 n 
-0007095481 00000 n 
-0007095674 00000 n 
-0007095868 00000 n 
-0007096063 00000 n 
-0007096258 00000 n 
-0007096307 00000 n 
-0007098515 00000 n 
-0007098863 00000 n 
-0007098911 00000 n 
-0007104096 00000 n 
-0007104472 00000 n 
-0007104520 00000 n 
-0007104647 00000 n 
-0007104771 00000 n 
-0007105701 00000 n 
-0007106068 00000 n 
-0007106116 00000 n 
-0007106244 00000 n 
-0007106805 00000 n 
-0007107153 00000 n 
-0007107201 00000 n 
-0007114461 00000 n 
-0007114899 00000 n 
-0007114947 00000 n 
-0007115118 00000 n 
-0007115237 00000 n 
-0007115388 00000 n 
-0007115538 00000 n 
-0007115794 00000 n 
-0007115918 00000 n 
-0007125515 00000 n 
-0007125889 00000 n 
-0007125937 00000 n 
-0007126492 00000 n 
-0007126540 00000 n 
-0007126588 00000 n 
-0007126636 00000 n 
-0007126684 00000 n 
-0007126732 00000 n 
-0007149504 00000 n 
-0007149878 00000 n 
-0007149926 00000 n 
-0007244990 00000 n 
-0007245351 00000 n 
-0007275297 00000 n 
-0007275686 00000 n 
-0007275945 00000 n 
-0007276067 00000 n 
-0007282515 00000 n 
-0007282927 00000 n 
-0007282975 00000 n 
-0007283023 00000 n 
-0007283190 00000 n 
-0007283238 00000 n 
-0007283424 00000 n 
-0007283570 00000 n 
-0007283757 00000 n 
-0007283805 00000 n 
-0007283976 00000 n 
-0007284024 00000 n 
-0007284557 00000 n 
-0007284605 00000 n 
-0007284790 00000 n 
-0007290474 00000 n 
-0007290854 00000 n 
-0007290902 00000 n 
-0007290950 00000 n 
-0007290998 00000 n 
-0007291046 00000 n 
-0007291173 00000 n 
-0007291221 00000 n 
-0007341592 00000 n 
-0007341967 00000 n 
-0007342015 00000 n 
-0007342063 00000 n 
-0007342111 00000 n 
-0007353817 00000 n 
-0007354210 00000 n 
-0007354396 00000 n 
-0007354444 00000 n 
-0007354861 00000 n 
-0007384477 00000 n 
-0007384838 00000 n 
-0007384886 00000 n 
-0007465324 00000 n 
-0007465672 00000 n 
-0007532129 00000 n 
-0007532477 00000 n 
-0007584121 00000 n 
-0007584469 00000 n 
-0007638446 00000 n 
-0007638826 00000 n 
-0007638874 00000 n 
-0007639036 00000 n 
-0007639084 00000 n 
-0007653864 00000 n 
-0007654289 00000 n 
-0007654337 00000 n 
-0007654473 00000 n 
-0007654521 00000 n 
-0007654569 00000 n 
-0007654708 00000 n 
-0007654756 00000 n 
-0007654898 00000 n 
-0007655138 00000 n 
-0007655186 00000 n 
-0007655327 00000 n 
-0007655610 00000 n 
-0007669258 00000 n 
-0007669687 00000 n 
-0007669735 00000 n 
-0007669783 00000 n 
-0007669916 00000 n 
-0007670050 00000 n 
-0007670312 00000 n 
-0007670360 00000 n 
-0007670559 00000 n 
-0007670758 00000 n 
-0007717304 00000 n 
-0007717720 00000 n 
-0007717914 00000 n 
-0007717962 00000 n 
-0007718106 00000 n 
-0007718153 00000 n 
-0007718386 00000 n 
-0007718661 00000 n 
-0007718935 00000 n 
-0007730891 00000 n 
-0007731311 00000 n 
-0007731359 00000 n 
-0007731553 00000 n 
-0007731601 00000 n 
-0007731838 00000 n 
-0007732061 00000 n 
-0007732290 00000 n 
-0007745783 00000 n 
-0007746163 00000 n 
-0007746211 00000 n 
-0007746880 00000 n 
-0007746928 00000 n 
-0007747065 00000 n 
-0007751446 00000 n 
-0007751867 00000 n 
-0007751915 00000 n 
-0007752108 00000 n 
-0007752299 00000 n 
-0007752492 00000 n 
-0007752686 00000 n 
-0007752877 00000 n 
-0007753069 00000 n 
-0007753265 00000 n 
-0007770429 00000 n 
-0007770818 00000 n 
-0007770866 00000 n 
-0007770992 00000 n 
-0007771040 00000 n 
-0007771279 00000 n 
-0007771327 00000 n 
-0007786595 00000 n 
-0007786988 00000 n 
-0007787219 00000 n 
-0007787267 00000 n 
-0007787315 00000 n 
-0007787363 00000 n 
-0007788196 00000 n 
-0007788544 00000 n 
-0007791989 00000 n 
-0007792387 00000 n 
-0007792435 00000 n 
-0007792483 00000 n 
-0007792615 00000 n 
-0007792663 00000 n 
-0007793335 00000 n 
-0007793459 00000 n 
-0007793507 00000 n 
-0007793638 0

<TRUNCATED>

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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-build-configuration/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/mail-lists.html b/hbase-build-configuration/mail-lists.html
index dc55b3e..9262bd1 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-build-configuration/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/plugin-management.html b/hbase-build-configuration/plugin-management.html
index 6999454..803a481 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-build-configuration/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/plugins.html b/hbase-build-configuration/plugins.html
index b972a4a..636d8aa 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-build-configuration/project-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/project-info.html b/hbase-build-configuration/project-info.html
index 6eac623..e4ae110 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-build-configuration/project-summary.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/project-summary.html b/hbase-build-configuration/project-summary.html
index 6f91dc8..fe3a189 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-build-configuration/source-repository.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/source-repository.html b/hbase-build-configuration/source-repository.html
index 021e247..0979366 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-build-configuration/team-list.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/team-list.html b/hbase-build-configuration/team-list.html
index 26c6779..6a01e15 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-shaded-check-invariants/checkstyle.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/checkstyle.html b/hbase-shaded-check-invariants/checkstyle.html
index 3e97116..98c4e1a 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-shaded-check-invariants/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/dependencies.html b/hbase-shaded-check-invariants/dependencies.html
index e99c863..b5e2655 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 5d8e71c..f565722 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -829,7 +829,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 901dad1..cd26206 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 d904265..1420b19 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -810,7 +810,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-shaded-check-invariants/index.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/index.html b/hbase-shaded-check-invariants/index.html
index 241afac..4962c2e 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-shaded-check-invariants/integration.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/integration.html b/hbase-shaded-check-invariants/integration.html
index 8b87397..72787bd 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 7dc4597..985e383 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-shaded-check-invariants/license.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/license.html b/hbase-shaded-check-invariants/license.html
index 9c311a1..4cfa774 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 30acb88..46cde51 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 fa09d40..caf70e2 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-shaded-check-invariants/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/plugins.html b/hbase-shaded-check-invariants/plugins.html
index e49b563..9f56b99 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 0df4134..c121752 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 d951e11..a4762ae 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 4b375b2..f1fc500 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 30b8e04..89530ac 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 dab3e67..b3d6a1a 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/index.html
----------------------------------------------------------------------
diff --git a/index.html b/index.html
index 6718a44..d524392 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/integration.html
----------------------------------------------------------------------
diff --git a/integration.html b/integration.html
index 314b64a..acb46d3 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/issue-tracking.html
----------------------------------------------------------------------
diff --git a/issue-tracking.html b/issue-tracking.html
index 0361bcb..d137557 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/license.html
----------------------------------------------------------------------
diff --git a/license.html b/license.html
index d5b9a69..97ac4d7 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/mail-lists.html
----------------------------------------------------------------------
diff --git a/mail-lists.html b/mail-lists.html
index 0683d8f..b0f0053 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/metrics.html
----------------------------------------------------------------------
diff --git a/metrics.html b/metrics.html
index e4b32e3..c7fc3ea 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/old_news.html
----------------------------------------------------------------------
diff --git a/old_news.html b/old_news.html
index e707c2a..276fbd4 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/plugin-management.html
----------------------------------------------------------------------
diff --git a/plugin-management.html b/plugin-management.html
index 01bfa2d..1f76e80 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/plugins.html
----------------------------------------------------------------------
diff --git a/plugins.html b/plugins.html
index 4b34700..cfc961c 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/poweredbyhbase.html
----------------------------------------------------------------------
diff --git a/poweredbyhbase.html b/poweredbyhbase.html
index bf74105..0cf99b5 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/project-info.html
----------------------------------------------------------------------
diff --git a/project-info.html b/project-info.html
index 5a1710c..0d1c250 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/project-reports.html
----------------------------------------------------------------------
diff --git a/project-reports.html b/project-reports.html
index 5af9f27..cdbf32b 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/project-summary.html
----------------------------------------------------------------------
diff --git a/project-summary.html b/project-summary.html
index 0155940..7ddfe0a 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/pseudo-distributed.html
----------------------------------------------------------------------
diff --git a/pseudo-distributed.html b/pseudo-distributed.html
index 787314e..131ee44 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/replication.html
----------------------------------------------------------------------
diff --git a/replication.html b/replication.html
index 1a12581..1751ec7 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/resources.html
----------------------------------------------------------------------
diff --git a/resources.html b/resources.html
index bd0bfac..78cae15 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/source-repository.html
----------------------------------------------------------------------
diff --git a/source-repository.html b/source-repository.html
index 095d6fe..a31a6ca 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/sponsors.html
----------------------------------------------------------------------
diff --git a/sponsors.html b/sponsors.html
index fad3fb2..30a0b9e 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/supportingprojects.html
----------------------------------------------------------------------
diff --git a/supportingprojects.html b/supportingprojects.html
index f5de38e..938ce63 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/team-list.html
----------------------------------------------------------------------
diff --git a/team-list.html b/team-list.html
index a505393..4869529 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/testdevapidocs/index-all.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/index-all.html b/testdevapidocs/index-all.html
index 999e685..204a741 100644
--- a/testdevapidocs/index-all.html
+++ b/testdevapidocs/index-all.html
@@ -7608,7 +7608,7 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/TestNamespace.html#createTableInSystemNamespace--">createTableInSystemNamespace()</a></span> - Method in class org.apache.hadoop.hbase.<a href="org/apache/hadoop/hbase/TestNamespace.html" title="class in org.apache.hadoop.hbase">TestNamespace</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/replication/TestMasterReplication.html#createTableOnClusters-org.apache.hadoop.hbase.HTableDescriptor-">createTableOnClusters(HTableDescriptor)</a></span> - Method in class org.apache.hadoop.hbase.replication.<a href="org/apache/hadoop/hbase/replication/TestMasterReplication.html" title="class in org.apache.hadoop.hbase.replication">TestMasterReplication</a></dt>
+<dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/replication/TestMasterReplication.html#createTableOnClusters-org.apache.hadoop.hbase.client.TableDescriptor-">createTableOnClusters(TableDescriptor)</a></span> - Method in class org.apache.hadoop.hbase.replication.<a href="org/apache/hadoop/hbase/replication/TestMasterReplication.html" title="class in org.apache.hadoop.hbase.replication">TestMasterReplication</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/backup/TestBackupBase.html#createTables--">createTables()</a></span> - Static method in class org.apache.hadoop.hbase.backup.<a href="org/apache/hadoop/hbase/backup/TestBackupBase.html" title="class in org.apache.hadoop.hbase.backup">TestBackupBase</a></dt>
 <dd>&nbsp;</dd>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 bd845ae..c9a3768 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/backup/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/backup/package-tree.html
@@ -143,8 +143,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/a80edfec/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 b89116f..e6bc9ca 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/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>
+<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>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 b2c46fc..0fa4d48 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/package-tree.html
@@ -578,15 +578,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/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>
-<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/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/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/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/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/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/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/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/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/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/a80edfec/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..451a7e3 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/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>
 <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>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 b2b0943..c6d5c5a 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html
@@ -628,11 +628,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/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/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/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/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/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/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/TestCacheOnWriteInSchema.CacheOnWriteType.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">TestCacheOnWriteInSchema.CacheOnWriteType</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/testdevapidocs/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html b/testdevapidocs/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html
index d234186..1833fc5 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html
@@ -117,7 +117,7 @@ var activeTableTab = "activeTableTab";
 </dl>
 <hr>
 <br>
-<pre>public static class <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.722">TestMasterReplication.CoprocessorCounter</a>
+<pre>public static class <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.719">TestMasterReplication.CoprocessorCounter</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>
 implements org.apache.hadoop.hbase.coprocessor.RegionCoprocessor, org.apache.hadoop.hbase.coprocessor.RegionObserver</pre>
 <div class="block">Use a coprocessor to count puts and deletes. as KVs would be replicated back with the same
@@ -282,7 +282,7 @@ implements org.apache.hadoop.hbase.coprocessor.RegionCoprocessor, org.apache.had
 <ul class="blockList">
 <li class="blockList">
 <h4>nCount</h4>
-<pre>private&nbsp;int <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html#line.723">nCount</a></pre>
+<pre>private&nbsp;int <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html#line.720">nCount</a></pre>
 </li>
 </ul>
 <a name="nDelete">
@@ -291,7 +291,7 @@ implements org.apache.hadoop.hbase.coprocessor.RegionCoprocessor, org.apache.had
 <ul class="blockListLast">
 <li class="blockList">
 <h4>nDelete</h4>
-<pre>private&nbsp;int <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html#line.724">nDelete</a></pre>
+<pre>private&nbsp;int <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html#line.721">nDelete</a></pre>
 </li>
 </ul>
 </li>
@@ -308,7 +308,7 @@ implements org.apache.hadoop.hbase.coprocessor.RegionCoprocessor, org.apache.had
 <ul class="blockListLast">
 <li class="blockList">
 <h4>CoprocessorCounter</h4>
-<pre>public&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html#line.722">CoprocessorCounter</a>()</pre>
+<pre>public&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html#line.719">CoprocessorCounter</a>()</pre>
 </li>
 </ul>
 </li>
@@ -325,7 +325,7 @@ implements org.apache.hadoop.hbase.coprocessor.RegionCoprocessor, org.apache.had
 <ul class="blockList">
 <li class="blockList">
 <h4>getRegionObserver</h4>
-<pre>public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/Optional.html?is-external=true" title="class or interface in java.util">Optional</a>&lt;org.apache.hadoop.hbase.coprocessor.RegionObserver&gt;&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html#line.727">getRegionObserver</a>()</pre>
+<pre>public&nbsp;<a href="http://docs.oracle.com/javase/8/docs/api/java/util/Optional.html?is-external=true" title="class or interface in java.util">Optional</a>&lt;org.apache.hadoop.hbase.coprocessor.RegionObserver&gt;&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html#line.724">getRegionObserver</a>()</pre>
 <dl>
 <dt><span class="overrideSpecifyLabel">Specified by:</span></dt>
 <dd><code>getRegionObserver</code>&nbsp;in interface&nbsp;<code>org.apache.hadoop.hbase.coprocessor.RegionCoprocessor</code></dd>
@@ -338,7 +338,7 @@ implements org.apache.hadoop.hbase.coprocessor.RegionCoprocessor, org.apache.had
 <ul class="blockList">
 <li class="blockList">
 <h4>prePut</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html#line.732">prePut</a>(org.apache.hadoop.hbase.coprocessor.ObserverContext&lt;org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment&gt;&nbsp;e,
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html#line.729">prePut</a>(org.apache.hadoop.hbase.coprocessor.ObserverContext&lt;org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment&gt;&nbsp;e,
                    org.apache.hadoop.hbase.client.Put&nbsp;put,
                    org.apache.hadoop.hbase.wal.WALEdit&nbsp;edit,
                    org.apache.hadoop.hbase.client.Durability&nbsp;durability)
@@ -357,7 +357,7 @@ implements org.apache.hadoop.hbase.coprocessor.RegionCoprocessor, org.apache.had
 <ul class="blockList">
 <li class="blockList">
 <h4>postDelete</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html#line.738">postDelete</a>(org.apache.hadoop.hbase.coprocessor.ObserverContext&lt;org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment&gt;&nbsp;c,
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html#line.735">postDelete</a>(org.apache.hadoop.hbase.coprocessor.ObserverContext&lt;org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment&gt;&nbsp;c,
                        org.apache.hadoop.hbase.client.Delete&nbsp;delete,
                        org.apache.hadoop.hbase.wal.WALEdit&nbsp;edit,
                        org.apache.hadoop.hbase.client.Durability&nbsp;durability)
@@ -376,7 +376,7 @@ implements org.apache.hadoop.hbase.coprocessor.RegionCoprocessor, org.apache.had
 <ul class="blockListLast">
 <li class="blockList">
 <h4>preGetOp</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html#line.744">preGetOp</a>(org.apache.hadoop.hbase.coprocessor.ObserverContext&lt;org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment&gt;&nbsp;c,
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html#line.741">preGetOp</a>(org.apache.hadoop.hbase.coprocessor.ObserverContext&lt;org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment&gt;&nbsp;c,
                      org.apache.hadoop.hbase.client.Get&nbsp;get,
                      <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;org.apache.hadoop.hbase.Cell&gt;&nbsp;result)
               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>


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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/book.html
----------------------------------------------------------------------
diff --git a/book.html b/book.html
index bcfa034..2e61607 100644
--- a/book.html
+++ b/book.html
@@ -1712,7 +1712,7 @@ earlier versions of Hadoop. See the table below for requirements specific to dif
 <td class="tableblock halign-left valign-top"><p class="tableblock">X</p></td>
 </tr>
 <tr>
-<td class="tableblock halign-left valign-top"><p class="tableblock">Hadoop-3.0.0-alphax</p></td>
+<td class="tableblock halign-left valign-top"><p class="tableblock">Hadoop-3.0.0</p></td>
 <td class="tableblock halign-left valign-top"><p class="tableblock">NT</p></td>
 <td class="tableblock halign-left valign-top"><p class="tableblock">NT</p></td>
 <td class="tableblock halign-left valign-top"><p class="tableblock">NT</p></td>
@@ -29982,7 +29982,7 @@ To create the full installable HBase package takes a little bit more work, so re
 Tests may not all pass so you may need to pass <code>-DskipTests</code> unless you are inclined to fix the failing tests.</p>
 </div>
 <div class="paragraph">
-<p>To pick a particular Hadoop 3.y release, you&#8217;d set e.g. <code>-Dhadoop-three.version=3.0.0-alpha1</code>.</p>
+<p>To pick a particular Hadoop 3.y release, you&#8217;d set hadoop-three.version property e.g. <code>-Dhadoop-three.version=3.0.0</code>.</p>
 </div>
 </div>
 <div class="sect3">
@@ -37002,7 +37002,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-17 14:29:54 UTC
+Last updated 2017-12-18 14:29:35 UTC
 </div>
 </div>
 </body>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/bulk-loads.html
----------------------------------------------------------------------
diff --git a/bulk-loads.html b/bulk-loads.html
index cf60ac4..394fee1 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/checkstyle-aggregate.html
----------------------------------------------------------------------
diff --git a/checkstyle-aggregate.html b/checkstyle-aggregate.html
index 5e523f33..0645f7c 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -289,7 +289,7 @@
 <td>3453</td>
 <td>0</td>
 <td>0</td>
-<td>19574</td></tr></table></div>
+<td>19572</td></tr></table></div>
 <div class="section">
 <h2><a name="Files"></a>Files</h2>
 <table border="0" class="table table-striped">
@@ -9277,7 +9277,7 @@
 <td><a href="#org.apache.hadoop.hbase.replication.TestMasterReplication.java">org/apache/hadoop/hbase/replication/TestMasterReplication.java</a></td>
 <td>0</td>
 <td>0</td>
-<td>14</td></tr>
+<td>12</td></tr>
 <tr class="b">
 <td><a href="#org.apache.hadoop.hbase.replication.TestMultiSlaveReplication.java">org/apache/hadoop/hbase/replication/TestMultiSlaveReplication.java</a></td>
 <td>0</td>
@@ -12202,7 +12202,7 @@
 <li>sortStaticImportsAlphabetically: <tt>&quot;true&quot;</tt></li>
 <li>groups: <tt>&quot;*,org.apache.hadoop.hbase.shaded&quot;</tt></li>
 <li>option: <tt>&quot;top&quot;</tt></li></ul></td>
-<td>2244</td>
+<td>2242</td>
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td></tr>
 <tr class="a">
 <td></td>
@@ -12232,12 +12232,12 @@
 <td><a class="externalLink" href="http://checkstyle.sourceforge.net/config_javadoc.html#JavadocTagContinuationIndentation">JavadocTagContinuationIndentation</a>
 <ul>
 <li>offset: <tt>&quot;2&quot;</tt></li></ul></td>
-<td>829</td>
+<td>813</td>
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td></tr>
 <tr class="a">
 <td></td>
 <td><a class="externalLink" href="http://checkstyle.sourceforge.net/config_javadoc.html#NonEmptyAtclauseDescription">NonEmptyAtclauseDescription</a></td>
-<td>4168</td>
+<td>4184</td>
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td></tr>
 <tr class="b">
 <td>misc</td>
@@ -16860,7 +16860,7 @@
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
-<td>JavadocTagContinuationIndentation</td>
+<td>NonEmptyAtclauseDescription</td>
 <td>Javadoc comment at column 26 has parse error. Missed HTML close tag 'arg'. Sometimes it means that close tag missed for one of previous tags.</td>
 <td>43</td></tr></table></div>
 <div class="section">
@@ -17505,7 +17505,7 @@
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
-<td>JavadocTagContinuationIndentation</td>
+<td>NonEmptyAtclauseDescription</td>
 <td>Javadoc comment at column 4 has parse error. Missed HTML close tag 'pre'. Sometimes it means that close tag missed for one of previous tags.</td>
 <td>59</td></tr></table></div>
 <div class="section">
@@ -19677,7 +19677,7 @@
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
-<td>JavadocTagContinuationIndentation</td>
+<td>NonEmptyAtclauseDescription</td>
 <td>Javadoc comment at column 19 has parse error. Details: no viable alternative at input '&lt;code&gt;\n   *   List&lt;Future&lt;' while parsing HTML_TAG</td>
 <td>165</td></tr></table></div>
 <div class="section">
@@ -22881,7 +22881,7 @@
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
-<td>JavadocTagContinuationIndentation</td>
+<td>NonEmptyAtclauseDescription</td>
 <td>Javadoc comment at column 2 has parse error. Unrecognized error from ANTLR parser: null</td>
 <td>83</td></tr>
 <tr class="b">
@@ -24327,7 +24327,7 @@
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
-<td>JavadocTagContinuationIndentation</td>
+<td>NonEmptyAtclauseDescription</td>
 <td>Javadoc comment at column 43 has parse error. Missed HTML close tag 'TableName'. Sometimes it means that close tag missed for one of previous tags.</td>
 <td>179</td></tr>
 <tr class="a">
@@ -40944,7 +40944,7 @@
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
-<td>JavadocTagContinuationIndentation</td>
+<td>NonEmptyAtclauseDescription</td>
 <td>Javadoc comment at column 37 has parse error. Details: no viable alternative at input '&lt;ColumnFamily,' while parsing HTML_ELEMENT</td>
 <td>29</td></tr></table></div>
 <div class="section">
@@ -59148,7 +59148,7 @@
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
-<td>JavadocTagContinuationIndentation</td>
+<td>NonEmptyAtclauseDescription</td>
 <td>Javadoc comment at column 24 has parse error. Details: no viable alternative at input '&lt;key,' while parsing HTML_ELEMENT</td>
 <td>25</td></tr>
 <tr class="b">
@@ -63036,7 +63036,7 @@
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
-<td>JavadocTagContinuationIndentation</td>
+<td>NonEmptyAtclauseDescription</td>
 <td>Javadoc comment at column 2 has parse error. Unrecognized error from ANTLR parser: null</td>
 <td>582</td></tr>
 <tr class="a">
@@ -87246,7 +87246,7 @@
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
-<td>JavadocTagContinuationIndentation</td>
+<td>NonEmptyAtclauseDescription</td>
 <td>Javadoc comment at column 60 has parse error. Missed HTML close tag 'Comparable'. Sometimes it means that close tag missed for one of previous tags.</td>
 <td>28</td></tr>
 <tr class="b">
@@ -91905,7 +91905,7 @@
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
-<td>JavadocTagContinuationIndentation</td>
+<td>NonEmptyAtclauseDescription</td>
 <td>Javadoc comment at column 0 has parse error. Unrecognized error from ANTLR parser: null</td>
 <td>74</td></tr>
 <tr class="b">
@@ -103638,7 +103638,7 @@
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
-<td>JavadocTagContinuationIndentation</td>
+<td>NonEmptyAtclauseDescription</td>
 <td>Javadoc comment at column 33 has parse error. Missed HTML close tag 'number'. Sometimes it means that close tag missed for one of previous tags.</td>
 <td>124</td></tr>
 <tr class="a">
@@ -112871,88 +112871,76 @@
 <th>Line</th></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
-<td>imports</td>
-<td>ImportOrder</td>
-<td>Wrong order for 'org.apache.hadoop.hbase.ClusterStatus.Option' import.</td>
-<td>52</td></tr>
-<tr class="a">
-<td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
-<td>imports</td>
-<td>ImportOrder</td>
-<td>Wrong order for 'org.apache.hadoop.hbase.replication.regionserver.TestSourceFSConfigurationProvider' import.</td>
-<td>70</td></tr>
-<tr class="b">
-<td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 14, expected level should be one of the following: 12, 27.</td>
-<td>230</td></tr>
+<td>227</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be one of the following: 8, 37.</td>
-<td>241</td></tr>
+<td>238</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be one of the following: 8, 44.</td>
-<td>244</td></tr>
+<td>241</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 14, expected level should be one of the following: 12, 27.</td>
-<td>344</td></tr>
+<td>341</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be one of the following: 8, 37.</td>
-<td>364</td></tr>
+<td>361</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be one of the following: 8, 44.</td>
-<td>368</td></tr>
+<td>365</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 14, expected level should be one of the following: 12, 27.</td>
-<td>400</td></tr>
+<td>397</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'array initialization' child have incorrect indentation level 10, expected level should be one of the following: 8, 37.</td>
-<td>410</td></tr>
+<td>407</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 10, expected level should be one of the following: 6, 8.</td>
-<td>696</td></tr>
+<td>693</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 12, expected level should be one of the following: 8, 10.</td>
-<td>698</td></tr>
+<td>695</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 10, expected level should be one of the following: 6, 8.</td>
-<td>699</td></tr>
+<td>696</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 8, expected level should be one of the following: 4, 6.</td>
-<td>700</td></tr></table></div>
+<td>697</td></tr></table></div>
 <div class="section">
 <h3 id="org.apache.hadoop.hbase.replication.TestMultiSlaveReplication.java">org/apache/hadoop/hbase/replication/TestMultiSlaveReplication.java</h3>
 <table border="0" class="table table-striped">
@@ -142443,7 +142431,7 @@
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
-<td>JavadocTagContinuationIndentation</td>
+<td>NonEmptyAtclauseDescription</td>
 <td>Javadoc comment at column 23 has parse error. Details: no viable alternative at input '&lt;expected,' while parsing HTML_ELEMENT</td>
 <td>143</td></tr>
 <tr class="a">
@@ -142668,7 +142656,7 @@
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
-<td>JavadocTagContinuationIndentation</td>
+<td>NonEmptyAtclauseDescription</td>
 <td>Javadoc comment at column 78 has parse error. Details: no viable alternative at input '&lt;Object&gt;, Map&lt;String,' while parsing HTML_TAG</td>
 <td>33</td></tr>
 <tr class="b">
@@ -143295,7 +143283,7 @@
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
-<td>JavadocTagContinuationIndentation</td>
+<td>NonEmptyAtclauseDescription</td>
 <td>Javadoc comment at column 35 has parse error. Missed HTML close tag 'index'. Sometimes it means that close tag missed for one of previous tags.</td>
 <td>794</td></tr>
 <tr class="a">
@@ -147444,7 +147432,7 @@
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
-<td>JavadocTagContinuationIndentation</td>
+<td>NonEmptyAtclauseDescription</td>
 <td>Javadoc comment at column 58 has parse error. Details: no viable alternative at input '&lt;byte[' while parsing HTML_ELEMENT</td>
 <td>421</td></tr>
 <tr class="a">
@@ -148260,7 +148248,7 @@
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
-<td>JavadocTagContinuationIndentation</td>
+<td>NonEmptyAtclauseDescription</td>
 <td>Javadoc comment at column 25 has parse error. Details: no viable alternative at input '&lt;returncode,' while parsing HTML_ELEMENT</td>
 <td>83</td></tr>
 <tr class="b">
@@ -151002,7 +150990,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/checkstyle.rss
----------------------------------------------------------------------
diff --git a/checkstyle.rss b/checkstyle.rss
index 0957a04..69795d6 100644
--- a/checkstyle.rss
+++ b/checkstyle.rss
@@ -26,7 +26,7 @@ under the License.
     <copyright>&#169;2007 - 2017 The Apache Software Foundation</copyright>
     <item>
       <title>File: 3453,
-             Errors: 19574,
+             Errors: 19572,
              Warnings: 0,
              Infos: 0
       </title>
@@ -22623,7 +22623,7 @@ under the License.
                   0
                 </td>
                 <td>
-                  14
+                  12
                 </td>
               </tr>
                           <tr>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/coc.html
----------------------------------------------------------------------
diff --git a/coc.html b/coc.html
index 6b7a63d..83f5734 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/cygwin.html
----------------------------------------------------------------------
diff --git a/cygwin.html b/cygwin.html
index 331a802..b0fc927 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/dependencies.html
----------------------------------------------------------------------
diff --git a/dependencies.html b/dependencies.html
index 9ec5139..fef6031 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/dependency-convergence.html b/dependency-convergence.html
index 03bf5ec..9df37fc 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -999,7 +999,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/dependency-info.html
----------------------------------------------------------------------
diff --git a/dependency-info.html b/dependency-info.html
index 9c8585c..751e2ab 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/dependency-management.html
----------------------------------------------------------------------
diff --git a/dependency-management.html b/dependency-management.html
index 3c22dea..f9a1bf6 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -980,7 +980,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/devapidocs/constant-values.html
----------------------------------------------------------------------
diff --git a/devapidocs/constant-values.html b/devapidocs/constant-values.html
index 42bb705..68cb415 100644
--- a/devapidocs/constant-values.html
+++ b/devapidocs/constant-values.html
@@ -3726,14 +3726,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 17 14:41:52 UTC 2017"</code></td>
+<td class="colLast"><code>"Mon Dec 18 14:41:40 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>"26b69dc45bf3c953905d5ed279e3f691ea802157"</code></td>
+<td class="colLast"><code>"62b591bdc7388e0f1aed480665ba33f1128505b9"</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/a80edfec/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 7b335ff..32f8cf3 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 = "26b69dc45bf3c953905d5ed279e3f691ea802157";<a name="line.11"></a>
+<span class="sourceLineNo">011</span>  public static final String revision = "62b591bdc7388e0f1aed480665ba33f1128505b9";<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 17 14:41:52 UTC 2017";<a name="line.13"></a>
+<span class="sourceLineNo">013</span>  public static final String date = "Mon Dec 18 14:41:40 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 = "17b2bd885a9f8f4e728cc4b3cea18074";<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/a80edfec/export_control.html
----------------------------------------------------------------------
diff --git a/export_control.html b/export_control.html
index 09c9fab..5c80b2e 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/checkstyle.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/checkstyle.html b/hbase-annotations/checkstyle.html
index 786327e..56b692f 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependencies.html b/hbase-annotations/dependencies.html
index 6c31d9f..8fdb2f0 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-convergence.html b/hbase-annotations/dependency-convergence.html
index fc28026..67c250c 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -829,7 +829,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-info.html b/hbase-annotations/dependency-info.html
index 36e4d1a..e4225d4 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-management.html b/hbase-annotations/dependency-management.html
index 5717679..da618c0 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -810,7 +810,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/index.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/index.html b/hbase-annotations/index.html
index 4fd067a..560d2ba 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/integration.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/integration.html b/hbase-annotations/integration.html
index a04a6d2..833a8d5 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/issue-tracking.html b/hbase-annotations/issue-tracking.html
index cc9cc58..5e2403e 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/license.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/license.html b/hbase-annotations/license.html
index a1b3a11..d53365e 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/mail-lists.html b/hbase-annotations/mail-lists.html
index 00d7fc4..c405aac 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/plugin-management.html b/hbase-annotations/plugin-management.html
index a967b99..564dd26 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/plugins.html b/hbase-annotations/plugins.html
index 94b111b..5aca4a3 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/project-info.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-info.html b/hbase-annotations/project-info.html
index 6f32916..1e4cc22 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/project-reports.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-reports.html b/hbase-annotations/project-reports.html
index e737204..a9938dc 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/project-summary.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-summary.html b/hbase-annotations/project-summary.html
index f3cd08b..63189e7 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/source-repository.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/source-repository.html b/hbase-annotations/source-repository.html
index 51123fc..6bcd90c 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-annotations/team-list.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/team-list.html b/hbase-annotations/team-list.html
index 54bb10e..fc35347 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-build-configuration/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependencies.html b/hbase-build-configuration/dependencies.html
index 5490d27..1552d64 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-build-configuration/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-convergence.html b/hbase-build-configuration/dependency-convergence.html
index b7b85b6..3101f94 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -829,7 +829,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-build-configuration/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-info.html b/hbase-build-configuration/dependency-info.html
index 943af4d..e13f811 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-build-configuration/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-management.html b/hbase-build-configuration/dependency-management.html
index 3fc80e6..242f941 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -810,7 +810,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 0eacf55..389695c 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 c44c172..1730745 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -829,7 +829,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 332114f..c42c1b5 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 f21cfd6..2171d95 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -810,7 +810,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 da959b2..9a551aa 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 7202be3..b5fd052 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -829,7 +829,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 e60ceb3..daeec2b 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 48d7ed8..b5690f8 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -810,7 +810,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 4f894dc..e5e541a 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 8b4602c..8ea6137 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 2167315..2eaf10d 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 b408f78..5ec67f5 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 8ccbe2e..64a2bc3 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 e56da00..d87288f 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 202b8c3..368d356 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 e8e368b..e3728e6 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 61fde18..0165902 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 d003db3..50c8fb3 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 c0aa4b2..179a31e 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 7362921..fa77e05 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 d604328..2ed2b24 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -4169,7 +4169,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 df02789..cc03382 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -829,7 +829,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 7453e19..cc20a14 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 


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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/testdevapidocs/src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html b/testdevapidocs/src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html
index cccfe2e..295ed45 100644
--- a/testdevapidocs/src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html
+++ b/testdevapidocs/src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.CoprocessorCounter.html
@@ -6,7 +6,7 @@
 </head>
 <body>
 <div class="sourceContainer">
-<pre><span class="sourceLineNo">001</span>/*<a name="line.1"></a>
+<pre><span class="sourceLineNo">001</span>/**<a name="line.1"></a>
 <span class="sourceLineNo">002</span> * Licensed to the Apache Software Foundation (ASF) under one<a name="line.2"></a>
 <span class="sourceLineNo">003</span> * or more contributor license agreements.  See the NOTICE file<a name="line.3"></a>
 <span class="sourceLineNo">004</span> * distributed with this work for additional information<a name="line.4"></a>
@@ -46,722 +46,719 @@
 <span class="sourceLineNo">038</span>import org.apache.hadoop.fs.Path;<a name="line.38"></a>
 <span class="sourceLineNo">039</span>import org.apache.hadoop.hbase.Cell;<a name="line.39"></a>
 <span class="sourceLineNo">040</span>import org.apache.hadoop.hbase.ClusterStatus;<a name="line.40"></a>
-<span class="sourceLineNo">041</span>import org.apache.hadoop.hbase.HBaseConfiguration;<a name="line.41"></a>
-<span class="sourceLineNo">042</span>import org.apache.hadoop.hbase.HBaseTestingUtility;<a name="line.42"></a>
-<span class="sourceLineNo">043</span>import org.apache.hadoop.hbase.HColumnDescriptor;<a name="line.43"></a>
+<span class="sourceLineNo">041</span>import org.apache.hadoop.hbase.ClusterStatus.Option;<a name="line.41"></a>
+<span class="sourceLineNo">042</span>import org.apache.hadoop.hbase.HBaseConfiguration;<a name="line.42"></a>
+<span class="sourceLineNo">043</span>import org.apache.hadoop.hbase.HBaseTestingUtility;<a name="line.43"></a>
 <span class="sourceLineNo">044</span>import org.apache.hadoop.hbase.HConstants;<a name="line.44"></a>
-<span class="sourceLineNo">045</span>import org.apache.hadoop.hbase.HTableDescriptor;<a name="line.45"></a>
-<span class="sourceLineNo">046</span>import org.apache.hadoop.hbase.KeyValue;<a name="line.46"></a>
-<span class="sourceLineNo">047</span>import org.apache.hadoop.hbase.MiniHBaseCluster;<a name="line.47"></a>
-<span class="sourceLineNo">048</span>import org.apache.hadoop.hbase.ServerLoad;<a name="line.48"></a>
-<span class="sourceLineNo">049</span>import org.apache.hadoop.hbase.ServerName;<a name="line.49"></a>
-<span class="sourceLineNo">050</span>import org.apache.hadoop.hbase.TableName;<a name="line.50"></a>
-<span class="sourceLineNo">051</span>import org.apache.hadoop.hbase.Waiter;<a name="line.51"></a>
-<span class="sourceLineNo">052</span>import org.apache.hadoop.hbase.ClusterStatus.Option;<a name="line.52"></a>
-<span class="sourceLineNo">053</span>import org.apache.hadoop.hbase.client.Admin;<a name="line.53"></a>
-<span class="sourceLineNo">054</span>import org.apache.hadoop.hbase.client.ConnectionFactory;<a name="line.54"></a>
-<span class="sourceLineNo">055</span>import org.apache.hadoop.hbase.client.Delete;<a name="line.55"></a>
-<span class="sourceLineNo">056</span>import org.apache.hadoop.hbase.client.Durability;<a name="line.56"></a>
-<span class="sourceLineNo">057</span>import org.apache.hadoop.hbase.client.Get;<a name="line.57"></a>
-<span class="sourceLineNo">058</span>import org.apache.hadoop.hbase.client.Put;<a name="line.58"></a>
-<span class="sourceLineNo">059</span>import org.apache.hadoop.hbase.client.Result;<a name="line.59"></a>
-<span class="sourceLineNo">060</span>import org.apache.hadoop.hbase.client.Table;<a name="line.60"></a>
-<span class="sourceLineNo">061</span>import org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil;<a name="line.61"></a>
-<span class="sourceLineNo">062</span>import org.apache.hadoop.hbase.coprocessor.CoprocessorHost;<a name="line.62"></a>
-<span class="sourceLineNo">063</span>import org.apache.hadoop.hbase.coprocessor.ObserverContext;<a name="line.63"></a>
-<span class="sourceLineNo">064</span>import org.apache.hadoop.hbase.coprocessor.RegionCoprocessor;<a name="line.64"></a>
-<span class="sourceLineNo">065</span>import org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment;<a name="line.65"></a>
-<span class="sourceLineNo">066</span>import org.apache.hadoop.hbase.coprocessor.RegionObserver;<a name="line.66"></a>
-<span class="sourceLineNo">067</span>import org.apache.hadoop.hbase.regionserver.HRegion;<a name="line.67"></a>
-<span class="sourceLineNo">068</span>import org.apache.hadoop.hbase.regionserver.wal.WALActionsListener;<a name="line.68"></a>
-<span class="sourceLineNo">069</span>import org.apache.hadoop.hbase.wal.WALEdit;<a name="line.69"></a>
+<span class="sourceLineNo">045</span>import org.apache.hadoop.hbase.KeyValue;<a name="line.45"></a>
+<span class="sourceLineNo">046</span>import org.apache.hadoop.hbase.MiniHBaseCluster;<a name="line.46"></a>
+<span class="sourceLineNo">047</span>import org.apache.hadoop.hbase.ServerLoad;<a name="line.47"></a>
+<span class="sourceLineNo">048</span>import org.apache.hadoop.hbase.ServerName;<a name="line.48"></a>
+<span class="sourceLineNo">049</span>import org.apache.hadoop.hbase.TableName;<a name="line.49"></a>
+<span class="sourceLineNo">050</span>import org.apache.hadoop.hbase.Waiter;<a name="line.50"></a>
+<span class="sourceLineNo">051</span>import org.apache.hadoop.hbase.client.Admin;<a name="line.51"></a>
+<span class="sourceLineNo">052</span>import org.apache.hadoop.hbase.client.ColumnFamilyDescriptorBuilder;<a name="line.52"></a>
+<span class="sourceLineNo">053</span>import org.apache.hadoop.hbase.client.ConnectionFactory;<a name="line.53"></a>
+<span class="sourceLineNo">054</span>import org.apache.hadoop.hbase.client.Delete;<a name="line.54"></a>
+<span class="sourceLineNo">055</span>import org.apache.hadoop.hbase.client.Durability;<a name="line.55"></a>
+<span class="sourceLineNo">056</span>import org.apache.hadoop.hbase.client.Get;<a name="line.56"></a>
+<span class="sourceLineNo">057</span>import org.apache.hadoop.hbase.client.Put;<a name="line.57"></a>
+<span class="sourceLineNo">058</span>import org.apache.hadoop.hbase.client.Result;<a name="line.58"></a>
+<span class="sourceLineNo">059</span>import org.apache.hadoop.hbase.client.Table;<a name="line.59"></a>
+<span class="sourceLineNo">060</span>import org.apache.hadoop.hbase.client.TableDescriptor;<a name="line.60"></a>
+<span class="sourceLineNo">061</span>import org.apache.hadoop.hbase.client.TableDescriptorBuilder;<a name="line.61"></a>
+<span class="sourceLineNo">062</span>import org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil;<a name="line.62"></a>
+<span class="sourceLineNo">063</span>import org.apache.hadoop.hbase.coprocessor.CoprocessorHost;<a name="line.63"></a>
+<span class="sourceLineNo">064</span>import org.apache.hadoop.hbase.coprocessor.ObserverContext;<a name="line.64"></a>
+<span class="sourceLineNo">065</span>import org.apache.hadoop.hbase.coprocessor.RegionCoprocessor;<a name="line.65"></a>
+<span class="sourceLineNo">066</span>import org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment;<a name="line.66"></a>
+<span class="sourceLineNo">067</span>import org.apache.hadoop.hbase.coprocessor.RegionObserver;<a name="line.67"></a>
+<span class="sourceLineNo">068</span>import org.apache.hadoop.hbase.regionserver.HRegion;<a name="line.68"></a>
+<span class="sourceLineNo">069</span>import org.apache.hadoop.hbase.regionserver.wal.WALActionsListener;<a name="line.69"></a>
 <span class="sourceLineNo">070</span>import org.apache.hadoop.hbase.replication.regionserver.TestSourceFSConfigurationProvider;<a name="line.70"></a>
 <span class="sourceLineNo">071</span>import org.apache.hadoop.hbase.testclassification.LargeTests;<a name="line.71"></a>
 <span class="sourceLineNo">072</span>import org.apache.hadoop.hbase.testclassification.ReplicationTests;<a name="line.72"></a>
 <span class="sourceLineNo">073</span>import org.apache.hadoop.hbase.tool.LoadIncrementalHFiles;<a name="line.73"></a>
 <span class="sourceLineNo">074</span>import org.apache.hadoop.hbase.util.Bytes;<a name="line.74"></a>
 <span class="sourceLineNo">075</span>import org.apache.hadoop.hbase.util.HFileTestUtil;<a name="line.75"></a>
-<span class="sourceLineNo">076</span>import org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster;<a name="line.76"></a>
-<span class="sourceLineNo">077</span>import org.apache.hadoop.hbase.zookeeper.ZKUtil;<a name="line.77"></a>
-<span class="sourceLineNo">078</span>import org.apache.hadoop.hbase.zookeeper.ZKWatcher;<a name="line.78"></a>
-<span class="sourceLineNo">079</span>import org.apache.hadoop.hbase.zookeeper.ZNodePaths;<a name="line.79"></a>
-<span class="sourceLineNo">080</span>import org.junit.After;<a name="line.80"></a>
-<span class="sourceLineNo">081</span>import org.junit.Before;<a name="line.81"></a>
-<span class="sourceLineNo">082</span>import org.junit.Test;<a name="line.82"></a>
-<span class="sourceLineNo">083</span>import org.junit.experimental.categories.Category;<a name="line.83"></a>
-<span class="sourceLineNo">084</span><a name="line.84"></a>
-<span class="sourceLineNo">085</span>@Category({ReplicationTests.class, LargeTests.class})<a name="line.85"></a>
-<span class="sourceLineNo">086</span>public class TestMasterReplication {<a name="line.86"></a>
-<span class="sourceLineNo">087</span><a name="line.87"></a>
-<span class="sourceLineNo">088</span>  private static final Log LOG = LogFactory.getLog(TestReplicationBase.class);<a name="line.88"></a>
-<span class="sourceLineNo">089</span><a name="line.89"></a>
-<span class="sourceLineNo">090</span>  private Configuration baseConfiguration;<a name="line.90"></a>
-<span class="sourceLineNo">091</span><a name="line.91"></a>
-<span class="sourceLineNo">092</span>  private HBaseTestingUtility[] utilities;<a name="line.92"></a>
-<span class="sourceLineNo">093</span>  private Configuration[] configurations;<a name="line.93"></a>
-<span class="sourceLineNo">094</span>  private MiniZooKeeperCluster miniZK;<a name="line.94"></a>
-<span class="sourceLineNo">095</span><a name="line.95"></a>
-<span class="sourceLineNo">096</span>  private static final long SLEEP_TIME = 1000;<a name="line.96"></a>
-<span class="sourceLineNo">097</span>  private static final int NB_RETRIES = 120;<a name="line.97"></a>
-<span class="sourceLineNo">098</span><a name="line.98"></a>
-<span class="sourceLineNo">099</span>  private static final TableName tableName = TableName.valueOf("test");<a name="line.99"></a>
-<span class="sourceLineNo">100</span>  private static final byte[] famName = Bytes.toBytes("f");<a name="line.100"></a>
-<span class="sourceLineNo">101</span>  private static final byte[] famName1 = Bytes.toBytes("f1");<a name="line.101"></a>
-<span class="sourceLineNo">102</span>  private static final byte[] row = Bytes.toBytes("row");<a name="line.102"></a>
-<span class="sourceLineNo">103</span>  private static final byte[] row1 = Bytes.toBytes("row1");<a name="line.103"></a>
-<span class="sourceLineNo">104</span>  private static final byte[] row2 = Bytes.toBytes("row2");<a name="line.104"></a>
-<span class="sourceLineNo">105</span>  private static final byte[] row3 = Bytes.toBytes("row3");<a name="line.105"></a>
-<span class="sourceLineNo">106</span>  private static final byte[] row4 = Bytes.toBytes("row4");<a name="line.106"></a>
-<span class="sourceLineNo">107</span>  private static final byte[] noRepfamName = Bytes.toBytes("norep");<a name="line.107"></a>
-<span class="sourceLineNo">108</span><a name="line.108"></a>
-<span class="sourceLineNo">109</span>  private static final byte[] count = Bytes.toBytes("count");<a name="line.109"></a>
-<span class="sourceLineNo">110</span>  private static final byte[] put = Bytes.toBytes("put");<a name="line.110"></a>
-<span class="sourceLineNo">111</span>  private static final byte[] delete = Bytes.toBytes("delete");<a name="line.111"></a>
-<span class="sourceLineNo">112</span><a name="line.112"></a>
-<span class="sourceLineNo">113</span>  private HTableDescriptor table;<a name="line.113"></a>
-<span class="sourceLineNo">114</span><a name="line.114"></a>
-<span class="sourceLineNo">115</span>  @Before<a name="line.115"></a>
-<span class="sourceLineNo">116</span>  public void setUp() throws Exception {<a name="line.116"></a>
-<span class="sourceLineNo">117</span>    baseConfiguration = HBaseConfiguration.create();<a name="line.117"></a>
-<span class="sourceLineNo">118</span>    // smaller block size and capacity to trigger more operations<a name="line.118"></a>
-<span class="sourceLineNo">119</span>    // and test them<a name="line.119"></a>
-<span class="sourceLineNo">120</span>    baseConfiguration.setInt("hbase.regionserver.hlog.blocksize", 1024 * 20);<a name="line.120"></a>
-<span class="sourceLineNo">121</span>    baseConfiguration.setInt("replication.source.size.capacity", 1024);<a name="line.121"></a>
-<span class="sourceLineNo">122</span>    baseConfiguration.setLong("replication.source.sleepforretries", 100);<a name="line.122"></a>
-<span class="sourceLineNo">123</span>    baseConfiguration.setInt("hbase.regionserver.maxlogs", 10);<a name="line.123"></a>
-<span class="sourceLineNo">124</span>    baseConfiguration.setLong("hbase.master.logcleaner.ttl", 10);<a name="line.124"></a>
-<span class="sourceLineNo">125</span>    baseConfiguration.setBoolean(HConstants.REPLICATION_BULKLOAD_ENABLE_KEY, true);<a name="line.125"></a>
-<span class="sourceLineNo">126</span>    baseConfiguration.set("hbase.replication.source.fs.conf.provider",<a name="line.126"></a>
-<span class="sourceLineNo">127</span>      TestSourceFSConfigurationProvider.class.getCanonicalName());<a name="line.127"></a>
-<span class="sourceLineNo">128</span>    baseConfiguration.set(HConstants.REPLICATION_CLUSTER_ID, "12345");<a name="line.128"></a>
-<span class="sourceLineNo">129</span>    baseConfiguration.setLong(HConstants.THREAD_WAKE_FREQUENCY, 100);<a name="line.129"></a>
-<span class="sourceLineNo">130</span>    baseConfiguration.setStrings(<a name="line.130"></a>
-<span class="sourceLineNo">131</span>        CoprocessorHost.USER_REGION_COPROCESSOR_CONF_KEY,<a name="line.131"></a>
-<span class="sourceLineNo">132</span>        CoprocessorCounter.class.getName());<a name="line.132"></a>
-<span class="sourceLineNo">133</span><a name="line.133"></a>
-<span class="sourceLineNo">134</span>    table = new HTableDescriptor(tableName);<a name="line.134"></a>
-<span class="sourceLineNo">135</span>    HColumnDescriptor fam = new HColumnDescriptor(famName);<a name="line.135"></a>
-<span class="sourceLineNo">136</span>    fam.setScope(HConstants.REPLICATION_SCOPE_GLOBAL);<a name="line.136"></a>
-<span class="sourceLineNo">137</span>    table.addFamily(fam);<a name="line.137"></a>
-<span class="sourceLineNo">138</span>    fam = new HColumnDescriptor(famName1);<a name="line.138"></a>
-<span class="sourceLineNo">139</span>    fam.setScope(HConstants.REPLICATION_SCOPE_GLOBAL);<a name="line.139"></a>
-<span class="sourceLineNo">140</span>    table.addFamily(fam);<a name="line.140"></a>
-<span class="sourceLineNo">141</span>    fam = new HColumnDescriptor(noRepfamName);<a name="line.141"></a>
-<span class="sourceLineNo">142</span>    table.addFamily(fam);<a name="line.142"></a>
-<span class="sourceLineNo">143</span>  }<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>   * It tests the replication scenario involving 0 -&gt; 1 -&gt; 0. It does it by<a name="line.146"></a>
-<span class="sourceLineNo">147</span>   * adding and deleting a row to a table in each cluster, checking if it's<a name="line.147"></a>
-<span class="sourceLineNo">148</span>   * replicated. It also tests that the puts and deletes are not replicated back<a name="line.148"></a>
-<span class="sourceLineNo">149</span>   * to the originating cluster.<a name="line.149"></a>
-<span class="sourceLineNo">150</span>   */<a name="line.150"></a>
-<span class="sourceLineNo">151</span>  @Test(timeout = 300000)<a name="line.151"></a>
-<span class="sourceLineNo">152</span>  public void testCyclicReplication1() throws Exception {<a name="line.152"></a>
-<span class="sourceLineNo">153</span>    LOG.info("testSimplePutDelete");<a name="line.153"></a>
-<span class="sourceLineNo">154</span>    int numClusters = 2;<a name="line.154"></a>
-<span class="sourceLineNo">155</span>    Table[] htables = null;<a name="line.155"></a>
-<span class="sourceLineNo">156</span>    try {<a name="line.156"></a>
-<span class="sourceLineNo">157</span>      htables = setUpClusterTablesAndPeers(numClusters);<a name="line.157"></a>
-<span class="sourceLineNo">158</span><a name="line.158"></a>
-<span class="sourceLineNo">159</span>      int[] expectedCounts = new int[] { 2, 2 };<a name="line.159"></a>
-<span class="sourceLineNo">160</span><a name="line.160"></a>
-<span class="sourceLineNo">161</span>      // add rows to both clusters,<a name="line.161"></a>
-<span class="sourceLineNo">162</span>      // make sure they are both replication<a name="line.162"></a>
-<span class="sourceLineNo">163</span>      putAndWait(row, famName, htables[0], htables[1]);<a name="line.163"></a>
-<span class="sourceLineNo">164</span>      putAndWait(row1, famName, htables[1], htables[0]);<a name="line.164"></a>
-<span class="sourceLineNo">165</span>      validateCounts(htables, put, expectedCounts);<a name="line.165"></a>
-<span class="sourceLineNo">166</span><a name="line.166"></a>
-<span class="sourceLineNo">167</span>      deleteAndWait(row, htables[0], htables[1]);<a name="line.167"></a>
-<span class="sourceLineNo">168</span>      deleteAndWait(row1, htables[1], htables[0]);<a name="line.168"></a>
-<span class="sourceLineNo">169</span>      validateCounts(htables, delete, expectedCounts);<a name="line.169"></a>
-<span class="sourceLineNo">170</span>    } finally {<a name="line.170"></a>
-<span class="sourceLineNo">171</span>      close(htables);<a name="line.171"></a>
-<span class="sourceLineNo">172</span>      shutDownMiniClusters();<a name="line.172"></a>
-<span class="sourceLineNo">173</span>    }<a name="line.173"></a>
-<span class="sourceLineNo">174</span>  }<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>   * Tests the replication scenario 0 -&gt; 0. By default<a name="line.177"></a>
-<span class="sourceLineNo">178</span>   * {@link BaseReplicationEndpoint#canReplicateToSameCluster()} returns false, so the<a name="line.178"></a>
-<span class="sourceLineNo">179</span>   * ReplicationSource should terminate, and no further logs should get enqueued<a name="line.179"></a>
-<span class="sourceLineNo">180</span>   */<a name="line.180"></a>
-<span class="sourceLineNo">181</span>  @Test(timeout = 300000)<a name="line.181"></a>
-<span class="sourceLineNo">182</span>  public void testLoopedReplication() throws Exception {<a name="line.182"></a>
-<span class="sourceLineNo">183</span>    LOG.info("testLoopedReplication");<a name="line.183"></a>
-<span class="sourceLineNo">184</span>    startMiniClusters(1);<a name="line.184"></a>
-<span class="sourceLineNo">185</span>    createTableOnClusters(table);<a name="line.185"></a>
-<span class="sourceLineNo">186</span>    addPeer("1", 0, 0);<a name="line.186"></a>
-<span class="sourceLineNo">187</span>    Thread.sleep(SLEEP_TIME);<a name="line.187"></a>
-<span class="sourceLineNo">188</span><a name="line.188"></a>
-<span class="sourceLineNo">189</span>    // wait for source to terminate<a name="line.189"></a>
-<span class="sourceLineNo">190</span>    final ServerName rsName = utilities[0].getHBaseCluster().getRegionServer(0).getServerName();<a name="line.190"></a>
-<span class="sourceLineNo">191</span>    Waiter.waitFor(baseConfiguration, 10000, new Waiter.Predicate&lt;Exception&gt;() {<a name="line.191"></a>
-<span class="sourceLineNo">192</span>      @Override<a name="line.192"></a>
-<span class="sourceLineNo">193</span>      public boolean evaluate() throws Exception {<a name="line.193"></a>
-<span class="sourceLineNo">194</span>        ClusterStatus clusterStatus = utilities[0].getAdmin()<a name="line.194"></a>
-<span class="sourceLineNo">195</span>            .getClusterStatus(EnumSet.of(Option.LIVE_SERVERS));<a name="line.195"></a>
-<span class="sourceLineNo">196</span>        ServerLoad serverLoad = clusterStatus.getLoad(rsName);<a name="line.196"></a>
-<span class="sourceLineNo">197</span>        List&lt;ReplicationLoadSource&gt; replicationLoadSourceList =<a name="line.197"></a>
-<span class="sourceLineNo">198</span>            serverLoad.getReplicationLoadSourceList();<a name="line.198"></a>
-<span class="sourceLineNo">199</span>        return replicationLoadSourceList.isEmpty();<a name="line.199"></a>
-<span class="sourceLineNo">200</span>      }<a name="line.200"></a>
-<span class="sourceLineNo">201</span>    });<a name="line.201"></a>
-<span class="sourceLineNo">202</span><a name="line.202"></a>
-<span class="sourceLineNo">203</span>    Table[] htables = getHTablesOnClusters(tableName);<a name="line.203"></a>
-<span class="sourceLineNo">204</span>    putAndWait(row, famName, htables[0], htables[0]);<a name="line.204"></a>
-<span class="sourceLineNo">205</span>    rollWALAndWait(utilities[0], table.getTableName(), row);<a name="line.205"></a>
-<span class="sourceLineNo">206</span>    ZKWatcher zkw = utilities[0].getZooKeeperWatcher();<a name="line.206"></a>
-<span class="sourceLineNo">207</span>    String queuesZnode = ZNodePaths.joinZNode(zkw.getZNodePaths().baseZNode,<a name="line.207"></a>
-<span class="sourceLineNo">208</span>      ZNodePaths.joinZNode("replication", "rs"));<a name="line.208"></a>
-<span class="sourceLineNo">209</span>    List&lt;String&gt; listChildrenNoWatch =<a name="line.209"></a>
-<span class="sourceLineNo">210</span>        ZKUtil.listChildrenNoWatch(zkw, ZNodePaths.joinZNode(queuesZnode, rsName.toString()));<a name="line.210"></a>
-<span class="sourceLineNo">211</span>    assertEquals(0, listChildrenNoWatch.size());<a name="line.211"></a>
-<span class="sourceLineNo">212</span>  }<a name="line.212"></a>
-<span class="sourceLineNo">213</span><a name="line.213"></a>
-<span class="sourceLineNo">214</span>  /**<a name="line.214"></a>
-<span class="sourceLineNo">215</span>   * It tests the replication scenario involving 0 -&gt; 1 -&gt; 0. It does it by bulk loading a set of<a name="line.215"></a>
-<span class="sourceLineNo">216</span>   * HFiles to a table in each cluster, checking if it's replicated.<a name="line.216"></a>
-<span class="sourceLineNo">217</span>   */<a name="line.217"></a>
-<span class="sourceLineNo">218</span>  @Test(timeout = 300000)<a name="line.218"></a>
-<span class="sourceLineNo">219</span>  public void testHFileCyclicReplication() throws Exception {<a name="line.219"></a>
-<span class="sourceLineNo">220</span>    LOG.info("testHFileCyclicReplication");<a name="line.220"></a>
-<span class="sourceLineNo">221</span>    int numClusters = 2;<a name="line.221"></a>
-<span class="sourceLineNo">222</span>    Table[] htables = null;<a name="line.222"></a>
-<span class="sourceLineNo">223</span>    try {<a name="line.223"></a>
-<span class="sourceLineNo">224</span>      htables = setUpClusterTablesAndPeers(numClusters);<a name="line.224"></a>
-<span class="sourceLineNo">225</span><a name="line.225"></a>
-<span class="sourceLineNo">226</span>      // Load 100 rows for each hfile range in cluster '0' and validate whether its been replicated<a name="line.226"></a>
-<span class="sourceLineNo">227</span>      // to cluster '1'.<a name="line.227"></a>
-<span class="sourceLineNo">228</span>      byte[][][] hfileRanges =<a name="line.228"></a>
-<span class="sourceLineNo">229</span>          new byte[][][] { new byte[][] { Bytes.toBytes("aaaa"), Bytes.toBytes("cccc") },<a name="line.229"></a>
-<span class="sourceLineNo">230</span>              new byte[][] { Bytes.toBytes("ddd"), Bytes.toBytes("fff") }, };<a name="line.230"></a>
-<span class="sourceLineNo">231</span>      int numOfRows = 100;<a name="line.231"></a>
-<span class="sourceLineNo">232</span>      int[] expectedCounts =<a name="line.232"></a>
-<span class="sourceLineNo">233</span>          new int[] { hfileRanges.length * numOfRows, hfileRanges.length * numOfRows };<a name="line.233"></a>
+<span class="sourceLineNo">076</span>import org.apache.hadoop.hbase.wal.WALEdit;<a name="line.76"></a>
+<span class="sourceLineNo">077</span>import org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster;<a name="line.77"></a>
+<span class="sourceLineNo">078</span>import org.apache.hadoop.hbase.zookeeper.ZKUtil;<a name="line.78"></a>
+<span class="sourceLineNo">079</span>import org.apache.hadoop.hbase.zookeeper.ZKWatcher;<a name="line.79"></a>
+<span class="sourceLineNo">080</span>import org.apache.hadoop.hbase.zookeeper.ZNodePaths;<a name="line.80"></a>
+<span class="sourceLineNo">081</span>import org.junit.After;<a name="line.81"></a>
+<span class="sourceLineNo">082</span>import org.junit.Before;<a name="line.82"></a>
+<span class="sourceLineNo">083</span>import org.junit.Test;<a name="line.83"></a>
+<span class="sourceLineNo">084</span>import org.junit.experimental.categories.Category;<a name="line.84"></a>
+<span class="sourceLineNo">085</span><a name="line.85"></a>
+<span class="sourceLineNo">086</span>@Category({ReplicationTests.class, LargeTests.class})<a name="line.86"></a>
+<span class="sourceLineNo">087</span>public class TestMasterReplication {<a name="line.87"></a>
+<span class="sourceLineNo">088</span><a name="line.88"></a>
+<span class="sourceLineNo">089</span>  private static final Log LOG = LogFactory.getLog(TestReplicationBase.class);<a name="line.89"></a>
+<span class="sourceLineNo">090</span><a name="line.90"></a>
+<span class="sourceLineNo">091</span>  private Configuration baseConfiguration;<a name="line.91"></a>
+<span class="sourceLineNo">092</span><a name="line.92"></a>
+<span class="sourceLineNo">093</span>  private HBaseTestingUtility[] utilities;<a name="line.93"></a>
+<span class="sourceLineNo">094</span>  private Configuration[] configurations;<a name="line.94"></a>
+<span class="sourceLineNo">095</span>  private MiniZooKeeperCluster miniZK;<a name="line.95"></a>
+<span class="sourceLineNo">096</span><a name="line.96"></a>
+<span class="sourceLineNo">097</span>  private static final long SLEEP_TIME = 1000;<a name="line.97"></a>
+<span class="sourceLineNo">098</span>  private static final int NB_RETRIES = 120;<a name="line.98"></a>
+<span class="sourceLineNo">099</span><a name="line.99"></a>
+<span class="sourceLineNo">100</span>  private static final TableName tableName = TableName.valueOf("test");<a name="line.100"></a>
+<span class="sourceLineNo">101</span>  private static final byte[] famName = Bytes.toBytes("f");<a name="line.101"></a>
+<span class="sourceLineNo">102</span>  private static final byte[] famName1 = Bytes.toBytes("f1");<a name="line.102"></a>
+<span class="sourceLineNo">103</span>  private static final byte[] row = Bytes.toBytes("row");<a name="line.103"></a>
+<span class="sourceLineNo">104</span>  private static final byte[] row1 = Bytes.toBytes("row1");<a name="line.104"></a>
+<span class="sourceLineNo">105</span>  private static final byte[] row2 = Bytes.toBytes("row2");<a name="line.105"></a>
+<span class="sourceLineNo">106</span>  private static final byte[] row3 = Bytes.toBytes("row3");<a name="line.106"></a>
+<span class="sourceLineNo">107</span>  private static final byte[] row4 = Bytes.toBytes("row4");<a name="line.107"></a>
+<span class="sourceLineNo">108</span>  private static final byte[] noRepfamName = Bytes.toBytes("norep");<a name="line.108"></a>
+<span class="sourceLineNo">109</span><a name="line.109"></a>
+<span class="sourceLineNo">110</span>  private static final byte[] count = Bytes.toBytes("count");<a name="line.110"></a>
+<span class="sourceLineNo">111</span>  private static final byte[] put = Bytes.toBytes("put");<a name="line.111"></a>
+<span class="sourceLineNo">112</span>  private static final byte[] delete = Bytes.toBytes("delete");<a name="line.112"></a>
+<span class="sourceLineNo">113</span><a name="line.113"></a>
+<span class="sourceLineNo">114</span>  private TableDescriptor table;<a name="line.114"></a>
+<span class="sourceLineNo">115</span><a name="line.115"></a>
+<span class="sourceLineNo">116</span>  @Before<a name="line.116"></a>
+<span class="sourceLineNo">117</span>  public void setUp() throws Exception {<a name="line.117"></a>
+<span class="sourceLineNo">118</span>    baseConfiguration = HBaseConfiguration.create();<a name="line.118"></a>
+<span class="sourceLineNo">119</span>    // smaller block size and capacity to trigger more operations<a name="line.119"></a>
+<span class="sourceLineNo">120</span>    // and test them<a name="line.120"></a>
+<span class="sourceLineNo">121</span>    baseConfiguration.setInt("hbase.regionserver.hlog.blocksize", 1024 * 20);<a name="line.121"></a>
+<span class="sourceLineNo">122</span>    baseConfiguration.setInt("replication.source.size.capacity", 1024);<a name="line.122"></a>
+<span class="sourceLineNo">123</span>    baseConfiguration.setLong("replication.source.sleepforretries", 100);<a name="line.123"></a>
+<span class="sourceLineNo">124</span>    baseConfiguration.setInt("hbase.regionserver.maxlogs", 10);<a name="line.124"></a>
+<span class="sourceLineNo">125</span>    baseConfiguration.setLong("hbase.master.logcleaner.ttl", 10);<a name="line.125"></a>
+<span class="sourceLineNo">126</span>    baseConfiguration.setBoolean(HConstants.REPLICATION_BULKLOAD_ENABLE_KEY, true);<a name="line.126"></a>
+<span class="sourceLineNo">127</span>    baseConfiguration.set("hbase.replication.source.fs.conf.provider",<a name="line.127"></a>
+<span class="sourceLineNo">128</span>      TestSourceFSConfigurationProvider.class.getCanonicalName());<a name="line.128"></a>
+<span class="sourceLineNo">129</span>    baseConfiguration.set(HConstants.REPLICATION_CLUSTER_ID, "12345");<a name="line.129"></a>
+<span class="sourceLineNo">130</span>    baseConfiguration.setLong(HConstants.THREAD_WAKE_FREQUENCY, 100);<a name="line.130"></a>
+<span class="sourceLineNo">131</span>    baseConfiguration.setStrings(<a name="line.131"></a>
+<span class="sourceLineNo">132</span>        CoprocessorHost.USER_REGION_COPROCESSOR_CONF_KEY,<a name="line.132"></a>
+<span class="sourceLineNo">133</span>        CoprocessorCounter.class.getName());<a name="line.133"></a>
+<span class="sourceLineNo">134</span>    table = TableDescriptorBuilder.newBuilder(tableName)<a name="line.134"></a>
+<span class="sourceLineNo">135</span>        .addColumnFamily(ColumnFamilyDescriptorBuilder.newBuilder(famName)<a name="line.135"></a>
+<span class="sourceLineNo">136</span>            .setScope(HConstants.REPLICATION_SCOPE_GLOBAL).build())<a name="line.136"></a>
+<span class="sourceLineNo">137</span>        .addColumnFamily(ColumnFamilyDescriptorBuilder.newBuilder(famName1)<a name="line.137"></a>
+<span class="sourceLineNo">138</span>            .setScope(HConstants.REPLICATION_SCOPE_GLOBAL).build())<a name="line.138"></a>
+<span class="sourceLineNo">139</span>        .addColumnFamily(ColumnFamilyDescriptorBuilder.of(noRepfamName)).build();<a name="line.139"></a>
+<span class="sourceLineNo">140</span>  }<a name="line.140"></a>
+<span class="sourceLineNo">141</span><a name="line.141"></a>
+<span class="sourceLineNo">142</span>  /**<a name="line.142"></a>
+<span class="sourceLineNo">143</span>   * It tests the replication scenario involving 0 -&gt; 1 -&gt; 0. It does it by<a name="line.143"></a>
+<span class="sourceLineNo">144</span>   * adding and deleting a row to a table in each cluster, checking if it's<a name="line.144"></a>
+<span class="sourceLineNo">145</span>   * replicated. It also tests that the puts and deletes are not replicated back<a name="line.145"></a>
+<span class="sourceLineNo">146</span>   * to the originating cluster.<a name="line.146"></a>
+<span class="sourceLineNo">147</span>   */<a name="line.147"></a>
+<span class="sourceLineNo">148</span>  @Test(timeout = 300000)<a name="line.148"></a>
+<span class="sourceLineNo">149</span>  public void testCyclicReplication1() throws Exception {<a name="line.149"></a>
+<span class="sourceLineNo">150</span>    LOG.info("testSimplePutDelete");<a name="line.150"></a>
+<span class="sourceLineNo">151</span>    int numClusters = 2;<a name="line.151"></a>
+<span class="sourceLineNo">152</span>    Table[] htables = null;<a name="line.152"></a>
+<span class="sourceLineNo">153</span>    try {<a name="line.153"></a>
+<span class="sourceLineNo">154</span>      htables = setUpClusterTablesAndPeers(numClusters);<a name="line.154"></a>
+<span class="sourceLineNo">155</span><a name="line.155"></a>
+<span class="sourceLineNo">156</span>      int[] expectedCounts = new int[] { 2, 2 };<a name="line.156"></a>
+<span class="sourceLineNo">157</span><a name="line.157"></a>
+<span class="sourceLineNo">158</span>      // add rows to both clusters,<a name="line.158"></a>
+<span class="sourceLineNo">159</span>      // make sure they are both replication<a name="line.159"></a>
+<span class="sourceLineNo">160</span>      putAndWait(row, famName, htables[0], htables[1]);<a name="line.160"></a>
+<span class="sourceLineNo">161</span>      putAndWait(row1, famName, htables[1], htables[0]);<a name="line.161"></a>
+<span class="sourceLineNo">162</span>      validateCounts(htables, put, expectedCounts);<a name="line.162"></a>
+<span class="sourceLineNo">163</span><a name="line.163"></a>
+<span class="sourceLineNo">164</span>      deleteAndWait(row, htables[0], htables[1]);<a name="line.164"></a>
+<span class="sourceLineNo">165</span>      deleteAndWait(row1, htables[1], htables[0]);<a name="line.165"></a>
+<span class="sourceLineNo">166</span>      validateCounts(htables, delete, expectedCounts);<a name="line.166"></a>
+<span class="sourceLineNo">167</span>    } finally {<a name="line.167"></a>
+<span class="sourceLineNo">168</span>      close(htables);<a name="line.168"></a>
+<span class="sourceLineNo">169</span>      shutDownMiniClusters();<a name="line.169"></a>
+<span class="sourceLineNo">170</span>    }<a name="line.170"></a>
+<span class="sourceLineNo">171</span>  }<a name="line.171"></a>
+<span class="sourceLineNo">172</span><a name="line.172"></a>
+<span class="sourceLineNo">173</span>  /**<a name="line.173"></a>
+<span class="sourceLineNo">174</span>   * Tests the replication scenario 0 -&gt; 0. By default<a name="line.174"></a>
+<span class="sourceLineNo">175</span>   * {@link BaseReplicationEndpoint#canReplicateToSameCluster()} returns false, so the<a name="line.175"></a>
+<span class="sourceLineNo">176</span>   * ReplicationSource should terminate, and no further logs should get enqueued<a name="line.176"></a>
+<span class="sourceLineNo">177</span>   */<a name="line.177"></a>
+<span class="sourceLineNo">178</span>  @Test(timeout = 300000)<a name="line.178"></a>
+<span class="sourceLineNo">179</span>  public void testLoopedReplication() throws Exception {<a name="line.179"></a>
+<span class="sourceLineNo">180</span>    LOG.info("testLoopedReplication");<a name="line.180"></a>
+<span class="sourceLineNo">181</span>    startMiniClusters(1);<a name="line.181"></a>
+<span class="sourceLineNo">182</span>    createTableOnClusters(table);<a name="line.182"></a>
+<span class="sourceLineNo">183</span>    addPeer("1", 0, 0);<a name="line.183"></a>
+<span class="sourceLineNo">184</span>    Thread.sleep(SLEEP_TIME);<a name="line.184"></a>
+<span class="sourceLineNo">185</span><a name="line.185"></a>
+<span class="sourceLineNo">186</span>    // wait for source to terminate<a name="line.186"></a>
+<span class="sourceLineNo">187</span>    final ServerName rsName = utilities[0].getHBaseCluster().getRegionServer(0).getServerName();<a name="line.187"></a>
+<span class="sourceLineNo">188</span>    Waiter.waitFor(baseConfiguration, 10000, new Waiter.Predicate&lt;Exception&gt;() {<a name="line.188"></a>
+<span class="sourceLineNo">189</span>      @Override<a name="line.189"></a>
+<span class="sourceLineNo">190</span>      public boolean evaluate() throws Exception {<a name="line.190"></a>
+<span class="sourceLineNo">191</span>        ClusterStatus clusterStatus = utilities[0].getAdmin()<a name="line.191"></a>
+<span class="sourceLineNo">192</span>            .getClusterStatus(EnumSet.of(Option.LIVE_SERVERS));<a name="line.192"></a>
+<span class="sourceLineNo">193</span>        ServerLoad serverLoad = clusterStatus.getLoad(rsName);<a name="line.193"></a>
+<span class="sourceLineNo">194</span>        List&lt;ReplicationLoadSource&gt; replicationLoadSourceList =<a name="line.194"></a>
+<span class="sourceLineNo">195</span>            serverLoad.getReplicationLoadSourceList();<a name="line.195"></a>
+<span class="sourceLineNo">196</span>        return replicationLoadSourceList.isEmpty();<a name="line.196"></a>
+<span class="sourceLineNo">197</span>      }<a name="line.197"></a>
+<span class="sourceLineNo">198</span>    });<a name="line.198"></a>
+<span class="sourceLineNo">199</span><a name="line.199"></a>
+<span class="sourceLineNo">200</span>    Table[] htables = getHTablesOnClusters(tableName);<a name="line.200"></a>
+<span class="sourceLineNo">201</span>    putAndWait(row, famName, htables[0], htables[0]);<a name="line.201"></a>
+<span class="sourceLineNo">202</span>    rollWALAndWait(utilities[0], table.getTableName(), row);<a name="line.202"></a>
+<span class="sourceLineNo">203</span>    ZKWatcher zkw = utilities[0].getZooKeeperWatcher();<a name="line.203"></a>
+<span class="sourceLineNo">204</span>    String queuesZnode = ZNodePaths.joinZNode(zkw.getZNodePaths().baseZNode,<a name="line.204"></a>
+<span class="sourceLineNo">205</span>      ZNodePaths.joinZNode("replication", "rs"));<a name="line.205"></a>
+<span class="sourceLineNo">206</span>    List&lt;String&gt; listChildrenNoWatch =<a name="line.206"></a>
+<span class="sourceLineNo">207</span>        ZKUtil.listChildrenNoWatch(zkw, ZNodePaths.joinZNode(queuesZnode, rsName.toString()));<a name="line.207"></a>
+<span class="sourceLineNo">208</span>    assertEquals(0, listChildrenNoWatch.size());<a name="line.208"></a>
+<span class="sourceLineNo">209</span>  }<a name="line.209"></a>
+<span class="sourceLineNo">210</span><a name="line.210"></a>
+<span class="sourceLineNo">211</span>  /**<a name="line.211"></a>
+<span class="sourceLineNo">212</span>   * It tests the replication scenario involving 0 -&gt; 1 -&gt; 0. It does it by bulk loading a set of<a name="line.212"></a>
+<span class="sourceLineNo">213</span>   * HFiles to a table in each cluster, checking if it's replicated.<a name="line.213"></a>
+<span class="sourceLineNo">214</span>   */<a name="line.214"></a>
+<span class="sourceLineNo">215</span>  @Test(timeout = 300000)<a name="line.215"></a>
+<span class="sourceLineNo">216</span>  public void testHFileCyclicReplication() throws Exception {<a name="line.216"></a>
+<span class="sourceLineNo">217</span>    LOG.info("testHFileCyclicReplication");<a name="line.217"></a>
+<span class="sourceLineNo">218</span>    int numClusters = 2;<a name="line.218"></a>
+<span class="sourceLineNo">219</span>    Table[] htables = null;<a name="line.219"></a>
+<span class="sourceLineNo">220</span>    try {<a name="line.220"></a>
+<span class="sourceLineNo">221</span>      htables = setUpClusterTablesAndPeers(numClusters);<a name="line.221"></a>
+<span class="sourceLineNo">222</span><a name="line.222"></a>
+<span class="sourceLineNo">223</span>      // Load 100 rows for each hfile range in cluster '0' and validate whether its been replicated<a name="line.223"></a>
+<span class="sourceLineNo">224</span>      // to cluster '1'.<a name="line.224"></a>
+<span class="sourceLineNo">225</span>      byte[][][] hfileRanges =<a name="line.225"></a>
+<span class="sourceLineNo">226</span>          new byte[][][] { new byte[][] { Bytes.toBytes("aaaa"), Bytes.toBytes("cccc") },<a name="line.226"></a>
+<span class="sourceLineNo">227</span>              new byte[][] { Bytes.toBytes("ddd"), Bytes.toBytes("fff") }, };<a name="line.227"></a>
+<span class="sourceLineNo">228</span>      int numOfRows = 100;<a name="line.228"></a>
+<span class="sourceLineNo">229</span>      int[] expectedCounts =<a name="line.229"></a>
+<span class="sourceLineNo">230</span>          new int[] { hfileRanges.length * numOfRows, hfileRanges.length * numOfRows };<a name="line.230"></a>
+<span class="sourceLineNo">231</span><a name="line.231"></a>
+<span class="sourceLineNo">232</span>      loadAndValidateHFileReplication("testHFileCyclicReplication_01", 0, new int[] { 1 }, row,<a name="line.232"></a>
+<span class="sourceLineNo">233</span>        famName, htables, hfileRanges, numOfRows, expectedCounts, true);<a name="line.233"></a>
 <span class="sourceLineNo">234</span><a name="line.234"></a>
-<span class="sourceLineNo">235</span>      loadAndValidateHFileReplication("testHFileCyclicReplication_01", 0, new int[] { 1 }, row,<a name="line.235"></a>
-<span class="sourceLineNo">236</span>        famName, htables, hfileRanges, numOfRows, expectedCounts, true);<a name="line.236"></a>
-<span class="sourceLineNo">237</span><a name="line.237"></a>
-<span class="sourceLineNo">238</span>      // Load 200 rows for each hfile range in cluster '1' and validate whether its been replicated<a name="line.238"></a>
-<span class="sourceLineNo">239</span>      // to cluster '0'.<a name="line.239"></a>
-<span class="sourceLineNo">240</span>      hfileRanges = new byte[][][] { new byte[][] { Bytes.toBytes("gggg"), Bytes.toBytes("iiii") },<a name="line.240"></a>
-<span class="sourceLineNo">241</span>          new byte[][] { Bytes.toBytes("jjj"), Bytes.toBytes("lll") }, };<a name="line.241"></a>
-<span class="sourceLineNo">242</span>      numOfRows = 200;<a name="line.242"></a>
-<span class="sourceLineNo">243</span>      int[] newExpectedCounts = new int[] { hfileRanges.length * numOfRows + expectedCounts[0],<a name="line.243"></a>
-<span class="sourceLineNo">244</span>          hfileRanges.length * numOfRows + expectedCounts[1] };<a name="line.244"></a>
+<span class="sourceLineNo">235</span>      // Load 200 rows for each hfile range in cluster '1' and validate whether its been replicated<a name="line.235"></a>
+<span class="sourceLineNo">236</span>      // to cluster '0'.<a name="line.236"></a>
+<span class="sourceLineNo">237</span>      hfileRanges = new byte[][][] { new byte[][] { Bytes.toBytes("gggg"), Bytes.toBytes("iiii") },<a name="line.237"></a>
+<span class="sourceLineNo">238</span>          new byte[][] { Bytes.toBytes("jjj"), Bytes.toBytes("lll") }, };<a name="line.238"></a>
+<span class="sourceLineNo">239</span>      numOfRows = 200;<a name="line.239"></a>
+<span class="sourceLineNo">240</span>      int[] newExpectedCounts = new int[] { hfileRanges.length * numOfRows + expectedCounts[0],<a name="line.240"></a>
+<span class="sourceLineNo">241</span>          hfileRanges.length * numOfRows + expectedCounts[1] };<a name="line.241"></a>
+<span class="sourceLineNo">242</span><a name="line.242"></a>
+<span class="sourceLineNo">243</span>      loadAndValidateHFileReplication("testHFileCyclicReplication_10", 1, new int[] { 0 }, row,<a name="line.243"></a>
+<span class="sourceLineNo">244</span>        famName, htables, hfileRanges, numOfRows, newExpectedCounts, true);<a name="line.244"></a>
 <span class="sourceLineNo">245</span><a name="line.245"></a>
-<span class="sourceLineNo">246</span>      loadAndValidateHFileReplication("testHFileCyclicReplication_10", 1, new int[] { 0 }, row,<a name="line.246"></a>
-<span class="sourceLineNo">247</span>        famName, htables, hfileRanges, numOfRows, newExpectedCounts, true);<a name="line.247"></a>
-<span class="sourceLineNo">248</span><a name="line.248"></a>
-<span class="sourceLineNo">249</span>    } finally {<a name="line.249"></a>
-<span class="sourceLineNo">250</span>      close(htables);<a name="line.250"></a>
-<span class="sourceLineNo">251</span>      shutDownMiniClusters();<a name="line.251"></a>
-<span class="sourceLineNo">252</span>    }<a name="line.252"></a>
-<span class="sourceLineNo">253</span>  }<a name="line.253"></a>
-<span class="sourceLineNo">254</span><a name="line.254"></a>
-<span class="sourceLineNo">255</span>  private Table[] setUpClusterTablesAndPeers(int numClusters) throws Exception {<a name="line.255"></a>
-<span class="sourceLineNo">256</span>    Table[] htables;<a name="line.256"></a>
-<span class="sourceLineNo">257</span>    startMiniClusters(numClusters);<a name="line.257"></a>
-<span class="sourceLineNo">258</span>    createTableOnClusters(table);<a name="line.258"></a>
-<span class="sourceLineNo">259</span><a name="line.259"></a>
-<span class="sourceLineNo">260</span>    htables = getHTablesOnClusters(tableName);<a name="line.260"></a>
-<span class="sourceLineNo">261</span>    // Test the replication scenarios of 0 -&gt; 1 -&gt; 0<a name="line.261"></a>
-<span class="sourceLineNo">262</span>    addPeer("1", 0, 1);<a name="line.262"></a>
-<span class="sourceLineNo">263</span>    addPeer("1", 1, 0);<a name="line.263"></a>
-<span class="sourceLineNo">264</span>    return htables;<a name="line.264"></a>
-<span class="sourceLineNo">265</span>  }<a name="line.265"></a>
-<span class="sourceLineNo">266</span><a name="line.266"></a>
-<span class="sourceLineNo">267</span>  /**<a name="line.267"></a>
-<span class="sourceLineNo">268</span>   * Tests the cyclic replication scenario of 0 -&gt; 1 -&gt; 2 -&gt; 0 by adding and deleting rows to a<a name="line.268"></a>
-<span class="sourceLineNo">269</span>   * table in each clusters and ensuring that the each of these clusters get the appropriate<a name="line.269"></a>
-<span class="sourceLineNo">270</span>   * mutations. It also tests the grouping scenario where a cluster needs to replicate the edits<a name="line.270"></a>
-<span class="sourceLineNo">271</span>   * originating from itself and also the edits that it received using replication from a different<a name="line.271"></a>
-<span class="sourceLineNo">272</span>   * cluster. The scenario is explained in HBASE-9158<a name="line.272"></a>
-<span class="sourceLineNo">273</span>   */<a name="line.273"></a>
-<span class="sourceLineNo">274</span>  @Test(timeout = 300000)<a name="line.274"></a>
-<span class="sourceLineNo">275</span>  public void testCyclicReplication2() throws Exception {<a name="line.275"></a>
-<span class="sourceLineNo">276</span>    LOG.info("testCyclicReplication1");<a name="line.276"></a>
-<span class="sourceLineNo">277</span>    int numClusters = 3;<a name="line.277"></a>
-<span class="sourceLineNo">278</span>    Table[] htables = null;<a name="line.278"></a>
-<span class="sourceLineNo">279</span>    try {<a name="line.279"></a>
-<span class="sourceLineNo">280</span>      startMiniClusters(numClusters);<a name="line.280"></a>
-<span class="sourceLineNo">281</span>      createTableOnClusters(table);<a name="line.281"></a>
-<span class="sourceLineNo">282</span><a name="line.282"></a>
-<span class="sourceLineNo">283</span>      // Test the replication scenario of 0 -&gt; 1 -&gt; 2 -&gt; 0<a name="line.283"></a>
-<span class="sourceLineNo">284</span>      addPeer("1", 0, 1);<a name="line.284"></a>
-<span class="sourceLineNo">285</span>      addPeer("1", 1, 2);<a name="line.285"></a>
-<span class="sourceLineNo">286</span>      addPeer("1", 2, 0);<a name="line.286"></a>
-<span class="sourceLineNo">287</span><a name="line.287"></a>
-<span class="sourceLineNo">288</span>      htables = getHTablesOnClusters(tableName);<a name="line.288"></a>
-<span class="sourceLineNo">289</span><a name="line.289"></a>
-<span class="sourceLineNo">290</span>      // put "row" and wait 'til it got around<a name="line.290"></a>
-<span class="sourceLineNo">291</span>      putAndWait(row, famName, htables[0], htables[2]);<a name="line.291"></a>
-<span class="sourceLineNo">292</span>      putAndWait(row1, famName, htables[1], htables[0]);<a name="line.292"></a>
-<span class="sourceLineNo">293</span>      putAndWait(row2, famName, htables[2], htables[1]);<a name="line.293"></a>
-<span class="sourceLineNo">294</span><a name="line.294"></a>
-<span class="sourceLineNo">295</span>      deleteAndWait(row, htables[0], htables[2]);<a name="line.295"></a>
-<span class="sourceLineNo">296</span>      deleteAndWait(row1, htables[1], htables[0]);<a name="line.296"></a>
-<span class="sourceLineNo">297</span>      deleteAndWait(row2, htables[2], htables[1]);<a name="line.297"></a>
-<span class="sourceLineNo">298</span><a name="line.298"></a>
-<span class="sourceLineNo">299</span>      int[] expectedCounts = new int[] { 3, 3, 3 };<a name="line.299"></a>
-<span class="sourceLineNo">300</span>      validateCounts(htables, put, expectedCounts);<a name="line.300"></a>
-<span class="sourceLineNo">301</span>      validateCounts(htables, delete, expectedCounts);<a name="line.301"></a>
-<span class="sourceLineNo">302</span><a name="line.302"></a>
-<span class="sourceLineNo">303</span>      // Test HBASE-9158<a name="line.303"></a>
-<span class="sourceLineNo">304</span>      disablePeer("1", 2);<a name="line.304"></a>
-<span class="sourceLineNo">305</span>      // we now have an edit that was replicated into cluster originating from<a name="line.305"></a>
-<span class="sourceLineNo">306</span>      // cluster 0<a name="line.306"></a>
-<span class="sourceLineNo">307</span>      putAndWait(row3, famName, htables[0], htables[1]);<a name="line.307"></a>
-<span class="sourceLineNo">308</span>      // now add a local edit to cluster 1<a name="line.308"></a>
-<span class="sourceLineNo">309</span>      htables[1].put(new Put(row4).addColumn(famName, row4, row4));<a name="line.309"></a>
-<span class="sourceLineNo">310</span>      // re-enable replication from cluster 2 to cluster 0<a name="line.310"></a>
-<span class="sourceLineNo">311</span>      enablePeer("1", 2);<a name="line.311"></a>
-<span class="sourceLineNo">312</span>      // without HBASE-9158 the edit for row4 would have been marked with<a name="line.312"></a>
-<span class="sourceLineNo">313</span>      // cluster 0's id<a name="line.313"></a>
-<span class="sourceLineNo">314</span>      // and hence not replicated to cluster 0<a name="line.314"></a>
-<span class="sourceLineNo">315</span>      wait(row4, htables[0], true);<a name="line.315"></a>
-<span class="sourceLineNo">316</span>    } finally {<a name="line.316"></a>
-<span class="sourceLineNo">317</span>      close(htables);<a name="line.317"></a>
-<span class="sourceLineNo">318</span>      shutDownMiniClusters();<a name="line.318"></a>
-<span class="sourceLineNo">319</span>    }<a name="line.319"></a>
-<span class="sourceLineNo">320</span>  }<a name="line.320"></a>
-<span class="sourceLineNo">321</span><a name="line.321"></a>
-<span class="sourceLineNo">322</span>  /**<a name="line.322"></a>
-<span class="sourceLineNo">323</span>   * It tests the multi slave hfile replication scenario involving 0 -&gt; 1, 2. It does it by bulk<a name="line.323"></a>
-<span class="sourceLineNo">324</span>   * loading a set of HFiles to a table in master cluster, checking if it's replicated in its peers.<a name="line.324"></a>
-<span class="sourceLineNo">325</span>   */<a name="line.325"></a>
-<span class="sourceLineNo">326</span>  @Test(timeout = 300000)<a name="line.326"></a>
-<span class="sourceLineNo">327</span>  public void testHFileMultiSlaveReplication() throws Exception {<a name="line.327"></a>
-<span class="sourceLineNo">328</span>    LOG.info("testHFileMultiSlaveReplication");<a name="line.328"></a>
-<span class="sourceLineNo">329</span>    int numClusters = 3;<a name="line.329"></a>
-<span class="sourceLineNo">330</span>    Table[] htables = null;<a name="line.330"></a>
-<span class="sourceLineNo">331</span>    try {<a name="line.331"></a>
-<span class="sourceLineNo">332</span>      startMiniClusters(numClusters);<a name="line.332"></a>
-<span class="sourceLineNo">333</span>      createTableOnClusters(table);<a name="line.333"></a>
+<span class="sourceLineNo">246</span>    } finally {<a name="line.246"></a>
+<span class="sourceLineNo">247</span>      close(htables);<a name="line.247"></a>
+<span class="sourceLineNo">248</span>      shutDownMiniClusters();<a name="line.248"></a>
+<span class="sourceLineNo">249</span>    }<a name="line.249"></a>
+<span class="sourceLineNo">250</span>  }<a name="line.250"></a>
+<span class="sourceLineNo">251</span><a name="line.251"></a>
+<span class="sourceLineNo">252</span>  private Table[] setUpClusterTablesAndPeers(int numClusters) throws Exception {<a name="line.252"></a>
+<span class="sourceLineNo">253</span>    Table[] htables;<a name="line.253"></a>
+<span class="sourceLineNo">254</span>    startMiniClusters(numClusters);<a name="line.254"></a>
+<span class="sourceLineNo">255</span>    createTableOnClusters(table);<a name="line.255"></a>
+<span class="sourceLineNo">256</span><a name="line.256"></a>
+<span class="sourceLineNo">257</span>    htables = getHTablesOnClusters(tableName);<a name="line.257"></a>
+<span class="sourceLineNo">258</span>    // Test the replication scenarios of 0 -&gt; 1 -&gt; 0<a name="line.258"></a>
+<span class="sourceLineNo">259</span>    addPeer("1", 0, 1);<a name="line.259"></a>
+<span class="sourceLineNo">260</span>    addPeer("1", 1, 0);<a name="line.260"></a>
+<span class="sourceLineNo">261</span>    return htables;<a name="line.261"></a>
+<span class="sourceLineNo">262</span>  }<a name="line.262"></a>
+<span class="sourceLineNo">263</span><a name="line.263"></a>
+<span class="sourceLineNo">264</span>  /**<a name="line.264"></a>
+<span class="sourceLineNo">265</span>   * Tests the cyclic replication scenario of 0 -&gt; 1 -&gt; 2 -&gt; 0 by adding and deleting rows to a<a name="line.265"></a>
+<span class="sourceLineNo">266</span>   * table in each clusters and ensuring that the each of these clusters get the appropriate<a name="line.266"></a>
+<span class="sourceLineNo">267</span>   * mutations. It also tests the grouping scenario where a cluster needs to replicate the edits<a name="line.267"></a>
+<span class="sourceLineNo">268</span>   * originating from itself and also the edits that it received using replication from a different<a name="line.268"></a>
+<span class="sourceLineNo">269</span>   * cluster. The scenario is explained in HBASE-9158<a name="line.269"></a>
+<span class="sourceLineNo">270</span>   */<a name="line.270"></a>
+<span class="sourceLineNo">271</span>  @Test(timeout = 300000)<a name="line.271"></a>
+<span class="sourceLineNo">272</span>  public void testCyclicReplication2() throws Exception {<a name="line.272"></a>
+<span class="sourceLineNo">273</span>    LOG.info("testCyclicReplication2");<a name="line.273"></a>
+<span class="sourceLineNo">274</span>    int numClusters = 3;<a name="line.274"></a>
+<span class="sourceLineNo">275</span>    Table[] htables = null;<a name="line.275"></a>
+<span class="sourceLineNo">276</span>    try {<a name="line.276"></a>
+<span class="sourceLineNo">277</span>      startMiniClusters(numClusters);<a name="line.277"></a>
+<span class="sourceLineNo">278</span>      createTableOnClusters(table);<a name="line.278"></a>
+<span class="sourceLineNo">279</span><a name="line.279"></a>
+<span class="sourceLineNo">280</span>      // Test the replication scenario of 0 -&gt; 1 -&gt; 2 -&gt; 0<a name="line.280"></a>
+<span class="sourceLineNo">281</span>      addPeer("1", 0, 1);<a name="line.281"></a>
+<span class="sourceLineNo">282</span>      addPeer("1", 1, 2);<a name="line.282"></a>
+<span class="sourceLineNo">283</span>      addPeer("1", 2, 0);<a name="line.283"></a>
+<span class="sourceLineNo">284</span><a name="line.284"></a>
+<span class="sourceLineNo">285</span>      htables = getHTablesOnClusters(tableName);<a name="line.285"></a>
+<span class="sourceLineNo">286</span><a name="line.286"></a>
+<span class="sourceLineNo">287</span>      // put "row" and wait 'til it got around<a name="line.287"></a>
+<span class="sourceLineNo">288</span>      putAndWait(row, famName, htables[0], htables[2]);<a name="line.288"></a>
+<span class="sourceLineNo">289</span>      putAndWait(row1, famName, htables[1], htables[0]);<a name="line.289"></a>
+<span class="sourceLineNo">290</span>      putAndWait(row2, famName, htables[2], htables[1]);<a name="line.290"></a>
+<span class="sourceLineNo">291</span><a name="line.291"></a>
+<span class="sourceLineNo">292</span>      deleteAndWait(row, htables[0], htables[2]);<a name="line.292"></a>
+<span class="sourceLineNo">293</span>      deleteAndWait(row1, htables[1], htables[0]);<a name="line.293"></a>
+<span class="sourceLineNo">294</span>      deleteAndWait(row2, htables[2], htables[1]);<a name="line.294"></a>
+<span class="sourceLineNo">295</span><a name="line.295"></a>
+<span class="sourceLineNo">296</span>      int[] expectedCounts = new int[] { 3, 3, 3 };<a name="line.296"></a>
+<span class="sourceLineNo">297</span>      validateCounts(htables, put, expectedCounts);<a name="line.297"></a>
+<span class="sourceLineNo">298</span>      validateCounts(htables, delete, expectedCounts);<a name="line.298"></a>
+<span class="sourceLineNo">299</span><a name="line.299"></a>
+<span class="sourceLineNo">300</span>      // Test HBASE-9158<a name="line.300"></a>
+<span class="sourceLineNo">301</span>      disablePeer("1", 2);<a name="line.301"></a>
+<span class="sourceLineNo">302</span>      // we now have an edit that was replicated into cluster originating from<a name="line.302"></a>
+<span class="sourceLineNo">303</span>      // cluster 0<a name="line.303"></a>
+<span class="sourceLineNo">304</span>      putAndWait(row3, famName, htables[0], htables[1]);<a name="line.304"></a>
+<span class="sourceLineNo">305</span>      // now add a local edit to cluster 1<a name="line.305"></a>
+<span class="sourceLineNo">306</span>      htables[1].put(new Put(row4).addColumn(famName, row4, row4));<a name="line.306"></a>
+<span class="sourceLineNo">307</span>      // re-enable replication from cluster 2 to cluster 0<a name="line.307"></a>
+<span class="sourceLineNo">308</span>      enablePeer("1", 2);<a name="line.308"></a>
+<span class="sourceLineNo">309</span>      // without HBASE-9158 the edit for row4 would have been marked with<a name="line.309"></a>
+<span class="sourceLineNo">310</span>      // cluster 0's id<a name="line.310"></a>
+<span class="sourceLineNo">311</span>      // and hence not replicated to cluster 0<a name="line.311"></a>
+<span class="sourceLineNo">312</span>      wait(row4, htables[0], false);<a name="line.312"></a>
+<span class="sourceLineNo">313</span>    } finally {<a name="line.313"></a>
+<span class="sourceLineNo">314</span>      close(htables);<a name="line.314"></a>
+<span class="sourceLineNo">315</span>      shutDownMiniClusters();<a name="line.315"></a>
+<span class="sourceLineNo">316</span>    }<a name="line.316"></a>
+<span class="sourceLineNo">317</span>  }<a name="line.317"></a>
+<span class="sourceLineNo">318</span><a name="line.318"></a>
+<span class="sourceLineNo">319</span>  /**<a name="line.319"></a>
+<span class="sourceLineNo">320</span>   * It tests the multi slave hfile replication scenario involving 0 -&gt; 1, 2. It does it by bulk<a name="line.320"></a>
+<span class="sourceLineNo">321</span>   * loading a set of HFiles to a table in master cluster, checking if it's replicated in its peers.<a name="line.321"></a>
+<span class="sourceLineNo">322</span>   */<a name="line.322"></a>
+<span class="sourceLineNo">323</span>  @Test(timeout = 300000)<a name="line.323"></a>
+<span class="sourceLineNo">324</span>  public void testHFileMultiSlaveReplication() throws Exception {<a name="line.324"></a>
+<span class="sourceLineNo">325</span>    LOG.info("testHFileMultiSlaveReplication");<a name="line.325"></a>
+<span class="sourceLineNo">326</span>    int numClusters = 3;<a name="line.326"></a>
+<span class="sourceLineNo">327</span>    Table[] htables = null;<a name="line.327"></a>
+<span class="sourceLineNo">328</span>    try {<a name="line.328"></a>
+<span class="sourceLineNo">329</span>      startMiniClusters(numClusters);<a name="line.329"></a>
+<span class="sourceLineNo">330</span>      createTableOnClusters(table);<a name="line.330"></a>
+<span class="sourceLineNo">331</span><a name="line.331"></a>
+<span class="sourceLineNo">332</span>      // Add a slave, 0 -&gt; 1<a name="line.332"></a>
+<span class="sourceLineNo">333</span>      addPeer("1", 0, 1);<a name="line.333"></a>
 <span class="sourceLineNo">334</span><a name="line.334"></a>
-<span class="sourceLineNo">335</span>      // Add a slave, 0 -&gt; 1<a name="line.335"></a>
-<span class="sourceLineNo">336</span>      addPeer("1", 0, 1);<a name="line.336"></a>
-<span class="sourceLineNo">337</span><a name="line.337"></a>
-<span class="sourceLineNo">338</span>      htables = getHTablesOnClusters(tableName);<a name="line.338"></a>
-<span class="sourceLineNo">339</span><a name="line.339"></a>
-<span class="sourceLineNo">340</span>      // Load 100 rows for each hfile range in cluster '0' and validate whether its been replicated<a name="line.340"></a>
-<span class="sourceLineNo">341</span>      // to cluster '1'.<a name="line.341"></a>
-<span class="sourceLineNo">342</span>      byte[][][] hfileRanges =<a name="line.342"></a>
-<span class="sourceLineNo">343</span>          new byte[][][] { new byte[][] { Bytes.toBytes("mmmm"), Bytes.toBytes("oooo") },<a name="line.343"></a>
-<span class="sourceLineNo">344</span>              new byte[][] { Bytes.toBytes("ppp"), Bytes.toBytes("rrr") }, };<a name="line.344"></a>
-<span class="sourceLineNo">345</span>      int numOfRows = 100;<a name="line.345"></a>
+<span class="sourceLineNo">335</span>      htables = getHTablesOnClusters(tableName);<a name="line.335"></a>
+<span class="sourceLineNo">336</span><a name="line.336"></a>
+<span class="sourceLineNo">337</span>      // Load 100 rows for each hfile range in cluster '0' and validate whether its been replicated<a name="line.337"></a>
+<span class="sourceLineNo">338</span>      // to cluster '1'.<a name="line.338"></a>
+<span class="sourceLineNo">339</span>      byte[][][] hfileRanges =<a name="line.339"></a>
+<span class="sourceLineNo">340</span>          new byte[][][] { new byte[][] { Bytes.toBytes("mmmm"), Bytes.toBytes("oooo") },<a name="line.340"></a>
+<span class="sourceLineNo">341</span>              new byte[][] { Bytes.toBytes("ppp"), Bytes.toBytes("rrr") }, };<a name="line.341"></a>
+<span class="sourceLineNo">342</span>      int numOfRows = 100;<a name="line.342"></a>
+<span class="sourceLineNo">343</span><a name="line.343"></a>
+<span class="sourceLineNo">344</span>      int[] expectedCounts =<a name="line.344"></a>
+<span class="sourceLineNo">345</span>          new int[] { hfileRanges.length * numOfRows, hfileRanges.length * numOfRows };<a name="line.345"></a>
 <span class="sourceLineNo">346</span><a name="line.346"></a>
-<span class="sourceLineNo">347</span>      int[] expectedCounts =<a name="line.347"></a>
-<span class="sourceLineNo">348</span>          new int[] { hfileRanges.length * numOfRows, hfileRanges.length * numOfRows };<a name="line.348"></a>
+<span class="sourceLineNo">347</span>      loadAndValidateHFileReplication("testHFileCyclicReplication_0", 0, new int[] { 1 }, row,<a name="line.347"></a>
+<span class="sourceLineNo">348</span>        famName, htables, hfileRanges, numOfRows, expectedCounts, true);<a name="line.348"></a>
 <span class="sourceLineNo">349</span><a name="line.349"></a>
-<span class="sourceLineNo">350</span>      loadAndValidateHFileReplication("testHFileCyclicReplication_0", 0, new int[] { 1 }, row,<a name="line.350"></a>
-<span class="sourceLineNo">351</span>        famName, htables, hfileRanges, numOfRows, expectedCounts, true);<a name="line.351"></a>
+<span class="sourceLineNo">350</span>      // Validate data is not replicated to cluster '2'.<a name="line.350"></a>
+<span class="sourceLineNo">351</span>      assertEquals(0, utilities[2].countRows(htables[2]));<a name="line.351"></a>
 <span class="sourceLineNo">352</span><a name="line.352"></a>
-<span class="sourceLineNo">353</span>      // Validate data is not replicated to cluster '2'.<a name="line.353"></a>
-<span class="sourceLineNo">354</span>      assertEquals(0, utilities[2].countRows(htables[2]));<a name="line.354"></a>
-<span class="sourceLineNo">355</span><a name="line.355"></a>
-<span class="sourceLineNo">356</span>      rollWALAndWait(utilities[0], htables[0].getName(), row);<a name="line.356"></a>
+<span class="sourceLineNo">353</span>      rollWALAndWait(utilities[0], htables[0].getName(), row);<a name="line.353"></a>
+<span class="sourceLineNo">354</span><a name="line.354"></a>
+<span class="sourceLineNo">355</span>      // Add one more slave, 0 -&gt; 2<a name="line.355"></a>
+<span class="sourceLineNo">356</span>      addPeer("2", 0, 2);<a name="line.356"></a>
 <span class="sourceLineNo">357</span><a name="line.357"></a>
-<span class="sourceLineNo">358</span>      // Add one more slave, 0 -&gt; 2<a name="line.358"></a>
-<span class="sourceLineNo">359</span>      addPeer("2", 0, 2);<a name="line.359"></a>
-<span class="sourceLineNo">360</span><a name="line.360"></a>
-<span class="sourceLineNo">361</span>      // Load 200 rows for each hfile range in cluster '0' and validate whether its been replicated<a name="line.361"></a>
-<span class="sourceLineNo">362</span>      // to cluster '1' and '2'. Previous data should be replicated to cluster '2'.<a name="line.362"></a>
-<span class="sourceLineNo">363</span>      hfileRanges = new byte[][][] { new byte[][] { Bytes.toBytes("ssss"), Bytes.toBytes("uuuu") },<a name="line.363"></a>
-<span class="sourceLineNo">364</span>          new byte[][] { Bytes.toBytes("vvv"), Bytes.toBytes("xxx") }, };<a name="line.364"></a>
-<span class="sourceLineNo">365</span>      numOfRows = 200;<a name="line.365"></a>
+<span class="sourceLineNo">358</span>      // Load 200 rows for each hfile range in cluster '0' and validate whether its been replicated<a name="line.358"></a>
+<span class="sourceLineNo">359</span>      // to cluster '1' and '2'. Previous data should be replicated to cluster '2'.<a name="line.359"></a>
+<span class="sourceLineNo">360</span>      hfileRanges = new byte[][][] { new byte[][] { Bytes.toBytes("ssss"), Bytes.toBytes("uuuu") },<a name="line.360"></a>
+<span class="sourceLineNo">361</span>          new byte[][] { Bytes.toBytes("vvv"), Bytes.toBytes("xxx") }, };<a name="line.361"></a>
+<span class="sourceLineNo">362</span>      numOfRows = 200;<a name="line.362"></a>
+<span class="sourceLineNo">363</span><a name="line.363"></a>
+<span class="sourceLineNo">364</span>      int[] newExpectedCounts = new int[] { hfileRanges.length * numOfRows + expectedCounts[0],<a name="line.364"></a>
+<span class="sourceLineNo">365</span>          hfileRanges.length * numOfRows + expectedCounts[1], hfileRanges.length * numOfRows };<a name="line.365"></a>
 <span class="sourceLineNo">366</span><a name="line.366"></a>
-<span class="sourceLineNo">367</span>      int[] newExpectedCounts = new int[] { hfileRanges.length * numOfRows + expectedCounts[0],<a name="line.367"></a>
-<span class="sourceLineNo">368</span>          hfileRanges.length * numOfRows + expectedCounts[1], hfileRanges.length * numOfRows };<a name="line.368"></a>
+<span class="sourceLineNo">367</span>      loadAndValidateHFileReplication("testHFileCyclicReplication_1", 0, new int[] { 1, 2 }, row,<a name="line.367"></a>
+<span class="sourceLineNo">368</span>        famName, htables, hfileRanges, numOfRows, newExpectedCounts, true);<a name="line.368"></a>
 <span class="sourceLineNo">369</span><a name="line.369"></a>
-<span class="sourceLineNo">370</span>      loadAndValidateHFileReplication("testHFileCyclicReplication_1", 0, new int[] { 1, 2 }, row,<a name="line.370"></a>
-<span class="sourceLineNo">371</span>        famName, htables, hfileRanges, numOfRows, newExpectedCounts, true);<a name="line.371"></a>
-<span class="sourceLineNo">372</span><a name="line.372"></a>
-<span class="sourceLineNo">373</span>    } finally {<a name="line.373"></a>
-<span class="sourceLineNo">374</span>      close(htables);<a name="line.374"></a>
-<span class="sourceLineNo">375</span>      shutDownMiniClusters();<a name="line.375"></a>
-<span class="sourceLineNo">376</span>    }<a name="line.376"></a>
-<span class="sourceLineNo">377</span>  }<a name="line.377"></a>
-<span class="sourceLineNo">378</span><a name="line.378"></a>
-<span class="sourceLineNo">379</span>  /**<a name="line.379"></a>
-<span class="sourceLineNo">380</span>   * It tests the bulk loaded hfile replication scenario to only explicitly specified table column<a name="line.380"></a>
-<span class="sourceLineNo">381</span>   * families. It does it by bulk loading a set of HFiles belonging to both the CFs of table and set<a name="line.381"></a>
-<span class="sourceLineNo">382</span>   * only one CF data to replicate.<a name="line.382"></a>
-<span class="sourceLineNo">383</span>   */<a name="line.383"></a>
-<span class="sourceLineNo">384</span>  @Test(timeout = 300000)<a name="line.384"></a>
-<span class="sourceLineNo">385</span>  public void testHFileReplicationForConfiguredTableCfs() throws Exception {<a name="line.385"></a>
-<span class="sourceLineNo">386</span>    LOG.info("testHFileReplicationForConfiguredTableCfs");<a name="line.386"></a>
-<span class="sourceLineNo">387</span>    int numClusters = 2;<a name="line.387"></a>
-<span class="sourceLineNo">388</span>    Table[] htables = null;<a name="line.388"></a>
-<span class="sourceLineNo">389</span>    try {<a name="line.389"></a>
-<span class="sourceLineNo">390</span>      startMiniClusters(numClusters);<a name="line.390"></a>
-<span class="sourceLineNo">391</span>      createTableOnClusters(table);<a name="line.391"></a>
-<span class="sourceLineNo">392</span><a name="line.392"></a>
-<span class="sourceLineNo">393</span>      htables = getHTablesOnClusters(tableName);<a name="line.393"></a>
-<span class="sourceLineNo">394</span>      // Test the replication scenarios only 'f' is configured for table data replication not 'f1'<a name="line.394"></a>
-<span class="sourceLineNo">395</span>      addPeer("1", 0, 1, tableName.getNameAsString() + ":" + Bytes.toString(famName));<a name="line.395"></a>
-<span class="sourceLineNo">396</span><a name="line.396"></a>
-<span class="sourceLineNo">397</span>      // Load 100 rows for each hfile range in cluster '0' for table CF 'f'<a name="line.397"></a>
-<span class="sourceLineNo">398</span>      byte[][][] hfileRanges =<a name="line.398"></a>
-<span class="sourceLineNo">399</span>          new byte[][][] { new byte[][] { Bytes.toBytes("aaaa"), Bytes.toBytes("cccc") },<a name="line.399"></a>
-<span class="sourceLineNo">400</span>              new byte[][] { Bytes.toBytes("ddd"), Bytes.toBytes("fff") }, };<a name="line.400"></a>
-<span class="sourceLineNo">401</span>      int numOfRows = 100;<a name="line.401"></a>
-<span class="sourceLineNo">402</span>      int[] expectedCounts =<a name="line.402"></a>
-<span class="sourceLineNo">403</span>          new int[] { hfileRanges.length * numOfRows, hfileRanges.length * numOfRows };<a name="line.403"></a>
+<span class="sourceLineNo">370</span>    } finally {<a name="line.370"></a>
+<span class="sourceLineNo">371</span>      close(htables);<a name="line.371"></a>
+<span class="sourceLineNo">372</span>      shutDownMiniClusters();<a name="line.372"></a>
+<span class="sourceLineNo">373</span>    }<a name="line.373"></a>
+<span class="sourceLineNo">374</span>  }<a name="line.374"></a>
+<span class="sourceLineNo">375</span><a name="line.375"></a>
+<span class="sourceLineNo">376</span>  /**<a name="line.376"></a>
+<span class="sourceLineNo">377</span>   * It tests the bulk loaded hfile replication scenario to only explicitly specified table column<a name="line.377"></a>
+<span class="sourceLineNo">378</span>   * families. It does it by bulk loading a set of HFiles belonging to both the CFs of table and set<a name="line.378"></a>
+<span class="sourceLineNo">379</span>   * only one CF data to replicate.<a name="line.379"></a>
+<span class="sourceLineNo">380</span>   */<a name="line.380"></a>
+<span class="sourceLineNo">381</span>  @Test(timeout = 300000)<a name="line.381"></a>
+<span class="sourceLineNo">382</span>  public void testHFileReplicationForConfiguredTableCfs() throws Exception {<a name="line.382"></a>
+<span class="sourceLineNo">383</span>    LOG.info("testHFileReplicationForConfiguredTableCfs");<a name="line.383"></a>
+<span class="sourceLineNo">384</span>    int numClusters = 2;<a name="line.384"></a>
+<span class="sourceLineNo">385</span>    Table[] htables = null;<a name="line.385"></a>
+<span class="sourceLineNo">386</span>    try {<a name="line.386"></a>
+<span class="sourceLineNo">387</span>      startMiniClusters(numClusters);<a name="line.387"></a>
+<span class="sourceLineNo">388</span>      createTableOnClusters(table);<a name="line.388"></a>
+<span class="sourceLineNo">389</span><a name="line.389"></a>
+<span class="sourceLineNo">390</span>      htables = getHTablesOnClusters(tableName);<a name="line.390"></a>
+<span class="sourceLineNo">391</span>      // Test the replication scenarios only 'f' is configured for table data replication not 'f1'<a name="line.391"></a>
+<span class="sourceLineNo">392</span>      addPeer("1", 0, 1, tableName.getNameAsString() + ":" + Bytes.toString(famName));<a name="line.392"></a>
+<span class="sourceLineNo">393</span><a name="line.393"></a>
+<span class="sourceLineNo">394</span>      // Load 100 rows for each hfile range in cluster '0' for table CF 'f'<a name="line.394"></a>
+<span class="sourceLineNo">395</span>      byte[][][] hfileRanges =<a name="line.395"></a>
+<span class="sourceLineNo">396</span>          new byte[][][] { new byte[][] { Bytes.toBytes("aaaa"), Bytes.toBytes("cccc") },<a name="line.396"></a>
+<span class="sourceLineNo">397</span>              new byte[][] { Bytes.toBytes("ddd"), Bytes.toBytes("fff") }, };<a name="line.397"></a>
+<span class="sourceLineNo">398</span>      int numOfRows = 100;<a name="line.398"></a>
+<span class="sourceLineNo">399</span>      int[] expectedCounts =<a name="line.399"></a>
+<span class="sourceLineNo">400</span>          new int[] { hfileRanges.length * numOfRows, hfileRanges.length * numOfRows };<a name="line.400"></a>
+<span class="sourceLineNo">401</span><a name="line.401"></a>
+<span class="sourceLineNo">402</span>      loadAndValidateHFileReplication("load_f", 0, new int[] { 1 }, row, famName, htables,<a name="line.402"></a>
+<span class="sourceLineNo">403</span>        hfileRanges, numOfRows, expectedCounts, true);<a name="line.403"></a>
 <span class="sourceLineNo">404</span><a name="line.404"></a>
-<span class="sourceLineNo">405</span>      loadAndValidateHFileReplication("load_f", 0, new int[] { 1 }, row, famName, htables,<a name="line.405"></a>
-<span class="sourceLineNo">406</span>        hfileRanges, numOfRows, expectedCounts, true);<a name="line.406"></a>
-<span class="sourceLineNo">407</span><a name="line.407"></a>
-<span class="sourceLineNo">408</span>      // Load 100 rows for each hfile range in cluster '0' for table CF 'f1'<a name="line.408"></a>
-<span class="sourceLineNo">409</span>      hfileRanges = new byte[][][] { new byte[][] { Bytes.toBytes("gggg"), Bytes.toBytes("iiii") },<a name="line.409"></a>
-<span class="sourceLineNo">410</span>          new byte[][] { Bytes.toBytes("jjj"), Bytes.toBytes("lll") }, };<a name="line.410"></a>
-<span class="sourceLineNo">411</span>      numOfRows = 100;<a name="line.411"></a>
+<span class="sourceLineNo">405</span>      // Load 100 rows for each hfile range in cluster '0' for table CF 'f1'<a name="line.405"></a>
+<span class="sourceLineNo">406</span>      hfileRanges = new byte[][][] { new byte[][] { Bytes.toBytes("gggg"), Bytes.toBytes("iiii") },<a name="line.406"></a>
+<span class="sourceLineNo">407</span>          new byte[][] { Bytes.toBytes("jjj"), Bytes.toBytes("lll") }, };<a name="line.407"></a>
+<span class="sourceLineNo">408</span>      numOfRows = 100;<a name="line.408"></a>
+<span class="sourceLineNo">409</span><a name="line.409"></a>
+<span class="sourceLineNo">410</span>      int[] newExpectedCounts =<a name="line.410"></a>
+<span class="sourceLineNo">411</span>          new int[] { hfileRanges.length * numOfRows + expectedCounts[0], expectedCounts[1] };<a name="line.411"></a>
 <span class="sourceLineNo">412</span><a name="line.412"></a>
-<span class="sourceLineNo">413</span>      int[] newExpectedCounts =<a name="line.413"></a>
-<span class="sourceLineNo">414</span>          new int[] { hfileRanges.length * numOfRows + expectedCounts[0], expectedCounts[1] };<a name="line.414"></a>
+<span class="sourceLineNo">413</span>      loadAndValidateHFileReplication("load_f1", 0, new int[] { 1 }, row, famName1, htables,<a name="line.413"></a>
+<span class="sourceLineNo">414</span>        hfileRanges, numOfRows, newExpectedCounts, false);<a name="line.414"></a>
 <span class="sourceLineNo">415</span><a name="line.415"></a>
-<span class="sourceLineNo">416</span>      loadAndValidateHFileReplication("load_f1", 0, new int[] { 1 }, row, famName1, htables,<a name="line.416"></a>
-<span class="sourceLineNo">417</span>        hfileRanges, numOfRows, newExpectedCounts, false);<a name="line.417"></a>
-<span class="sourceLineNo">418</span><a name="line.418"></a>
-<span class="sourceLineNo">419</span>      // Validate data replication for CF 'f1'<a name="line.419"></a>
+<span class="sourceLineNo">416</span>      // Validate data replication for CF 'f1'<a name="line.416"></a>
+<span class="sourceLineNo">417</span><a name="line.417"></a>
+<span class="sourceLineNo">418</span>      // Source cluster table should contain data for the families<a name="line.418"></a>
+<span class="sourceLineNo">419</span>      wait(0, htables[0], hfileRanges.length * numOfRows + expectedCounts[0]);<a name="line.419"></a>
 <span class="sourceLineNo">420</span><a name="line.420"></a>
-<span class="sourceLineNo">421</span>      // Source cluster table should contain data for the families<a name="line.421"></a>
-<span class="sourceLineNo">422</span>      wait(0, htables[0], hfileRanges.length * numOfRows + expectedCounts[0]);<a name="line.422"></a>
-<span class="sourceLineNo">423</span><a name="line.423"></a>
-<span class="sourceLineNo">424</span>      // Sleep for enough time so that the data is still not replicated for the CF which is not<a name="line.424"></a>
-<span class="sourceLineNo">425</span>      // configured for replication<a name="line.425"></a>
-<span class="sourceLineNo">426</span>      Thread.sleep((NB_RETRIES / 2) * SLEEP_TIME);<a name="line.426"></a>
-<span class="sourceLineNo">427</span>      // Peer cluster should have only configured CF data<a name="line.427"></a>
-<span class="sourceLineNo">428</span>      wait(1, htables[1], expectedCounts[1]);<a name="line.428"></a>
-<span class="sourceLineNo">429</span>    } finally {<a name="line.429"></a>
-<span class="sourceLineNo">430</span>      close(htables);<a name="line.430"></a>
-<span class="sourceLineNo">431</span>      shutDownMiniClusters();<a name="line.431"></a>
-<span class="sourceLineNo">432</span>    }<a name="line.432"></a>
-<span class="sourceLineNo">433</span>  }<a name="line.433"></a>
-<span class="sourceLineNo">434</span><a name="line.434"></a>
-<span class="sourceLineNo">435</span>  /**<a name="line.435"></a>
-<span class="sourceLineNo">436</span>   * Tests cyclic replication scenario of 0 -&gt; 1 -&gt; 2 -&gt; 1.<a name="line.436"></a>
-<span class="sourceLineNo">437</span>   */<a name="line.437"></a>
-<span class="sourceLineNo">438</span>  @Test(timeout = 300000)<a name="line.438"></a>
-<span class="sourceLineNo">439</span>  public void testCyclicReplication3() throws Exception {<a name="line.439"></a>
-<span class="sourceLineNo">440</span>    LOG.info("testCyclicReplication2");<a name="line.440"></a>
-<span class="sourceLineNo">441</span>    int numClusters = 3;<a name="line.441"></a>
-<span class="sourceLineNo">442</span>    Table[] htables = null;<a name="line.442"></a>
-<span class="sourceLineNo">443</span>    try {<a name="line.443"></a>
-<span class="sourceLineNo">444</span>      startMiniClusters(numClusters);<a name="line.444"></a>
-<span class="sourceLineNo">445</span>      createTableOnClusters(table);<a name="line.445"></a>
-<span class="sourceLineNo">446</span><a name="line.446"></a>
-<span class="sourceLineNo">447</span>      // Test the replication scenario of 0 -&gt; 1 -&gt; 2 -&gt; 1<a name="line.447"></a>
-<span class="sourceLineNo">448</span>      addPeer("1", 0, 1);<a name="line.448"></a>
-<span class="sourceLineNo">449</span>      addPeer("1", 1, 2);<a name="line.449"></a>
-<span class="sourceLineNo">450</span>      addPeer("1", 2, 1);<a name="line.450"></a>
-<span class="sourceLineNo">451</span><a name="line.451"></a>
-<span class="sourceLineNo">452</span>      htables = getHTablesOnClusters(tableName);<a name="line.452"></a>
-<span class="sourceLineNo">453</span><a name="line.453"></a>
-<span class="sourceLineNo">454</span>      // put "row" and wait 'til it got around<a name="line.454"></a>
-<span class="sourceLineNo">455</span>      putAndWait(row, famName, htables[0], htables[2]);<a name="line.455"></a>
-<span class="sourceLineNo">456</span>      putAndWait(row1, famName, htables[1], htables[2]);<a name="line.456"></a>
-<span class="sourceLineNo">457</span>      putAndWait(row2, famName, htables[2], htables[1]);<a name="line.457"></a>
-<span class="sourceLineNo">458</span><a name="line.458"></a>
-<span class="sourceLineNo">459</span>      deleteAndWait(row, htables[0], htables[2]);<a name="line.459"></a>
-<span class="sourceLineNo">460</span>      deleteAndWait(row1, htables[1], htables[2]);<a name="line.460"></a>
-<span class="sourceLineNo">461</span>      deleteAndWait(row2, htables[2], htables[1]);<a name="line.461"></a>
-<span class="sourceLineNo">462</span><a name="line.462"></a>
-<span class="sourceLineNo">463</span>      int[] expectedCounts = new int[] { 1, 3, 3 };<a name="line.463"></a>
-<span class="sourceLineNo">464</span>      validateCounts(htables, put, expectedCounts);<a name="line.464"></a>
-<span class="sourceLineNo">465</span>      validateCounts(htables, delete, expectedCounts);<a name="line.465"></a>
-<span class="sourceLineNo">466</span>    } finally {<a name="line.466"></a>
-<span class="sourceLineNo">467</span>      close(htables);<a name="line.467"></a>
-<span class="sourceLineNo">468</span>      shutDownMiniClusters();<a name="line.468"></a>
-<span class="sourceLineNo">469</span>    }<a name="line.469"></a>
-<span class="sourceLineNo">470</span>  }<a name="line.470"></a>
-<span class="sourceLineNo">471</span><a name="line.471"></a>
-<span class="sourceLineNo">472</span>  @After<a name="line.472"></a>
-<span class="sourceLineNo">473</span>  public void tearDown() throws IOException {<a name="line.473"></a>
-<span class="sourceLineNo">474</span>    configurations = null;<a name="line.474"></a>
-<span class="sourceLineNo">475</span>    utilities = null;<a name="line.475"></a>
-<span class="sourceLineNo">476</span>  }<a name="line.476"></a>
-<span class="sourceLineNo">477</span><a name="line.477"></a>
-<span class="sourceLineNo">478</span>  @SuppressWarnings("resource")<a name="line.478"></a>
-<span class="sourceLineNo">479</span>  private void startMiniClusters(int numClusters) throws Exception {<a name="line.479"></a>
-<span class="sourceLineNo">480</span>    Random random = new Random();<a name="line.480"></a>
-<span class="sourceLineNo">481</span>    utilities = new HBaseTestingUtility[numClusters];<a name="line.481"></a>
-<span class="sourceLineNo">482</span>    configurations = new Configuration[numClusters];<a name="line.482"></a>
-<span class="sourceLineNo">483</span>    for (int i = 0; i &lt; numClusters; i++) {<a name="line.483"></a>
-<span class="sourceLineNo">484</span>      Configuration conf = new Configuration(baseConfiguration);<a name="line.484"></a>
-<span class="sourceLineNo">485</span>      conf.set(HConstants.ZOOKEEPER_ZNODE_PARENT, "/" + i + random.nextInt());<a name="line.485"></a>
-<span class="sourceLineNo">486</span>      HBaseTestingUtility utility = new HBaseTestingUtility(conf);<a name="line.486"></a>
-<span class="sourceLineNo">487</span>      if (i == 0) {<a name="line.487"></a>
-<span class="sourceLineNo">488</span>        utility.startMiniZKCluster();<a name="line.488"></a>
-<span class="sourceLineNo">489</span>        miniZK = utility.getZkCluster();<a name="line.489"></a>
-<span class="sourceLineNo">490</span>      } else {<a name="line.490"></a>
-<span class="sourceLineNo">491</span>        utility.setZkCluster(miniZK);<a name="line.491"></a>
-<span class="sourceLineNo">492</span>      }<a name="line.492"></a>
-<span class="sourceLineNo">493</span>      utility.startMiniCluster();<a name="line.493"></a>
-<span class="sourceLineNo">494</span>      utilities[i] = utility;<a name="line.494"></a>
-<span class="sourceLineNo">495</span>      configurations[i] = conf;<a name="line.495"></a>
-<span class="sourceLineNo">496</span>      new ZKWatcher(conf, "cluster" + i, null, true);<a name="line.496"></a>
-<span class="sourceLineNo">497</span>    }<a name="line.497"></a>
-<span class="sourceLineNo">498</span>  }<a name="line.498"></a>
-<span class="sourceLineNo">499</span><a name="line.499"></a>
-<span class="sourceLineNo">500</span>  private void shutDownMiniClusters() throws Exception {<a name="line.500"></a>
-<span class="sourceLineNo">501</span>    int numClusters = utilities.length;<a name="line.501"></a>
-<span class="sourceLineNo">502</span>    for (int i = numClusters - 1; i &gt;= 0; i--) {<a name="line.502"></a>
-<span class="sourceLineNo">503</span>      if (utilities[i] != null) {<a name="line.503"></a>
-<span class="sourceLineNo">504</span>        utilities[i].shutdownMiniCluster();<a name="line.504"></a>
-<span class="sourceLineNo">505</span>      }<a name="line.505"></a>
-<span class="sourceLineNo">506</span>    }<a name="line.506"></a>
-<span class="sourceLineNo">507</span>    miniZK.shutdown();<a name="line.507"></a>
-<span class="sourceLineNo">508</span>  }<a name="line.508"></a>
-<span class="sourceLineNo">509</span><a name="line.509"></a>
-<span class="sourceLineNo">510</span>  private void createTableOnClusters(HTableDescriptor table) throws Exception {<a name="line.510"></a>
-<span class="sourceLineNo">511</span>    for (HBaseTestingUtility utility : utilities) {<a name="line.511"></a>
-<span class="sourceLineNo">512</span>      utility.getAdmin().createTable(table);<a name="line.512"></a>
-<span class="sourceLineNo">513</span>    }<a name="line.513"></a>
-<span class="sourceLineNo">514</span>  }<a name="line.514"></a>
-<span class="sourceLineNo">515</span><a name="line.515"></a>
-<span class="sourceLineNo">516</span>  private void addPeer(String id, int masterClusterNumber,<a name="line.516"></a>
-<span class="sourceLineNo">517</span>      int slaveClusterNumber) throws Exception {<a name="line.517"></a>
-<span class="sourceLineNo">518</span>    try (Admin admin = ConnectionFactory.createConnection(configurations[masterClusterNumber])<a name="line.518"></a>
-<span class="sourceLineNo">519</span>        .getAdmin()) {<a name="line.519"></a>
-<span class="sourceLineNo">520</span>      admin.addReplicationPeer(id,<a name="line.520"></a>
-<span class="sourceLineNo">521</span>        new ReplicationPeerConfig().setClusterKey(utilities[slaveClusterNumber].getClusterKey()));<a name="line.521"></a>
-<span class="sourceLineNo">522</span>    }<a name="line.522"></a>
-<span class="sourceLineNo">523</span>  }<a name="line.523"></a>
-<span class="sourceLineNo">524</span><a name="line.524"></a>
-<span class="sourceLineNo">525</span>  private void addPeer(String id, int masterClusterNumber, int slaveClusterNumber, String tableCfs)<a name="line.525"></a>
-<span class="sourceLineNo">526</span>      throws Exception {<a name="line.526"></a>
-<span class="sourceLineNo">527</span>    try (Admin admin =<a name="line.527"></a>
-<span class="sourceLineNo">528</span>        ConnectionFactory.createConnection(configurations[masterClusterNumber]).getAdmin()) {<a name="line.528"></a>
-<span class="sourceLineNo">529</span>      admin.addReplicationPeer(<a name="line.529"></a>
-<span class="sourceLineNo">530</span>        id,<a name="line.530"></a>
-<span class="sourceLineNo">531</span>        new ReplicationPeerConfig().setClusterKey(utilities[slaveClusterNumber].getClusterKey())<a name="line.531"></a>
-<span class="sourceLineNo">532</span>            .setReplicateAllUserTables(false)<a name="line.532"></a>
-<span class="sourceLineNo">533</s

<TRUNCATED>

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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/testdevapidocs/org/apache/hadoop/hbase/replication/TestMasterReplication.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/replication/TestMasterReplication.html b/testdevapidocs/org/apache/hadoop/hbase/replication/TestMasterReplication.html
index 6018c32..4e8960e 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/replication/TestMasterReplication.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/replication/TestMasterReplication.html
@@ -109,7 +109,7 @@ var activeTableTab = "activeTableTab";
 <li class="blockList">
 <hr>
 <br>
-<pre>public class <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.86">TestMasterReplication</a>
+<pre>public class <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.87">TestMasterReplication</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>
@@ -219,7 +219,7 @@ 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/replication/TestMasterReplication.html#SLEEP_TIME">SLEEP_TIME</a></span></code>&nbsp;</td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><code>private org.apache.hadoop.hbase.HTableDescriptor</code></td>
+<td class="colFirst"><code>private org.apache.hadoop.hbase.client.TableDescriptor</code></td>
 <td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/replication/TestMasterReplication.html#table">table</a></span></code>&nbsp;</td>
 </tr>
 <tr class="altColor">
@@ -281,7 +281,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 </tr>
 <tr id="i3" class="rowColor">
 <td class="colFirst"><code>private void</code></td>
-<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/replication/TestMasterReplication.html#createTableOnClusters-org.apache.hadoop.hbase.HTableDescriptor-">createTableOnClusters</a></span>(org.apache.hadoop.hbase.HTableDescriptor&nbsp;table)</code>&nbsp;</td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../org/apache/hadoop/hbase/replication/TestMasterReplication.html#createTableOnClusters-org.apache.hadoop.hbase.client.TableDescriptor-">createTableOnClusters</a></span>(org.apache.hadoop.hbase.client.TableDescriptor&nbsp;table)</code>&nbsp;</td>
 </tr>
 <tr id="i4" class="altColor">
 <td class="colFirst"><code>private void</code></td>
@@ -445,7 +445,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <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/replication/TestMasterReplication.html#line.88">LOG</a></pre>
+<pre>private static final&nbsp;org.apache.commons.logging.Log <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.89">LOG</a></pre>
 </li>
 </ul>
 <a name="baseConfiguration">
@@ -454,7 +454,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>baseConfiguration</h4>
-<pre>private&nbsp;org.apache.hadoop.conf.Configuration <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.90">baseConfiguration</a></pre>
+<pre>private&nbsp;org.apache.hadoop.conf.Configuration <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.91">baseConfiguration</a></pre>
 </li>
 </ul>
 <a name="utilities">
@@ -463,7 +463,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>utilities</h4>
-<pre>private&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/replication/TestMasterReplication.html#line.92">utilities</a></pre>
+<pre>private&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/replication/TestMasterReplication.html#line.93">utilities</a></pre>
 </li>
 </ul>
 <a name="configurations">
@@ -472,7 +472,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>configurations</h4>
-<pre>private&nbsp;org.apache.hadoop.conf.Configuration[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.93">configurations</a></pre>
+<pre>private&nbsp;org.apache.hadoop.conf.Configuration[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.94">configurations</a></pre>
 </li>
 </ul>
 <a name="miniZK">
@@ -481,7 +481,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>miniZK</h4>
-<pre>private&nbsp;org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.94">miniZK</a></pre>
+<pre>private&nbsp;org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.95">miniZK</a></pre>
 </li>
 </ul>
 <a name="SLEEP_TIME">
@@ -490,7 +490,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>SLEEP_TIME</h4>
-<pre>private static final&nbsp;long <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.96">SLEEP_TIME</a></pre>
+<pre>private static final&nbsp;long <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.97">SLEEP_TIME</a></pre>
 <dl>
 <dt><span class="seeLabel">See Also:</span></dt>
 <dd><a href="../../../../../constant-values.html#org.apache.hadoop.hbase.replication.TestMasterReplication.SLEEP_TIME">Constant Field Values</a></dd>
@@ -503,7 +503,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>NB_RETRIES</h4>
-<pre>private static final&nbsp;int <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.97">NB_RETRIES</a></pre>
+<pre>private static final&nbsp;int <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.98">NB_RETRIES</a></pre>
 <dl>
 <dt><span class="seeLabel">See Also:</span></dt>
 <dd><a href="../../../../../constant-values.html#org.apache.hadoop.hbase.replication.TestMasterReplication.NB_RETRIES">Constant Field Values</a></dd>
@@ -516,7 +516,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>tableName</h4>
-<pre>private static final&nbsp;org.apache.hadoop.hbase.TableName <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.99">tableName</a></pre>
+<pre>private static final&nbsp;org.apache.hadoop.hbase.TableName <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.100">tableName</a></pre>
 </li>
 </ul>
 <a name="famName">
@@ -525,7 +525,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>famName</h4>
-<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.100">famName</a></pre>
+<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.101">famName</a></pre>
 </li>
 </ul>
 <a name="famName1">
@@ -534,7 +534,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>famName1</h4>
-<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.101">famName1</a></pre>
+<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.102">famName1</a></pre>
 </li>
 </ul>
 <a name="row">
@@ -543,7 +543,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>row</h4>
-<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.102">row</a></pre>
+<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.103">row</a></pre>
 </li>
 </ul>
 <a name="row1">
@@ -552,7 +552,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>row1</h4>
-<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.103">row1</a></pre>
+<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.104">row1</a></pre>
 </li>
 </ul>
 <a name="row2">
@@ -561,7 +561,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>row2</h4>
-<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.104">row2</a></pre>
+<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.105">row2</a></pre>
 </li>
 </ul>
 <a name="row3">
@@ -570,7 +570,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>row3</h4>
-<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.105">row3</a></pre>
+<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.106">row3</a></pre>
 </li>
 </ul>
 <a name="row4">
@@ -579,7 +579,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>row4</h4>
-<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.106">row4</a></pre>
+<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.107">row4</a></pre>
 </li>
 </ul>
 <a name="noRepfamName">
@@ -588,7 +588,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>noRepfamName</h4>
-<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.107">noRepfamName</a></pre>
+<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.108">noRepfamName</a></pre>
 </li>
 </ul>
 <a name="count">
@@ -597,7 +597,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>count</h4>
-<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.109">count</a></pre>
+<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.110">count</a></pre>
 </li>
 </ul>
 <a name="put">
@@ -606,7 +606,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>put</h4>
-<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.110">put</a></pre>
+<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.111">put</a></pre>
 </li>
 </ul>
 <a name="delete">
@@ -615,7 +615,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>delete</h4>
-<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.111">delete</a></pre>
+<pre>private static final&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.112">delete</a></pre>
 </li>
 </ul>
 <a name="table">
@@ -624,7 +624,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>table</h4>
-<pre>private&nbsp;org.apache.hadoop.hbase.HTableDescriptor <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.113">table</a></pre>
+<pre>private&nbsp;org.apache.hadoop.hbase.client.TableDescriptor <a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.114">table</a></pre>
 </li>
 </ul>
 </li>
@@ -641,7 +641,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>TestMasterReplication</h4>
-<pre>public&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.86">TestMasterReplication</a>()</pre>
+<pre>public&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.87">TestMasterReplication</a>()</pre>
 </li>
 </ul>
 </li>
@@ -658,7 +658,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/replication/TestMasterReplication.html#line.116">setUp</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.117">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>
@@ -672,7 +672,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testCyclicReplication1</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.152">testCyclicReplication1</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.149">testCyclicReplication1</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">It tests the replication scenario involving 0 -> 1 -> 0. It does it by
  adding and deleting a row to a table in each cluster, checking if it's
@@ -690,7 +690,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testLoopedReplication</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.182">testLoopedReplication</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.179">testLoopedReplication</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">Tests the replication scenario 0 -> 0. By default
  <code>BaseReplicationEndpoint.canReplicateToSameCluster()</code> returns false, so the
@@ -707,7 +707,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testHFileCyclicReplication</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.219">testHFileCyclicReplication</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.216">testHFileCyclicReplication</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">It tests the replication scenario involving 0 -> 1 -> 0. It does it by bulk loading a set of
  HFiles to a table in each cluster, checking if it's replicated.</div>
@@ -723,7 +723,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>setUpClusterTablesAndPeers</h4>
-<pre>private&nbsp;org.apache.hadoop.hbase.client.Table[]&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.255">setUpClusterTablesAndPeers</a>(int&nbsp;numClusters)
+<pre>private&nbsp;org.apache.hadoop.hbase.client.Table[]&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.252">setUpClusterTablesAndPeers</a>(int&nbsp;numClusters)
                                                                    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>
@@ -737,7 +737,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testCyclicReplication2</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.275">testCyclicReplication2</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.272">testCyclicReplication2</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">Tests the cyclic replication scenario of 0 -> 1 -> 2 -> 0 by adding and deleting rows to a
  table in each clusters and ensuring that the each of these clusters get the appropriate
@@ -756,7 +756,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testHFileMultiSlaveReplication</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.327">testHFileMultiSlaveReplication</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.324">testHFileMultiSlaveReplication</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">It tests the multi slave hfile replication scenario involving 0 -> 1, 2. It does it by bulk
  loading a set of HFiles to a table in master cluster, checking if it's replicated in its peers.</div>
@@ -772,7 +772,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testHFileReplicationForConfiguredTableCfs</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.385">testHFileReplicationForConfiguredTableCfs</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.382">testHFileReplicationForConfiguredTableCfs</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">It tests the bulk loaded hfile replication scenario to only explicitly specified table column
  families. It does it by bulk loading a set of HFiles belonging to both the CFs of table and set
@@ -789,7 +789,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testCyclicReplication3</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.439">testCyclicReplication3</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.436">testCyclicReplication3</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">Tests cyclic replication scenario of 0 -> 1 -> 2 -> 1.</div>
 <dl>
@@ -804,7 +804,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/replication/TestMasterReplication.html#line.473">tearDown</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.470">tearDown</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>
 <dl>
 <dt><span class="throwsLabel">Throws:</span></dt>
@@ -818,7 +818,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>startMiniClusters</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.479">startMiniClusters</a>(int&nbsp;numClusters)
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.476">startMiniClusters</a>(int&nbsp;numClusters)
                         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>
@@ -832,7 +832,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>shutDownMiniClusters</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.500">shutDownMiniClusters</a>()
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.497">shutDownMiniClusters</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>
@@ -840,13 +840,13 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 </dl>
 </li>
 </ul>
-<a name="createTableOnClusters-org.apache.hadoop.hbase.HTableDescriptor-">
+<a name="createTableOnClusters-org.apache.hadoop.hbase.client.TableDescriptor-">
 <!--   -->
 </a>
 <ul class="blockList">
 <li class="blockList">
 <h4>createTableOnClusters</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.510">createTableOnClusters</a>(org.apache.hadoop.hbase.HTableDescriptor&nbsp;table)
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.507">createTableOnClusters</a>(org.apache.hadoop.hbase.client.TableDescriptor&nbsp;table)
                             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>
@@ -860,7 +860,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>addPeer</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.516">addPeer</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;id,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.513">addPeer</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;id,
                      int&nbsp;masterClusterNumber,
                      int&nbsp;slaveClusterNumber)
               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>
@@ -876,7 +876,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>addPeer</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.525">addPeer</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;id,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.522">addPeer</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;id,
                      int&nbsp;masterClusterNumber,
                      int&nbsp;slaveClusterNumber,
                      <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;tableCfs)
@@ -893,7 +893,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>disablePeer</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.537">disablePeer</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;id,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.534">disablePeer</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;id,
                          int&nbsp;masterClusterNumber)
                   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>
@@ -908,7 +908,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>enablePeer</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.544">enablePeer</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;id,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.541">enablePeer</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;id,
                         int&nbsp;masterClusterNumber)
                  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>
@@ -923,7 +923,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>close</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.551">close</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/io/Closeable.html?is-external=true" title="class or interface in java.io">Closeable</a>...&nbsp;closeables)</pre>
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.548">close</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/io/Closeable.html?is-external=true" title="class or interface in java.io">Closeable</a>...&nbsp;closeables)</pre>
 </li>
 </ul>
 <a name="getHTablesOnClusters-org.apache.hadoop.hbase.TableName-">
@@ -932,7 +932,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>getHTablesOnClusters</h4>
-<pre>private&nbsp;org.apache.hadoop.hbase.client.Table[]&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.564">getHTablesOnClusters</a>(org.apache.hadoop.hbase.TableName&nbsp;tableName)
+<pre>private&nbsp;org.apache.hadoop.hbase.client.Table[]&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.561">getHTablesOnClusters</a>(org.apache.hadoop.hbase.TableName&nbsp;tableName)
                                                              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>
@@ -946,7 +946,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>validateCounts</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.574">validateCounts</a>(org.apache.hadoop.hbase.client.Table[]&nbsp;htables,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.571">validateCounts</a>(org.apache.hadoop.hbase.client.Table[]&nbsp;htables,
                             byte[]&nbsp;type,
                             int[]&nbsp;expectedCounts)
                      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>
@@ -962,7 +962,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>getCount</h4>
-<pre>private&nbsp;int&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.582">getCount</a>(org.apache.hadoop.hbase.client.Table&nbsp;t,
+<pre>private&nbsp;int&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.579">getCount</a>(org.apache.hadoop.hbase.client.Table&nbsp;t,
                      byte[]&nbsp;type)
               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>
@@ -977,7 +977,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>deleteAndWait</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.589">deleteAndWait</a>(byte[]&nbsp;row,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.586">deleteAndWait</a>(byte[]&nbsp;row,
                            org.apache.hadoop.hbase.client.Table&nbsp;source,
                            org.apache.hadoop.hbase.client.Table&nbsp;target)
                     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>
@@ -993,7 +993,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>putAndWait</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.596">putAndWait</a>(byte[]&nbsp;row,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.593">putAndWait</a>(byte[]&nbsp;row,
                         byte[]&nbsp;fam,
                         org.apache.hadoop.hbase.client.Table&nbsp;source,
                         org.apache.hadoop.hbase.client.Table&nbsp;target)
@@ -1010,7 +1010,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>loadAndValidateHFileReplication</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.604">loadAndValidateHFileReplication</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;testName,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.601">loadAndValidateHFileReplication</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;testName,
                                              int&nbsp;masterNumber,
                                              int[]&nbsp;slaveNumbers,
                                              byte[]&nbsp;row,
@@ -1033,7 +1033,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>wait</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.635">wait</a>(int&nbsp;slaveNumber,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.632">wait</a>(int&nbsp;slaveNumber,
                   org.apache.hadoop.hbase.client.Table&nbsp;target,
                   int&nbsp;expectedCount)
            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>,
@@ -1051,7 +1051,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>wait</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.653">wait</a>(byte[]&nbsp;row,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.650">wait</a>(byte[]&nbsp;row,
                   org.apache.hadoop.hbase.client.Table&nbsp;target,
                   boolean&nbsp;isDeleted)
            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>
@@ -1067,7 +1067,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>rollWALAndWait</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.677">rollWALAndWait</a>(<a href="../../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility</a>&nbsp;utility,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/replication/TestMasterReplication.html#line.674">rollWALAndWait</a>(<a href="../../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility</a>&nbsp;utility,
                             org.apache.hadoop.hbase.TableName&nbsp;table,
                             byte[]&nbsp;row)
                      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>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 b15b625..18aadff 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/test/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/test/package-tree.html
@@ -254,9 +254,9 @@
 <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/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.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/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.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/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/a80edfec/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 644d9f7..dd4469a 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/wal/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/wal/package-tree.html
@@ -136,9 +136,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.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/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>
+<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>
 </ul>
 </li>
 </ul>


[8/8] 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/a80edfec
Tree: http://git-wip-us.apache.org/repos/asf/hbase-site/tree/a80edfec
Diff: http://git-wip-us.apache.org/repos/asf/hbase-site/diff/a80edfec

Branch: refs/heads/asf-site
Commit: a80edfecafa87e74cbad5ee7ee1ece4a3113e74a
Parents: abbe3df
Author: jenkins <bu...@apache.org>
Authored: Mon Dec 18 15:17:10 2017 +0000
Committer: jenkins <bu...@apache.org>
Committed: Mon Dec 18 15:17:10 2017 +0000

----------------------------------------------------------------------
 acid-semantics.html                             |    4 +-
 apache_hbase_reference_guide.pdf                | 9950 +++++++++---------
 book.html                                       |    6 +-
 bulk-loads.html                                 |    4 +-
 checkstyle-aggregate.html                       |   82 +-
 checkstyle.rss                                  |    4 +-
 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 +-
 testdevapidocs/index-all.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/procedure2/package-tree.html   |    2 +-
 .../hadoop/hbase/regionserver/package-tree.html |    4 +-
 ...estMasterReplication.CoprocessorCounter.html |   16 +-
 .../replication/TestMasterReplication.html      |  104 +-
 .../apache/hadoop/hbase/test/package-tree.html  |    2 +-
 .../apache/hadoop/hbase/wal/package-tree.html   |    2 +-
 ...estMasterReplication.CoprocessorCounter.html | 1391 ++-
 .../replication/TestMasterReplication.html      | 1391 ++-
 177 files changed, 6804 insertions(+), 6812 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/acid-semantics.html
----------------------------------------------------------------------
diff --git a/acid-semantics.html b/acid-semantics.html
index daf0780..8e6730d 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 


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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 3813361..7377e05 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -810,7 +810,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 928ea8a..ee21a8f 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 b7d96a8..04a2ba3 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 79ba882..9b7c8ef 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 e74e75e..1e1ee8d 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 1ed4d7a..40c0b02 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 ec02c6d..c03f24a 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 e4940e6..0d2df3c 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 7719272..291891d 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 91b6f11..a44017a 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 57c2e20..0c2e12c 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 a1b28b0..eb7243c 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 806217c..060287d 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 15e050c..06b6131 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 d8e3ad7..c0569f2 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -4194,7 +4194,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 b319565..d17344c 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -829,7 +829,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 cf76acd..b75af19 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 921a375..70c0c51 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -810,7 +810,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 12b67ea..c2a73c9 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 be9de6d..099b586 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 3e7cfde..944299c 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 a935e7e..2e598b4 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 ec6eba5..772c053 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 4fca91a..184e629 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 2493313..ebf809b 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 fe16d5d..3e3fae2 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 9bc200f..b23bc4c 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 ba8b641..cb8e8d2 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 02cfa3f..570dc78 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 eb54fe8..09d0430 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 bb9fa38..aef1c21 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 6eca0bd..f403688 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 9b4ab0f..7523d4b 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 d095da3..ae04ede 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 92d1e5e..a456c4f 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 40e3bb6..b90a1fb 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 cc18284..4e5c6d3 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 7920c62..a6b6f87 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 f30dde9..ef69bb1 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 afe59a2..f4fd1e0 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 c056ec0..9f7b545 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 0df61e4..66e9c50 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 592c5a4..23fe2dd 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -5692,7 +5692,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 2e1d060..01dfe60 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -829,7 +829,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 fa53bb8..58034e6 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 2e1c469..4cd2ee7 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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" />
@@ -810,7 +810,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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 a8cbd91..1d3cb9b 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 15e6e7e..69868e2 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 894c41f..19a028d 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 7fc884d..b522cf8 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 45d4d30..669b26f 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 cd2a362..91cdfe4 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 a0d1595..3d3ac53 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 50fe301..f8ad7ae 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 9fd97ea..4e764a5 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 dfcdb6b..bbb5057 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 27a6699..5694615 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/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 4427387..aa86885 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-build-configuration/index.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/index.html b/hbase-build-configuration/index.html
index 69efaa8..2f0fbb6 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-build-configuration/integration.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/integration.html b/hbase-build-configuration/integration.html
index 80665bc..11d0c16 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-build-configuration/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/issue-tracking.html b/hbase-build-configuration/issue-tracking.html
index 9fad34e..7207e36 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/a80edfec/hbase-build-configuration/license.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/license.html b/hbase-build-configuration/license.html
index c9aa727..9d88066 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="20171217" />
+    <meta name="Date-Revision-yyyymmdd" content="20171218" />
     <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-17</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2017-12-18</li>
             </p>
                 </div>