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 2018/02/12 15:16:56 UTC

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

Repository: hbase-site
Updated Branches:
  refs/heads/asf-site 0f5c75b81 -> 2fda40d6c


http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/testdevapidocs/src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html b/testdevapidocs/src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html
index 0e73425..faa3100 100644
--- a/testdevapidocs/src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html
+++ b/testdevapidocs/src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html
@@ -52,358 +52,396 @@
 <span class="sourceLineNo">044</span>import org.apache.hadoop.hbase.KeyValue;<a name="line.44"></a>
 <span class="sourceLineNo">045</span>import org.apache.hadoop.hbase.Stoppable;<a name="line.45"></a>
 <span class="sourceLineNo">046</span>import org.apache.hadoop.hbase.TableName;<a name="line.46"></a>
-<span class="sourceLineNo">047</span>import org.apache.hadoop.hbase.client.Connection;<a name="line.47"></a>
-<span class="sourceLineNo">048</span>import org.apache.hadoop.hbase.client.ConnectionFactory;<a name="line.48"></a>
-<span class="sourceLineNo">049</span>import org.apache.hadoop.hbase.client.Get;<a name="line.49"></a>
-<span class="sourceLineNo">050</span>import org.apache.hadoop.hbase.client.RegionLocator;<a name="line.50"></a>
-<span class="sourceLineNo">051</span>import org.apache.hadoop.hbase.client.Result;<a name="line.51"></a>
-<span class="sourceLineNo">052</span>import org.apache.hadoop.hbase.client.ResultScanner;<a name="line.52"></a>
-<span class="sourceLineNo">053</span>import org.apache.hadoop.hbase.client.Scan;<a name="line.53"></a>
-<span class="sourceLineNo">054</span>import org.apache.hadoop.hbase.client.Table;<a name="line.54"></a>
-<span class="sourceLineNo">055</span>import org.apache.hadoop.hbase.testclassification.MediumTests;<a name="line.55"></a>
-<span class="sourceLineNo">056</span>import org.apache.hadoop.hbase.testclassification.ReplicationTests;<a name="line.56"></a>
-<span class="sourceLineNo">057</span>import org.apache.hadoop.hbase.util.Bytes;<a name="line.57"></a>
-<span class="sourceLineNo">058</span>import org.apache.hadoop.hbase.util.FSUtils;<a name="line.58"></a>
-<span class="sourceLineNo">059</span>import org.apache.hadoop.hbase.util.HFileTestUtil;<a name="line.59"></a>
-<span class="sourceLineNo">060</span>import org.junit.AfterClass;<a name="line.60"></a>
-<span class="sourceLineNo">061</span>import org.junit.Before;<a name="line.61"></a>
-<span class="sourceLineNo">062</span>import org.junit.BeforeClass;<a name="line.62"></a>
-<span class="sourceLineNo">063</span>import org.junit.ClassRule;<a name="line.63"></a>
-<span class="sourceLineNo">064</span>import org.junit.Test;<a name="line.64"></a>
-<span class="sourceLineNo">065</span>import org.junit.experimental.categories.Category;<a name="line.65"></a>
-<span class="sourceLineNo">066</span>import org.slf4j.Logger;<a name="line.66"></a>
-<span class="sourceLineNo">067</span>import org.slf4j.LoggerFactory;<a name="line.67"></a>
-<span class="sourceLineNo">068</span><a name="line.68"></a>
-<span class="sourceLineNo">069</span>import org.apache.hbase.thirdparty.com.google.protobuf.UnsafeByteOperations;<a name="line.69"></a>
-<span class="sourceLineNo">070</span><a name="line.70"></a>
-<span class="sourceLineNo">071</span>import org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil;<a name="line.71"></a>
-<span class="sourceLineNo">072</span>import org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry;<a name="line.72"></a>
-<span class="sourceLineNo">073</span>import org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.UUID;<a name="line.73"></a>
-<span class="sourceLineNo">074</span>import org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos;<a name="line.74"></a>
-<span class="sourceLineNo">075</span>import org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.WALKey;<a name="line.75"></a>
-<span class="sourceLineNo">076</span><a name="line.76"></a>
-<span class="sourceLineNo">077</span>@Category({ReplicationTests.class, MediumTests.class})<a name="line.77"></a>
-<span class="sourceLineNo">078</span>public class TestReplicationSink {<a name="line.78"></a>
-<span class="sourceLineNo">079</span><a name="line.79"></a>
-<span class="sourceLineNo">080</span>  @ClassRule<a name="line.80"></a>
-<span class="sourceLineNo">081</span>  public static final HBaseClassTestRule CLASS_RULE =<a name="line.81"></a>
-<span class="sourceLineNo">082</span>      HBaseClassTestRule.forClass(TestReplicationSink.class);<a name="line.82"></a>
+<span class="sourceLineNo">047</span>import org.apache.hadoop.hbase.TableNotFoundException;<a name="line.47"></a>
+<span class="sourceLineNo">048</span>import org.apache.hadoop.hbase.client.Admin;<a name="line.48"></a>
+<span class="sourceLineNo">049</span>import org.apache.hadoop.hbase.client.Connection;<a name="line.49"></a>
+<span class="sourceLineNo">050</span>import org.apache.hadoop.hbase.client.ConnectionFactory;<a name="line.50"></a>
+<span class="sourceLineNo">051</span>import org.apache.hadoop.hbase.client.Get;<a name="line.51"></a>
+<span class="sourceLineNo">052</span>import org.apache.hadoop.hbase.client.RegionLocator;<a name="line.52"></a>
+<span class="sourceLineNo">053</span>import org.apache.hadoop.hbase.client.Result;<a name="line.53"></a>
+<span class="sourceLineNo">054</span>import org.apache.hadoop.hbase.client.ResultScanner;<a name="line.54"></a>
+<span class="sourceLineNo">055</span>import org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException;<a name="line.55"></a>
+<span class="sourceLineNo">056</span>import org.apache.hadoop.hbase.client.Scan;<a name="line.56"></a>
+<span class="sourceLineNo">057</span>import org.apache.hadoop.hbase.client.Table;<a name="line.57"></a>
+<span class="sourceLineNo">058</span>import org.apache.hadoop.hbase.testclassification.MediumTests;<a name="line.58"></a>
+<span class="sourceLineNo">059</span>import org.apache.hadoop.hbase.testclassification.ReplicationTests;<a name="line.59"></a>
+<span class="sourceLineNo">060</span>import org.apache.hadoop.hbase.util.Bytes;<a name="line.60"></a>
+<span class="sourceLineNo">061</span>import org.apache.hadoop.hbase.util.FSUtils;<a name="line.61"></a>
+<span class="sourceLineNo">062</span>import org.apache.hadoop.hbase.util.HFileTestUtil;<a name="line.62"></a>
+<span class="sourceLineNo">063</span>import org.junit.AfterClass;<a name="line.63"></a>
+<span class="sourceLineNo">064</span>import org.junit.Assert;<a name="line.64"></a>
+<span class="sourceLineNo">065</span>import org.junit.Before;<a name="line.65"></a>
+<span class="sourceLineNo">066</span>import org.junit.BeforeClass;<a name="line.66"></a>
+<span class="sourceLineNo">067</span>import org.junit.ClassRule;<a name="line.67"></a>
+<span class="sourceLineNo">068</span>import org.junit.Test;<a name="line.68"></a>
+<span class="sourceLineNo">069</span>import org.junit.experimental.categories.Category;<a name="line.69"></a>
+<span class="sourceLineNo">070</span>import org.slf4j.Logger;<a name="line.70"></a>
+<span class="sourceLineNo">071</span>import org.slf4j.LoggerFactory;<a name="line.71"></a>
+<span class="sourceLineNo">072</span><a name="line.72"></a>
+<span class="sourceLineNo">073</span>import org.apache.hbase.thirdparty.com.google.protobuf.UnsafeByteOperations;<a name="line.73"></a>
+<span class="sourceLineNo">074</span><a name="line.74"></a>
+<span class="sourceLineNo">075</span>import org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil;<a name="line.75"></a>
+<span class="sourceLineNo">076</span>import org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry;<a name="line.76"></a>
+<span class="sourceLineNo">077</span>import org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.UUID;<a name="line.77"></a>
+<span class="sourceLineNo">078</span>import org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos;<a name="line.78"></a>
+<span class="sourceLineNo">079</span>import org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.WALKey;<a name="line.79"></a>
+<span class="sourceLineNo">080</span><a name="line.80"></a>
+<span class="sourceLineNo">081</span>@Category({ReplicationTests.class, MediumTests.class})<a name="line.81"></a>
+<span class="sourceLineNo">082</span>public class TestReplicationSink {<a name="line.82"></a>
 <span class="sourceLineNo">083</span><a name="line.83"></a>
-<span class="sourceLineNo">084</span>  private static final Logger LOG = LoggerFactory.getLogger(TestReplicationSink.class);<a name="line.84"></a>
-<span class="sourceLineNo">085</span>  private static final int BATCH_SIZE = 10;<a name="line.85"></a>
-<span class="sourceLineNo">086</span><a name="line.86"></a>
-<span class="sourceLineNo">087</span>  protected final static HBaseTestingUtility TEST_UTIL = new HBaseTestingUtility();<a name="line.87"></a>
-<span class="sourceLineNo">088</span><a name="line.88"></a>
-<span class="sourceLineNo">089</span>  protected static ReplicationSink SINK;<a name="line.89"></a>
+<span class="sourceLineNo">084</span>  @ClassRule<a name="line.84"></a>
+<span class="sourceLineNo">085</span>  public static final HBaseClassTestRule CLASS_RULE =<a name="line.85"></a>
+<span class="sourceLineNo">086</span>      HBaseClassTestRule.forClass(TestReplicationSink.class);<a name="line.86"></a>
+<span class="sourceLineNo">087</span><a name="line.87"></a>
+<span class="sourceLineNo">088</span>  private static final Logger LOG = LoggerFactory.getLogger(TestReplicationSink.class);<a name="line.88"></a>
+<span class="sourceLineNo">089</span>  private static final int BATCH_SIZE = 10;<a name="line.89"></a>
 <span class="sourceLineNo">090</span><a name="line.90"></a>
-<span class="sourceLineNo">091</span>  protected static final TableName TABLE_NAME1 = TableName.valueOf("table1");<a name="line.91"></a>
-<span class="sourceLineNo">092</span>  protected static final TableName TABLE_NAME2 = TableName.valueOf("table2");<a name="line.92"></a>
-<span class="sourceLineNo">093</span><a name="line.93"></a>
-<span class="sourceLineNo">094</span>  protected static final byte[] FAM_NAME1 = Bytes.toBytes("info1");<a name="line.94"></a>
-<span class="sourceLineNo">095</span>  protected static final byte[] FAM_NAME2 = Bytes.toBytes("info2");<a name="line.95"></a>
-<span class="sourceLineNo">096</span><a name="line.96"></a>
-<span class="sourceLineNo">097</span>  protected static Table table1;<a name="line.97"></a>
-<span class="sourceLineNo">098</span>  protected static Stoppable STOPPABLE = new Stoppable() {<a name="line.98"></a>
-<span class="sourceLineNo">099</span>    final AtomicBoolean stop = new AtomicBoolean(false);<a name="line.99"></a>
+<span class="sourceLineNo">091</span>  protected final static HBaseTestingUtility TEST_UTIL = new HBaseTestingUtility();<a name="line.91"></a>
+<span class="sourceLineNo">092</span><a name="line.92"></a>
+<span class="sourceLineNo">093</span>  protected static ReplicationSink SINK;<a name="line.93"></a>
+<span class="sourceLineNo">094</span><a name="line.94"></a>
+<span class="sourceLineNo">095</span>  protected static final TableName TABLE_NAME1 = TableName.valueOf("table1");<a name="line.95"></a>
+<span class="sourceLineNo">096</span>  protected static final TableName TABLE_NAME2 = TableName.valueOf("table2");<a name="line.96"></a>
+<span class="sourceLineNo">097</span><a name="line.97"></a>
+<span class="sourceLineNo">098</span>  protected static final byte[] FAM_NAME1 = Bytes.toBytes("info1");<a name="line.98"></a>
+<span class="sourceLineNo">099</span>  protected static final byte[] FAM_NAME2 = Bytes.toBytes("info2");<a name="line.99"></a>
 <span class="sourceLineNo">100</span><a name="line.100"></a>
-<span class="sourceLineNo">101</span>    @Override<a name="line.101"></a>
-<span class="sourceLineNo">102</span>    public boolean isStopped() {<a name="line.102"></a>
-<span class="sourceLineNo">103</span>      return this.stop.get();<a name="line.103"></a>
-<span class="sourceLineNo">104</span>    }<a name="line.104"></a>
-<span class="sourceLineNo">105</span><a name="line.105"></a>
-<span class="sourceLineNo">106</span>    @Override<a name="line.106"></a>
-<span class="sourceLineNo">107</span>    public void stop(String why) {<a name="line.107"></a>
-<span class="sourceLineNo">108</span>      LOG.info("STOPPING BECAUSE: " + why);<a name="line.108"></a>
-<span class="sourceLineNo">109</span>      this.stop.set(true);<a name="line.109"></a>
-<span class="sourceLineNo">110</span>    }<a name="line.110"></a>
-<span class="sourceLineNo">111</span><a name="line.111"></a>
-<span class="sourceLineNo">112</span>  };<a name="line.112"></a>
-<span class="sourceLineNo">113</span><a name="line.113"></a>
-<span class="sourceLineNo">114</span>  protected static Table table2;<a name="line.114"></a>
-<span class="sourceLineNo">115</span>  protected static String baseNamespaceDir;<a name="line.115"></a>
-<span class="sourceLineNo">116</span>  protected static String hfileArchiveDir;<a name="line.116"></a>
-<span class="sourceLineNo">117</span>  protected static String replicationClusterId;<a name="line.117"></a>
-<span class="sourceLineNo">118</span><a name="line.118"></a>
-<span class="sourceLineNo">119</span>   /**<a name="line.119"></a>
-<span class="sourceLineNo">120</span>   * @throws java.lang.Exception<a name="line.120"></a>
-<span class="sourceLineNo">121</span>   */<a name="line.121"></a>
-<span class="sourceLineNo">122</span>  @BeforeClass<a name="line.122"></a>
-<span class="sourceLineNo">123</span>  public static void setUpBeforeClass() throws Exception {<a name="line.123"></a>
-<span class="sourceLineNo">124</span>    TEST_UTIL.getConfiguration().set("hbase.replication.source.fs.conf.provider",<a name="line.124"></a>
-<span class="sourceLineNo">125</span>      TestSourceFSConfigurationProvider.class.getCanonicalName());<a name="line.125"></a>
-<span class="sourceLineNo">126</span><a name="line.126"></a>
-<span class="sourceLineNo">127</span>    TEST_UTIL.startMiniCluster(3);<a name="line.127"></a>
-<span class="sourceLineNo">128</span>    SINK =<a name="line.128"></a>
-<span class="sourceLineNo">129</span>      new ReplicationSink(new Configuration(TEST_UTIL.getConfiguration()), STOPPABLE);<a name="line.129"></a>
-<span class="sourceLineNo">130</span>    table1 = TEST_UTIL.createTable(TABLE_NAME1, FAM_NAME1);<a name="line.130"></a>
-<span class="sourceLineNo">131</span>    table2 = TEST_UTIL.createTable(TABLE_NAME2, FAM_NAME2);<a name="line.131"></a>
-<span class="sourceLineNo">132</span>    Path rootDir = FSUtils.getRootDir(TEST_UTIL.getConfiguration());<a name="line.132"></a>
-<span class="sourceLineNo">133</span>    baseNamespaceDir = new Path(rootDir, new Path(HConstants.BASE_NAMESPACE_DIR)).toString();<a name="line.133"></a>
-<span class="sourceLineNo">134</span>    hfileArchiveDir = new Path(rootDir, new Path(HConstants.HFILE_ARCHIVE_DIRECTORY)).toString();<a name="line.134"></a>
-<span class="sourceLineNo">135</span>    replicationClusterId = "12345";<a name="line.135"></a>
-<span class="sourceLineNo">136</span>  }<a name="line.136"></a>
-<span class="sourceLineNo">137</span><a name="line.137"></a>
-<span class="sourceLineNo">138</span>  /**<a name="line.138"></a>
-<span class="sourceLineNo">139</span>   * @throws java.lang.Exception<a name="line.139"></a>
-<span class="sourceLineNo">140</span>   */<a name="line.140"></a>
-<span class="sourceLineNo">141</span>  @AfterClass<a name="line.141"></a>
-<span class="sourceLineNo">142</span>  public static void tearDownAfterClass() throws Exception {<a name="line.142"></a>
-<span class="sourceLineNo">143</span>    STOPPABLE.stop("Shutting down");<a name="line.143"></a>
-<span class="sourceLineNo">144</span>    TEST_UTIL.shutdownMiniCluster();<a name="line.144"></a>
-<span class="sourceLineNo">145</span>  }<a name="line.145"></a>
-<span class="sourceLineNo">146</span><a name="line.146"></a>
-<span class="sourceLineNo">147</span>  /**<a name="line.147"></a>
-<span class="sourceLineNo">148</span>   * @throws java.lang.Exception<a name="line.148"></a>
-<span class="sourceLineNo">149</span>   */<a name="line.149"></a>
-<span class="sourceLineNo">150</span>  @Before<a name="line.150"></a>
-<span class="sourceLineNo">151</span>  public void setUp() throws Exception {<a name="line.151"></a>
-<span class="sourceLineNo">152</span>    table1 = TEST_UTIL.deleteTableData(TABLE_NAME1);<a name="line.152"></a>
-<span class="sourceLineNo">153</span>    table2 = TEST_UTIL.deleteTableData(TABLE_NAME2);<a name="line.153"></a>
-<span class="sourceLineNo">154</span>  }<a name="line.154"></a>
-<span class="sourceLineNo">155</span><a name="line.155"></a>
-<span class="sourceLineNo">156</span>  /**<a name="line.156"></a>
-<span class="sourceLineNo">157</span>   * Insert a whole batch of entries<a name="line.157"></a>
-<span class="sourceLineNo">158</span>   * @throws Exception<a name="line.158"></a>
-<span class="sourceLineNo">159</span>   */<a name="line.159"></a>
-<span class="sourceLineNo">160</span>  @Test<a name="line.160"></a>
-<span class="sourceLineNo">161</span>  public void testBatchSink() throws Exception {<a name="line.161"></a>
-<span class="sourceLineNo">162</span>    List&lt;WALEntry&gt; entries = new ArrayList&lt;&gt;(BATCH_SIZE);<a name="line.162"></a>
-<span class="sourceLineNo">163</span>    List&lt;Cell&gt; cells = new ArrayList&lt;&gt;();<a name="line.163"></a>
-<span class="sourceLineNo">164</span>    for(int i = 0; i &lt; BATCH_SIZE; i++) {<a name="line.164"></a>
-<span class="sourceLineNo">165</span>      entries.add(createEntry(TABLE_NAME1, i, KeyValue.Type.Put, cells));<a name="line.165"></a>
-<span class="sourceLineNo">166</span>    }<a name="line.166"></a>
-<span class="sourceLineNo">167</span>    SINK.replicateEntries(entries, CellUtil.createCellScanner(cells.iterator()),<a name="line.167"></a>
-<span class="sourceLineNo">168</span>      replicationClusterId, baseNamespaceDir, hfileArchiveDir);<a name="line.168"></a>
-<span class="sourceLineNo">169</span>    Scan scan = new Scan();<a name="line.169"></a>
-<span class="sourceLineNo">170</span>    ResultScanner scanRes = table1.getScanner(scan);<a name="line.170"></a>
-<span class="sourceLineNo">171</span>    assertEquals(BATCH_SIZE, scanRes.next(BATCH_SIZE).length);<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>  /**<a name="line.174"></a>
-<span class="sourceLineNo">175</span>   * Insert a mix of puts and deletes<a name="line.175"></a>
-<span class="sourceLineNo">176</span>   * @throws Exception<a name="line.176"></a>
-<span class="sourceLineNo">177</span>   */<a name="line.177"></a>
-<span class="sourceLineNo">178</span>  @Test<a name="line.178"></a>
-<span class="sourceLineNo">179</span>  public void testMixedPutDelete() throws Exception {<a name="line.179"></a>
-<span class="sourceLineNo">180</span>    List&lt;WALEntry&gt; entries = new ArrayList&lt;&gt;(BATCH_SIZE/2);<a name="line.180"></a>
-<span class="sourceLineNo">181</span>    List&lt;Cell&gt; cells = new ArrayList&lt;&gt;();<a name="line.181"></a>
-<span class="sourceLineNo">182</span>    for(int i = 0; i &lt; BATCH_SIZE/2; i++) {<a name="line.182"></a>
-<span class="sourceLineNo">183</span>      entries.add(createEntry(TABLE_NAME1, i, KeyValue.Type.Put, cells));<a name="line.183"></a>
-<span class="sourceLineNo">184</span>    }<a name="line.184"></a>
-<span class="sourceLineNo">185</span>    SINK.replicateEntries(entries, CellUtil.createCellScanner(cells), replicationClusterId,<a name="line.185"></a>
-<span class="sourceLineNo">186</span>      baseNamespaceDir, hfileArchiveDir);<a name="line.186"></a>
-<span class="sourceLineNo">187</span><a name="line.187"></a>
-<span class="sourceLineNo">188</span>    entries = new ArrayList&lt;&gt;(BATCH_SIZE);<a name="line.188"></a>
-<span class="sourceLineNo">189</span>    cells = new ArrayList&lt;&gt;();<a name="line.189"></a>
-<span class="sourceLineNo">190</span>    for(int i = 0; i &lt; BATCH_SIZE; i++) {<a name="line.190"></a>
-<span class="sourceLineNo">191</span>      entries.add(createEntry(TABLE_NAME1, i,<a name="line.191"></a>
-<span class="sourceLineNo">192</span>          i % 2 != 0 ? KeyValue.Type.Put: KeyValue.Type.DeleteColumn, cells));<a name="line.192"></a>
-<span class="sourceLineNo">193</span>    }<a name="line.193"></a>
-<span class="sourceLineNo">194</span><a name="line.194"></a>
-<span class="sourceLineNo">195</span>    SINK.replicateEntries(entries, CellUtil.createCellScanner(cells.iterator()),<a name="line.195"></a>
-<span class="sourceLineNo">196</span>      replicationClusterId, baseNamespaceDir, hfileArchiveDir);<a name="line.196"></a>
-<span class="sourceLineNo">197</span>    Scan scan = new Scan();<a name="line.197"></a>
-<span class="sourceLineNo">198</span>    ResultScanner scanRes = table1.getScanner(scan);<a name="line.198"></a>
-<span class="sourceLineNo">199</span>    assertEquals(BATCH_SIZE/2, scanRes.next(BATCH_SIZE).length);<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>   * Insert to 2 different tables<a name="line.203"></a>
-<span class="sourceLineNo">204</span>   * @throws Exception<a name="line.204"></a>
-<span class="sourceLineNo">205</span>   */<a name="line.205"></a>
-<span class="sourceLineNo">206</span>  @Test<a name="line.206"></a>
-<span class="sourceLineNo">207</span>  public void testMixedPutTables() throws Exception {<a name="line.207"></a>
-<span class="sourceLineNo">208</span>    List&lt;WALEntry&gt; entries = new ArrayList&lt;&gt;(BATCH_SIZE/2);<a name="line.208"></a>
-<span class="sourceLineNo">209</span>    List&lt;Cell&gt; cells = new ArrayList&lt;&gt;();<a name="line.209"></a>
-<span class="sourceLineNo">210</span>    for(int i = 0; i &lt; BATCH_SIZE; i++) {<a name="line.210"></a>
-<span class="sourceLineNo">211</span>      entries.add(createEntry( i % 2 == 0 ? TABLE_NAME2 : TABLE_NAME1,<a name="line.211"></a>
-<span class="sourceLineNo">212</span>              i, KeyValue.Type.Put, cells));<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>    SINK.replicateEntries(entries, CellUtil.createCellScanner(cells.iterator()),<a name="line.215"></a>
-<span class="sourceLineNo">216</span>      replicationClusterId, baseNamespaceDir, hfileArchiveDir);<a name="line.216"></a>
-<span class="sourceLineNo">217</span>    Scan scan = new Scan();<a name="line.217"></a>
-<span class="sourceLineNo">218</span>    ResultScanner scanRes = table2.getScanner(scan);<a name="line.218"></a>
-<span class="sourceLineNo">219</span>    for(Result res : scanRes) {<a name="line.219"></a>
-<span class="sourceLineNo">220</span>      assertTrue(Bytes.toInt(res.getRow()) % 2 == 0);<a name="line.220"></a>
-<span class="sourceLineNo">221</span>    }<a name="line.221"></a>
-<span class="sourceLineNo">222</span>  }<a name="line.222"></a>
-<span class="sourceLineNo">223</span><a name="line.223"></a>
-<span class="sourceLineNo">224</span>  /**<a name="line.224"></a>
-<span class="sourceLineNo">225</span>   * Insert then do different types of deletes<a name="line.225"></a>
-<span class="sourceLineNo">226</span>   * @throws Exception<a name="line.226"></a>
-<span class="sourceLineNo">227</span>   */<a name="line.227"></a>
-<span class="sourceLineNo">228</span>  @Test<a name="line.228"></a>
-<span class="sourceLineNo">229</span>  public void testMixedDeletes() throws Exception {<a name="line.229"></a>
-<span class="sourceLineNo">230</span>    List&lt;WALEntry&gt; entries = new ArrayList&lt;&gt;(3);<a name="line.230"></a>
-<span class="sourceLineNo">231</span>    List&lt;Cell&gt; cells = new ArrayList&lt;&gt;();<a name="line.231"></a>
-<span class="sourceLineNo">232</span>    for(int i = 0; i &lt; 3; i++) {<a name="line.232"></a>
-<span class="sourceLineNo">233</span>      entries.add(createEntry(TABLE_NAME1, i, KeyValue.Type.Put, cells));<a name="line.233"></a>
-<span class="sourceLineNo">234</span>    }<a name="line.234"></a>
-<span class="sourceLineNo">235</span>    SINK.replicateEntries(entries, CellUtil.createCellScanner(cells.iterator()),<a name="line.235"></a>
-<span class="sourceLineNo">236</span>      replicationClusterId, baseNamespaceDir, hfileArchiveDir);<a name="line.236"></a>
-<span class="sourceLineNo">237</span>    entries = new ArrayList&lt;&gt;(3);<a name="line.237"></a>
-<span class="sourceLineNo">238</span>    cells = new ArrayList&lt;&gt;();<a name="line.238"></a>
-<span class="sourceLineNo">239</span>    entries.add(createEntry(TABLE_NAME1, 0, KeyValue.Type.DeleteColumn, cells));<a name="line.239"></a>
-<span class="sourceLineNo">240</span>    entries.add(createEntry(TABLE_NAME1, 1, KeyValue.Type.DeleteFamily, cells));<a name="line.240"></a>
-<span class="sourceLineNo">241</span>    entries.add(createEntry(TABLE_NAME1, 2, KeyValue.Type.DeleteColumn, cells));<a name="line.241"></a>
-<span class="sourceLineNo">242</span><a name="line.242"></a>
-<span class="sourceLineNo">243</span>    SINK.replicateEntries(entries, CellUtil.createCellScanner(cells.iterator()),<a name="line.243"></a>
-<span class="sourceLineNo">244</span>      replicationClusterId, baseNamespaceDir, hfileArchiveDir);<a name="line.244"></a>
-<span class="sourceLineNo">245</span><a name="line.245"></a>
-<span class="sourceLineNo">246</span>    Scan scan = new Scan();<a name="line.246"></a>
-<span class="sourceLineNo">247</span>    ResultScanner scanRes = table1.getScanner(scan);<a name="line.247"></a>
-<span class="sourceLineNo">248</span>    assertEquals(0, scanRes.next(3).length);<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>   * Puts are buffered, but this tests when a delete (not-buffered) is applied<a name="line.252"></a>
-<span class="sourceLineNo">253</span>   * before the actual Put that creates it.<a name="line.253"></a>
-<span class="sourceLineNo">254</span>   * @throws Exception<a name="line.254"></a>
-<span class="sourceLineNo">255</span>   */<a name="line.255"></a>
-<span class="sourceLineNo">256</span>  @Test<a name="line.256"></a>
-<span class="sourceLineNo">257</span>  public void testApplyDeleteBeforePut() throws Exception {<a name="line.257"></a>
-<span class="sourceLineNo">258</span>    List&lt;WALEntry&gt; entries = new ArrayList&lt;&gt;(5);<a name="line.258"></a>
-<span class="sourceLineNo">259</span>    List&lt;Cell&gt; cells = new ArrayList&lt;&gt;();<a name="line.259"></a>
-<span class="sourceLineNo">260</span>    for(int i = 0; i &lt; 2; i++) {<a name="line.260"></a>
-<span class="sourceLineNo">261</span>      entries.add(createEntry(TABLE_NAME1, i, KeyValue.Type.Put, cells));<a name="line.261"></a>
-<span class="sourceLineNo">262</span>    }<a name="line.262"></a>
-<span class="sourceLineNo">263</span>    entries.add(createEntry(TABLE_NAME1, 1, KeyValue.Type.DeleteFamily, cells));<a name="line.263"></a>
-<span class="sourceLineNo">264</span>    for(int i = 3; i &lt; 5; i++) {<a name="line.264"></a>
+<span class="sourceLineNo">101</span>  protected static Table table1;<a name="line.101"></a>
+<span class="sourceLineNo">102</span>  protected static Stoppable STOPPABLE = new Stoppable() {<a name="line.102"></a>
+<span class="sourceLineNo">103</span>    final AtomicBoolean stop = new AtomicBoolean(false);<a name="line.103"></a>
+<span class="sourceLineNo">104</span><a name="line.104"></a>
+<span class="sourceLineNo">105</span>    @Override<a name="line.105"></a>
+<span class="sourceLineNo">106</span>    public boolean isStopped() {<a name="line.106"></a>
+<span class="sourceLineNo">107</span>      return this.stop.get();<a name="line.107"></a>
+<span class="sourceLineNo">108</span>    }<a name="line.108"></a>
+<span class="sourceLineNo">109</span><a name="line.109"></a>
+<span class="sourceLineNo">110</span>    @Override<a name="line.110"></a>
+<span class="sourceLineNo">111</span>    public void stop(String why) {<a name="line.111"></a>
+<span class="sourceLineNo">112</span>      LOG.info("STOPPING BECAUSE: " + why);<a name="line.112"></a>
+<span class="sourceLineNo">113</span>      this.stop.set(true);<a name="line.113"></a>
+<span class="sourceLineNo">114</span>    }<a name="line.114"></a>
+<span class="sourceLineNo">115</span><a name="line.115"></a>
+<span class="sourceLineNo">116</span>  };<a name="line.116"></a>
+<span class="sourceLineNo">117</span><a name="line.117"></a>
+<span class="sourceLineNo">118</span>  protected static Table table2;<a name="line.118"></a>
+<span class="sourceLineNo">119</span>  protected static String baseNamespaceDir;<a name="line.119"></a>
+<span class="sourceLineNo">120</span>  protected static String hfileArchiveDir;<a name="line.120"></a>
+<span class="sourceLineNo">121</span>  protected static String replicationClusterId;<a name="line.121"></a>
+<span class="sourceLineNo">122</span><a name="line.122"></a>
+<span class="sourceLineNo">123</span>   /**<a name="line.123"></a>
+<span class="sourceLineNo">124</span>   * @throws java.lang.Exception<a name="line.124"></a>
+<span class="sourceLineNo">125</span>   */<a name="line.125"></a>
+<span class="sourceLineNo">126</span>  @BeforeClass<a name="line.126"></a>
+<span class="sourceLineNo">127</span>  public static void setUpBeforeClass() throws Exception {<a name="line.127"></a>
+<span class="sourceLineNo">128</span>    TEST_UTIL.getConfiguration().set("hbase.replication.source.fs.conf.provider",<a name="line.128"></a>
+<span class="sourceLineNo">129</span>      TestSourceFSConfigurationProvider.class.getCanonicalName());<a name="line.129"></a>
+<span class="sourceLineNo">130</span><a name="line.130"></a>
+<span class="sourceLineNo">131</span>    TEST_UTIL.startMiniCluster(3);<a name="line.131"></a>
+<span class="sourceLineNo">132</span>    SINK =<a name="line.132"></a>
+<span class="sourceLineNo">133</span>      new ReplicationSink(new Configuration(TEST_UTIL.getConfiguration()), STOPPABLE);<a name="line.133"></a>
+<span class="sourceLineNo">134</span>    table1 = TEST_UTIL.createTable(TABLE_NAME1, FAM_NAME1);<a name="line.134"></a>
+<span class="sourceLineNo">135</span>    table2 = TEST_UTIL.createTable(TABLE_NAME2, FAM_NAME2);<a name="line.135"></a>
+<span class="sourceLineNo">136</span>    Path rootDir = FSUtils.getRootDir(TEST_UTIL.getConfiguration());<a name="line.136"></a>
+<span class="sourceLineNo">137</span>    baseNamespaceDir = new Path(rootDir, new Path(HConstants.BASE_NAMESPACE_DIR)).toString();<a name="line.137"></a>
+<span class="sourceLineNo">138</span>    hfileArchiveDir = new Path(rootDir, new Path(HConstants.HFILE_ARCHIVE_DIRECTORY)).toString();<a name="line.138"></a>
+<span class="sourceLineNo">139</span>    replicationClusterId = "12345";<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>   * @throws java.lang.Exception<a name="line.143"></a>
+<span class="sourceLineNo">144</span>   */<a name="line.144"></a>
+<span class="sourceLineNo">145</span>  @AfterClass<a name="line.145"></a>
+<span class="sourceLineNo">146</span>  public static void tearDownAfterClass() throws Exception {<a name="line.146"></a>
+<span class="sourceLineNo">147</span>    STOPPABLE.stop("Shutting down");<a name="line.147"></a>
+<span class="sourceLineNo">148</span>    TEST_UTIL.shutdownMiniCluster();<a name="line.148"></a>
+<span class="sourceLineNo">149</span>  }<a name="line.149"></a>
+<span class="sourceLineNo">150</span><a name="line.150"></a>
+<span class="sourceLineNo">151</span>  /**<a name="line.151"></a>
+<span class="sourceLineNo">152</span>   * @throws java.lang.Exception<a name="line.152"></a>
+<span class="sourceLineNo">153</span>   */<a name="line.153"></a>
+<span class="sourceLineNo">154</span>  @Before<a name="line.154"></a>
+<span class="sourceLineNo">155</span>  public void setUp() throws Exception {<a name="line.155"></a>
+<span class="sourceLineNo">156</span>    table1 = TEST_UTIL.deleteTableData(TABLE_NAME1);<a name="line.156"></a>
+<span class="sourceLineNo">157</span>    table2 = TEST_UTIL.deleteTableData(TABLE_NAME2);<a name="line.157"></a>
+<span class="sourceLineNo">158</span>  }<a name="line.158"></a>
+<span class="sourceLineNo">159</span><a name="line.159"></a>
+<span class="sourceLineNo">160</span>  /**<a name="line.160"></a>
+<span class="sourceLineNo">161</span>   * Insert a whole batch of entries<a name="line.161"></a>
+<span class="sourceLineNo">162</span>   * @throws Exception<a name="line.162"></a>
+<span class="sourceLineNo">163</span>   */<a name="line.163"></a>
+<span class="sourceLineNo">164</span>  @Test<a name="line.164"></a>
+<span class="sourceLineNo">165</span>  public void testBatchSink() throws Exception {<a name="line.165"></a>
+<span class="sourceLineNo">166</span>    List&lt;WALEntry&gt; entries = new ArrayList&lt;&gt;(BATCH_SIZE);<a name="line.166"></a>
+<span class="sourceLineNo">167</span>    List&lt;Cell&gt; cells = new ArrayList&lt;&gt;();<a name="line.167"></a>
+<span class="sourceLineNo">168</span>    for(int i = 0; i &lt; BATCH_SIZE; i++) {<a name="line.168"></a>
+<span class="sourceLineNo">169</span>      entries.add(createEntry(TABLE_NAME1, i, KeyValue.Type.Put, cells));<a name="line.169"></a>
+<span class="sourceLineNo">170</span>    }<a name="line.170"></a>
+<span class="sourceLineNo">171</span>    SINK.replicateEntries(entries, CellUtil.createCellScanner(cells.iterator()),<a name="line.171"></a>
+<span class="sourceLineNo">172</span>      replicationClusterId, baseNamespaceDir, hfileArchiveDir);<a name="line.172"></a>
+<span class="sourceLineNo">173</span>    Scan scan = new Scan();<a name="line.173"></a>
+<span class="sourceLineNo">174</span>    ResultScanner scanRes = table1.getScanner(scan);<a name="line.174"></a>
+<span class="sourceLineNo">175</span>    assertEquals(BATCH_SIZE, scanRes.next(BATCH_SIZE).length);<a name="line.175"></a>
+<span class="sourceLineNo">176</span>  }<a name="line.176"></a>
+<span class="sourceLineNo">177</span><a name="line.177"></a>
+<span class="sourceLineNo">178</span>  /**<a name="line.178"></a>
+<span class="sourceLineNo">179</span>   * Insert a mix of puts and deletes<a name="line.179"></a>
+<span class="sourceLineNo">180</span>   * @throws Exception<a name="line.180"></a>
+<span class="sourceLineNo">181</span>   */<a name="line.181"></a>
+<span class="sourceLineNo">182</span>  @Test<a name="line.182"></a>
+<span class="sourceLineNo">183</span>  public void testMixedPutDelete() throws Exception {<a name="line.183"></a>
+<span class="sourceLineNo">184</span>    List&lt;WALEntry&gt; entries = new ArrayList&lt;&gt;(BATCH_SIZE/2);<a name="line.184"></a>
+<span class="sourceLineNo">185</span>    List&lt;Cell&gt; cells = new ArrayList&lt;&gt;();<a name="line.185"></a>
+<span class="sourceLineNo">186</span>    for(int i = 0; i &lt; BATCH_SIZE/2; i++) {<a name="line.186"></a>
+<span class="sourceLineNo">187</span>      entries.add(createEntry(TABLE_NAME1, i, KeyValue.Type.Put, cells));<a name="line.187"></a>
+<span class="sourceLineNo">188</span>    }<a name="line.188"></a>
+<span class="sourceLineNo">189</span>    SINK.replicateEntries(entries, CellUtil.createCellScanner(cells), replicationClusterId,<a name="line.189"></a>
+<span class="sourceLineNo">190</span>      baseNamespaceDir, hfileArchiveDir);<a name="line.190"></a>
+<span class="sourceLineNo">191</span><a name="line.191"></a>
+<span class="sourceLineNo">192</span>    entries = new ArrayList&lt;&gt;(BATCH_SIZE);<a name="line.192"></a>
+<span class="sourceLineNo">193</span>    cells = new ArrayList&lt;&gt;();<a name="line.193"></a>
+<span class="sourceLineNo">194</span>    for(int i = 0; i &lt; BATCH_SIZE; i++) {<a name="line.194"></a>
+<span class="sourceLineNo">195</span>      entries.add(createEntry(TABLE_NAME1, i,<a name="line.195"></a>
+<span class="sourceLineNo">196</span>          i % 2 != 0 ? KeyValue.Type.Put: KeyValue.Type.DeleteColumn, cells));<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>    SINK.replicateEntries(entries, CellUtil.createCellScanner(cells.iterator()),<a name="line.199"></a>
+<span class="sourceLineNo">200</span>      replicationClusterId, baseNamespaceDir, hfileArchiveDir);<a name="line.200"></a>
+<span class="sourceLineNo">201</span>    Scan scan = new Scan();<a name="line.201"></a>
+<span class="sourceLineNo">202</span>    ResultScanner scanRes = table1.getScanner(scan);<a name="line.202"></a>
+<span class="sourceLineNo">203</span>    assertEquals(BATCH_SIZE/2, scanRes.next(BATCH_SIZE).length);<a name="line.203"></a>
+<span class="sourceLineNo">204</span>  }<a name="line.204"></a>
+<span class="sourceLineNo">205</span><a name="line.205"></a>
+<span class="sourceLineNo">206</span>  /**<a name="line.206"></a>
+<span class="sourceLineNo">207</span>   * Insert to 2 different tables<a name="line.207"></a>
+<span class="sourceLineNo">208</span>   * @throws Exception<a name="line.208"></a>
+<span class="sourceLineNo">209</span>   */<a name="line.209"></a>
+<span class="sourceLineNo">210</span>  @Test<a name="line.210"></a>
+<span class="sourceLineNo">211</span>  public void testMixedPutTables() throws Exception {<a name="line.211"></a>
+<span class="sourceLineNo">212</span>    List&lt;WALEntry&gt; entries = new ArrayList&lt;&gt;(BATCH_SIZE/2);<a name="line.212"></a>
+<span class="sourceLineNo">213</span>    List&lt;Cell&gt; cells = new ArrayList&lt;&gt;();<a name="line.213"></a>
+<span class="sourceLineNo">214</span>    for(int i = 0; i &lt; BATCH_SIZE; i++) {<a name="line.214"></a>
+<span class="sourceLineNo">215</span>      entries.add(createEntry( i % 2 == 0 ? TABLE_NAME2 : TABLE_NAME1,<a name="line.215"></a>
+<span class="sourceLineNo">216</span>              i, KeyValue.Type.Put, cells));<a name="line.216"></a>
+<span class="sourceLineNo">217</span>    }<a name="line.217"></a>
+<span class="sourceLineNo">218</span><a name="line.218"></a>
+<span class="sourceLineNo">219</span>    SINK.replicateEntries(entries, CellUtil.createCellScanner(cells.iterator()),<a name="line.219"></a>
+<span class="sourceLineNo">220</span>      replicationClusterId, baseNamespaceDir, hfileArchiveDir);<a name="line.220"></a>
+<span class="sourceLineNo">221</span>    Scan scan = new Scan();<a name="line.221"></a>
+<span class="sourceLineNo">222</span>    ResultScanner scanRes = table2.getScanner(scan);<a name="line.222"></a>
+<span class="sourceLineNo">223</span>    for(Result res : scanRes) {<a name="line.223"></a>
+<span class="sourceLineNo">224</span>      assertTrue(Bytes.toInt(res.getRow()) % 2 == 0);<a name="line.224"></a>
+<span class="sourceLineNo">225</span>    }<a name="line.225"></a>
+<span class="sourceLineNo">226</span>  }<a name="line.226"></a>
+<span class="sourceLineNo">227</span><a name="line.227"></a>
+<span class="sourceLineNo">228</span>  /**<a name="line.228"></a>
+<span class="sourceLineNo">229</span>   * Insert then do different types of deletes<a name="line.229"></a>
+<span class="sourceLineNo">230</span>   * @throws Exception<a name="line.230"></a>
+<span class="sourceLineNo">231</span>   */<a name="line.231"></a>
+<span class="sourceLineNo">232</span>  @Test<a name="line.232"></a>
+<span class="sourceLineNo">233</span>  public void testMixedDeletes() throws Exception {<a name="line.233"></a>
+<span class="sourceLineNo">234</span>    List&lt;WALEntry&gt; entries = new ArrayList&lt;&gt;(3);<a name="line.234"></a>
+<span class="sourceLineNo">235</span>    List&lt;Cell&gt; cells = new ArrayList&lt;&gt;();<a name="line.235"></a>
+<span class="sourceLineNo">236</span>    for(int i = 0; i &lt; 3; i++) {<a name="line.236"></a>
+<span class="sourceLineNo">237</span>      entries.add(createEntry(TABLE_NAME1, i, KeyValue.Type.Put, cells));<a name="line.237"></a>
+<span class="sourceLineNo">238</span>    }<a name="line.238"></a>
+<span class="sourceLineNo">239</span>    SINK.replicateEntries(entries, CellUtil.createCellScanner(cells.iterator()),<a name="line.239"></a>
+<span class="sourceLineNo">240</span>      replicationClusterId, baseNamespaceDir, hfileArchiveDir);<a name="line.240"></a>
+<span class="sourceLineNo">241</span>    entries = new ArrayList&lt;&gt;(3);<a name="line.241"></a>
+<span class="sourceLineNo">242</span>    cells = new ArrayList&lt;&gt;();<a name="line.242"></a>
+<span class="sourceLineNo">243</span>    entries.add(createEntry(TABLE_NAME1, 0, KeyValue.Type.DeleteColumn, cells));<a name="line.243"></a>
+<span class="sourceLineNo">244</span>    entries.add(createEntry(TABLE_NAME1, 1, KeyValue.Type.DeleteFamily, cells));<a name="line.244"></a>
+<span class="sourceLineNo">245</span>    entries.add(createEntry(TABLE_NAME1, 2, KeyValue.Type.DeleteColumn, cells));<a name="line.245"></a>
+<span class="sourceLineNo">246</span><a name="line.246"></a>
+<span class="sourceLineNo">247</span>    SINK.replicateEntries(entries, CellUtil.createCellScanner(cells.iterator()),<a name="line.247"></a>
+<span class="sourceLineNo">248</span>      replicationClusterId, baseNamespaceDir, hfileArchiveDir);<a name="line.248"></a>
+<span class="sourceLineNo">249</span><a name="line.249"></a>
+<span class="sourceLineNo">250</span>    Scan scan = new Scan();<a name="line.250"></a>
+<span class="sourceLineNo">251</span>    ResultScanner scanRes = table1.getScanner(scan);<a name="line.251"></a>
+<span class="sourceLineNo">252</span>    assertEquals(0, scanRes.next(3).length);<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>  /**<a name="line.255"></a>
+<span class="sourceLineNo">256</span>   * Puts are buffered, but this tests when a delete (not-buffered) is applied<a name="line.256"></a>
+<span class="sourceLineNo">257</span>   * before the actual Put that creates it.<a name="line.257"></a>
+<span class="sourceLineNo">258</span>   * @throws Exception<a name="line.258"></a>
+<span class="sourceLineNo">259</span>   */<a name="line.259"></a>
+<span class="sourceLineNo">260</span>  @Test<a name="line.260"></a>
+<span class="sourceLineNo">261</span>  public void testApplyDeleteBeforePut() throws Exception {<a name="line.261"></a>
+<span class="sourceLineNo">262</span>    List&lt;WALEntry&gt; entries = new ArrayList&lt;&gt;(5);<a name="line.262"></a>
+<span class="sourceLineNo">263</span>    List&lt;Cell&gt; cells = new ArrayList&lt;&gt;();<a name="line.263"></a>
+<span class="sourceLineNo">264</span>    for(int i = 0; i &lt; 2; i++) {<a name="line.264"></a>
 <span class="sourceLineNo">265</span>      entries.add(createEntry(TABLE_NAME1, i, KeyValue.Type.Put, cells));<a name="line.265"></a>
 <span class="sourceLineNo">266</span>    }<a name="line.266"></a>
-<span class="sourceLineNo">267</span>    SINK.replicateEntries(entries, CellUtil.createCellScanner(cells.iterator()),<a name="line.267"></a>
-<span class="sourceLineNo">268</span>      replicationClusterId, baseNamespaceDir, hfileArchiveDir);<a name="line.268"></a>
-<span class="sourceLineNo">269</span>    Get get = new Get(Bytes.toBytes(1));<a name="line.269"></a>
-<span class="sourceLineNo">270</span>    Result res = table1.get(get);<a name="line.270"></a>
-<span class="sourceLineNo">271</span>    assertEquals(0, res.size());<a name="line.271"></a>
-<span class="sourceLineNo">272</span>  }<a name="line.272"></a>
-<span class="sourceLineNo">273</span><a name="line.273"></a>
-<span class="sourceLineNo">274</span>  /**<a name="line.274"></a>
-<span class="sourceLineNo">275</span>   * Test replicateEntries with a bulk load entry for 25 HFiles<a name="line.275"></a>
-<span class="sourceLineNo">276</span>   */<a name="line.276"></a>
-<span class="sourceLineNo">277</span>  @Test<a name="line.277"></a>
-<span class="sourceLineNo">278</span>  public void testReplicateEntriesForHFiles() throws Exception {<a name="line.278"></a>
-<span class="sourceLineNo">279</span>    Path dir = TEST_UTIL.getDataTestDirOnTestFS("testReplicateEntries");<a name="line.279"></a>
-<span class="sourceLineNo">280</span>    Path familyDir = new Path(dir, Bytes.toString(FAM_NAME1));<a name="line.280"></a>
-<span class="sourceLineNo">281</span>    int numRows = 10;<a name="line.281"></a>
-<span class="sourceLineNo">282</span><a name="line.282"></a>
-<span class="sourceLineNo">283</span>    List&lt;Path&gt; p = new ArrayList&lt;&gt;(1);<a name="line.283"></a>
-<span class="sourceLineNo">284</span><a name="line.284"></a>
-<span class="sourceLineNo">285</span>    // 1. Generate 25 hfile ranges<a name="line.285"></a>
-<span class="sourceLineNo">286</span>    Random rng = new SecureRandom();<a name="line.286"></a>
-<span class="sourceLineNo">287</span>    Set&lt;Integer&gt; numbers = new HashSet&lt;&gt;();<a name="line.287"></a>
-<span class="sourceLineNo">288</span>    while (numbers.size() &lt; 50) {<a name="line.288"></a>
-<span class="sourceLineNo">289</span>      numbers.add(rng.nextInt(1000));<a name="line.289"></a>
-<span class="sourceLineNo">290</span>    }<a name="line.290"></a>
-<span class="sourceLineNo">291</span>    List&lt;Integer&gt; numberList = new ArrayList&lt;&gt;(numbers);<a name="line.291"></a>
-<span class="sourceLineNo">292</span>    Collections.sort(numberList);<a name="line.292"></a>
-<span class="sourceLineNo">293</span>    Map&lt;String, Long&gt; storeFilesSize = new HashMap&lt;&gt;(1);<a name="line.293"></a>
-<span class="sourceLineNo">294</span><a name="line.294"></a>
-<span class="sourceLineNo">295</span>    // 2. Create 25 hfiles<a name="line.295"></a>
-<span class="sourceLineNo">296</span>    Configuration conf = TEST_UTIL.getConfiguration();<a name="line.296"></a>
-<span class="sourceLineNo">297</span>    FileSystem fs = dir.getFileSystem(conf);<a name="line.297"></a>
-<span class="sourceLineNo">298</span>    Iterator&lt;Integer&gt; numbersItr = numberList.iterator();<a name="line.298"></a>
-<span class="sourceLineNo">299</span>    for (int i = 0; i &lt; 25; i++) {<a name="line.299"></a>
-<span class="sourceLineNo">300</span>      Path hfilePath = new Path(familyDir, "hfile_" + i);<a name="line.300"></a>
-<span class="sourceLineNo">301</span>      HFileTestUtil.createHFile(conf, fs, hfilePath, FAM_NAME1, FAM_NAME1,<a name="line.301"></a>
-<span class="sourceLineNo">302</span>        Bytes.toBytes(numbersItr.next()), Bytes.toBytes(numbersItr.next()), numRows);<a name="line.302"></a>
-<span class="sourceLineNo">303</span>      p.add(hfilePath);<a name="line.303"></a>
-<span class="sourceLineNo">304</span>      storeFilesSize.put(hfilePath.getName(), fs.getFileStatus(hfilePath).getLen());<a name="line.304"></a>
-<span class="sourceLineNo">305</span>    }<a name="line.305"></a>
-<span class="sourceLineNo">306</span><a name="line.306"></a>
-<span class="sourceLineNo">307</span>    // 3. Create a BulkLoadDescriptor and a WALEdit<a name="line.307"></a>
-<span class="sourceLineNo">308</span>    Map&lt;byte[], List&lt;Path&gt;&gt; storeFiles = new HashMap&lt;&gt;(1);<a name="line.308"></a>
-<span class="sourceLineNo">309</span>    storeFiles.put(FAM_NAME1, p);<a name="line.309"></a>
-<span class="sourceLineNo">310</span>    org.apache.hadoop.hbase.wal.WALEdit edit = null;<a name="line.310"></a>
-<span class="sourceLineNo">311</span>    WALProtos.BulkLoadDescriptor loadDescriptor = null;<a name="line.311"></a>
-<span class="sourceLineNo">312</span><a name="line.312"></a>
-<span class="sourceLineNo">313</span>    try (Connection c = ConnectionFactory.createConnection(conf);<a name="line.313"></a>
-<span class="sourceLineNo">314</span>        RegionLocator l = c.getRegionLocator(TABLE_NAME1)) {<a name="line.314"></a>
-<span class="sourceLineNo">315</span>      HRegionInfo regionInfo = l.getAllRegionLocations().get(0).getRegionInfo();<a name="line.315"></a>
-<span class="sourceLineNo">316</span>      loadDescriptor =<a name="line.316"></a>
-<span class="sourceLineNo">317</span>          ProtobufUtil.toBulkLoadDescriptor(TABLE_NAME1,<a name="line.317"></a>
-<span class="sourceLineNo">318</span>              UnsafeByteOperations.unsafeWrap(regionInfo.getEncodedNameAsBytes()),<a name="line.318"></a>
-<span class="sourceLineNo">319</span>              storeFiles, storeFilesSize, 1);<a name="line.319"></a>
-<span class="sourceLineNo">320</span>      edit = org.apache.hadoop.hbase.wal.WALEdit.createBulkLoadEvent(regionInfo,<a name="line.320"></a>
-<span class="sourceLineNo">321</span>        loadDescriptor);<a name="line.321"></a>
-<span class="sourceLineNo">322</span>    }<a name="line.322"></a>
-<span class="sourceLineNo">323</span>    List&lt;WALEntry&gt; entries = new ArrayList&lt;&gt;(1);<a name="line.323"></a>
-<span class="sourceLineNo">324</span><a name="line.324"></a>
-<span class="sourceLineNo">325</span>    // 4. Create a WALEntryBuilder<a name="line.325"></a>
-<span class="sourceLineNo">326</span>    WALEntry.Builder builder = createWALEntryBuilder(TABLE_NAME1);<a name="line.326"></a>
-<span class="sourceLineNo">327</span><a name="line.327"></a>
-<span class="sourceLineNo">328</span>    // 5. Copy the hfile to the path as it is in reality<a name="line.328"></a>
-<span class="sourceLineNo">329</span>    for (int i = 0; i &lt; 25; i++) {<a name="line.329"></a>
-<span class="sourceLineNo">330</span>      String pathToHfileFromNS =<a name="line.330"></a>
-<span class="sourceLineNo">331</span>          new StringBuilder(100).append(TABLE_NAME1.getNamespaceAsString()).append(Path.SEPARATOR)<a name="line.331"></a>
-<span class="sourceLineNo">332</span>              .append(Bytes.toString(TABLE_NAME1.getName())).append(Path.SEPARATOR)<a name="line.332"></a>
-<span class="sourceLineNo">333</span>              .append(Bytes.toString(loadDescriptor.getEncodedRegionName().toByteArray()))<a name="line.333"></a>
-<span class="sourceLineNo">334</span>              .append(Path.SEPARATOR).append(Bytes.toString(FAM_NAME1)).append(Path.SEPARATOR)<a name="line.334"></a>
-<span class="sourceLineNo">335</span>              .append("hfile_" + i).toString();<a name="line.335"></a>
-<span class="sourceLineNo">336</span>      String dst = baseNamespaceDir + Path.SEPARATOR + pathToHfileFromNS;<a name="line.336"></a>
-<span class="sourceLineNo">337</span><a name="line.337"></a>
-<span class="sourceLineNo">338</span>      FileUtil.copy(fs, p.get(0), fs, new Path(dst), false, conf);<a name="line.338"></a>
-<span class="sourceLineNo">339</span>    }<a name="line.339"></a>
-<span class="sourceLineNo">340</span><a name="line.340"></a>
-<span class="sourceLineNo">341</span>    entries.add(builder.build());<a name="line.341"></a>
-<span class="sourceLineNo">342</span>    try (ResultScanner scanner = table1.getScanner(new Scan())) {<a name="line.342"></a>
-<span class="sourceLineNo">343</span>      // 6. Assert no existing data in table<a name="line.343"></a>
-<span class="sourceLineNo">344</span>      assertEquals(0, scanner.next(numRows).length);<a name="line.344"></a>
-<span class="sourceLineNo">345</span>    }<a name="line.345"></a>
-<span class="sourceLineNo">346</span>    // 7. Replicate the bulk loaded entry<a name="line.346"></a>
-<span class="sourceLineNo">347</span>    SINK.replicateEntries(entries, CellUtil.createCellScanner(edit.getCells().iterator()),<a name="line.347"></a>
-<span class="sourceLineNo">348</span>      replicationClusterId, baseNamespaceDir, hfileArchiveDir);<a name="line.348"></a>
-<span class="sourceLineNo">349</span>    try (ResultScanner scanner = table1.getScanner(new Scan())) {<a name="line.349"></a>
-<span class="sourceLineNo">350</span>      // 8. Assert data is replicated<a name="line.350"></a>
-<span class="sourceLineNo">351</span>      assertEquals(numRows, scanner.next(numRows).length);<a name="line.351"></a>
-<span class="sourceLineNo">352</span>    }<a name="line.352"></a>
-<span class="sourceLineNo">353</span>  }<a name="line.353"></a>
-<span class="sourceLineNo">354</span><a name="line.354"></a>
-<span class="sourceLineNo">355</span>  private WALEntry createEntry(TableName table, int row,  KeyValue.Type type, List&lt;Cell&gt; cells) {<a name="line.355"></a>
-<span class="sourceLineNo">356</span>    byte[] fam = table.equals(TABLE_NAME1) ? FAM_NAME1 : FAM_NAME2;<a name="line.356"></a>
-<span class="sourceLineNo">357</span>    byte[] rowBytes = Bytes.toBytes(row);<a name="line.357"></a>
-<span class="sourceLineNo">358</span>    // Just make sure we don't get the same ts for two consecutive rows with<a name="line.358"></a>
-<span class="sourceLineNo">359</span>    // same key<a name="line.359"></a>
-<span class="sourceLineNo">360</span>    try {<a name="line.360"></a>
-<span class="sourceLineNo">361</span>      Thread.sleep(1);<a name="line.361"></a>
-<span class="sourceLineNo">362</span>    } catch (InterruptedException e) {<a name="line.362"></a>
-<span class="sourceLineNo">363</span>      LOG.info("Was interrupted while sleep, meh", e);<a name="line.363"></a>
-<span class="sourceLineNo">364</span>    }<a name="line.364"></a>
-<span class="sourceLineNo">365</span>    final long now = System.currentTimeMillis();<a name="line.365"></a>
-<span class="sourceLineNo">366</span>    KeyValue kv = null;<a name="line.366"></a>
-<span class="sourceLineNo">367</span>    if(type.getCode() == KeyValue.Type.Put.getCode()) {<a name="line.367"></a>
-<span class="sourceLineNo">368</span>      kv = new KeyValue(rowBytes, fam, fam, now,<a name="line.368"></a>
-<span class="sourceLineNo">369</span>          KeyValue.Type.Put, Bytes.toBytes(row));<a name="line.369"></a>
-<span class="sourceLineNo">370</span>    } else if (type.getCode() == KeyValue.Type.DeleteColumn.getCode()) {<a name="line.370"></a>
-<span class="sourceLineNo">371</span>        kv = new KeyValue(rowBytes, fam, fam,<a name="line.371"></a>
-<span class="sourceLineNo">372</span>            now, KeyValue.Type.DeleteColumn);<a name="line.372"></a>
-<span class="sourceLineNo">373</span>    } else if (type.getCode() == KeyValue.Type.DeleteFamily.getCode()) {<a name="line.373"></a>
-<span class="sourceLineNo">374</span>        kv = new KeyValue(rowBytes, fam, null,<a name="line.374"></a>
-<span class="sourceLineNo">375</span>            now, KeyValue.Type.DeleteFamily);<a name="line.375"></a>
-<span class="sourceLineNo">376</span>    }<a name="line.376"></a>
-<span class="sourceLineNo">377</span>    WALEntry.Builder builder = createWALEntryBuilder(table);<a name="line.377"></a>
-<span class="sourceLineNo">378</span>    cells.add(kv);<a name="line.378"></a>
-<span class="sourceLineNo">379</span><a name="line.379"></a>
-<span class="sourceLineNo">380</span>    return builder.build();<a name="line.380"></a>
-<span class="sourceLineNo">381</span>  }<a name="line.381"></a>
-<span class="sourceLineNo">382</span><a name="line.382"></a>
-<span class="sourceLineNo">383</span>  private WALEntry.Builder createWALEntryBuilder(TableName table) {<a name="line.383"></a>
-<span class="sourceLineNo">384</span>    WALEntry.Builder builder = WALEntry.newBuilder();<a name="line.384"></a>
-<span class="sourceLineNo">385</span>    builder.setAssociatedCellCount(1);<a name="line.385"></a>
-<span class="sourceLineNo">386</span>    WALKey.Builder keyBuilder = WALKey.newBuilder();<a name="line.386"></a>
-<span class="sourceLineNo">387</span>    UUID.Builder uuidBuilder = UUID.newBuilder();<a name="line.387"></a>
-<span class="sourceLineNo">388</span>    uuidBuilder.setLeastSigBits(HConstants.DEFAULT_CLUSTER_ID.getLeastSignificantBits());<a name="line.388"></a>
-<span class="sourceLineNo">389</span>    uuidBuilder.setMostSigBits(HConstants.DEFAULT_CLUSTER_ID.getMostSignificantBits());<a name="line.389"></a>
-<span class="sourceLineNo">390</span>    keyBuilder.setClusterId(uuidBuilder.build());<a name="line.390"></a>
-<span class="sourceLineNo">391</span>    keyBuilder.setTableName(UnsafeByteOperations.unsafeWrap(table.getName()));<a name="line.391"></a>
-<span class="sourceLineNo">392</span>    keyBuilder.setWriteTime(System.currentTimeMillis());<a name="line.392"></a>
-<span class="sourceLineNo">393</span>    keyBuilder.setEncodedRegionName(UnsafeByteOperations.unsafeWrap(HConstants.EMPTY_BYTE_ARRAY));<a name="line.393"></a>
-<span class="sourceLineNo">394</span>    keyBuilder.setLogSequenceNumber(-1);<a name="line.394"></a>
-<span class="sourceLineNo">395</span>    builder.setKey(keyBuilder.build());<a name="line.395"></a>
-<span class="sourceLineNo">396</span>    return builder;<a name="line.396"></a>
-<span class="sourceLineNo">397</span>  }<a name="line.397"></a>
-<span class="sourceLineNo">398</span>}<a name="line.398"></a>
+<span class="sourceLineNo">267</span>    entries.add(createEntry(TABLE_NAME1, 1, KeyValue.Type.DeleteFamily, cells));<a name="line.267"></a>
+<span class="sourceLineNo">268</span>    for(int i = 3; i &lt; 5; i++) {<a name="line.268"></a>
+<span class="sourceLineNo">269</span>      entries.add(createEntry(TABLE_NAME1, i, KeyValue.Type.Put, cells));<a name="line.269"></a>
+<span class="sourceLineNo">270</span>    }<a name="line.270"></a>
+<span class="sourceLineNo">271</span>    SINK.replicateEntries(entries, CellUtil.createCellScanner(cells.iterator()),<a name="line.271"></a>
+<span class="sourceLineNo">272</span>      replicationClusterId, baseNamespaceDir, hfileArchiveDir);<a name="line.272"></a>
+<span class="sourceLineNo">273</span>    Get get = new Get(Bytes.toBytes(1));<a name="line.273"></a>
+<span class="sourceLineNo">274</span>    Result res = table1.get(get);<a name="line.274"></a>
+<span class="sourceLineNo">275</span>    assertEquals(0, res.size());<a name="line.275"></a>
+<span class="sourceLineNo">276</span>  }<a name="line.276"></a>
+<span class="sourceLineNo">277</span><a name="line.277"></a>
+<span class="sourceLineNo">278</span>  @Test<a name="line.278"></a>
+<span class="sourceLineNo">279</span>  public void testRethrowRetriesExhaustedWithDetailsException() throws Exception {<a name="line.279"></a>
+<span class="sourceLineNo">280</span>    TableName notExistTable = TableName.valueOf("notExistTable");<a name="line.280"></a>
+<span class="sourceLineNo">281</span>    List&lt;WALEntry&gt; entries = new ArrayList&lt;&gt;();<a name="line.281"></a>
+<span class="sourceLineNo">282</span>    List&lt;Cell&gt; cells = new ArrayList&lt;&gt;();<a name="line.282"></a>
+<span class="sourceLineNo">283</span>    for (int i = 0; i &lt; 10; i++) {<a name="line.283"></a>
+<span class="sourceLineNo">284</span>      entries.add(createEntry(notExistTable, i, KeyValue.Type.Put, cells));<a name="line.284"></a>
+<span class="sourceLineNo">285</span>    }<a name="line.285"></a>
+<span class="sourceLineNo">286</span>    try {<a name="line.286"></a>
+<span class="sourceLineNo">287</span>      SINK.replicateEntries(entries, CellUtil.createCellScanner(cells.iterator()),<a name="line.287"></a>
+<span class="sourceLineNo">288</span>        replicationClusterId, baseNamespaceDir, hfileArchiveDir);<a name="line.288"></a>
+<span class="sourceLineNo">289</span>      Assert.fail("Should re-throw TableNotFoundException.");<a name="line.289"></a>
+<span class="sourceLineNo">290</span>    } catch (TableNotFoundException e) {<a name="line.290"></a>
+<span class="sourceLineNo">291</span>    }<a name="line.291"></a>
+<span class="sourceLineNo">292</span>    entries.clear();<a name="line.292"></a>
+<span class="sourceLineNo">293</span>    cells.clear();<a name="line.293"></a>
+<span class="sourceLineNo">294</span>    for (int i = 0; i &lt; 10; i++) {<a name="line.294"></a>
+<span class="sourceLineNo">295</span>      entries.add(createEntry(TABLE_NAME1, i, KeyValue.Type.Put, cells));<a name="line.295"></a>
+<span class="sourceLineNo">296</span>    }<a name="line.296"></a>
+<span class="sourceLineNo">297</span>    try (Connection conn = ConnectionFactory.createConnection(TEST_UTIL.getConfiguration())) {<a name="line.297"></a>
+<span class="sourceLineNo">298</span>      try (Admin admin = conn.getAdmin()) {<a name="line.298"></a>
+<span class="sourceLineNo">299</span>        admin.disableTable(TABLE_NAME1);<a name="line.299"></a>
+<span class="sourceLineNo">300</span>        try {<a name="line.300"></a>
+<span class="sourceLineNo">301</span>          SINK.replicateEntries(entries, CellUtil.createCellScanner(cells.iterator()),<a name="line.301"></a>
+<span class="sourceLineNo">302</span>            replicationClusterId, baseNamespaceDir, hfileArchiveDir);<a name="line.302"></a>
+<span class="sourceLineNo">303</span>          Assert.fail("Should re-throw RetriesExhaustedWithDetailsException.");<a name="line.303"></a>
+<span class="sourceLineNo">304</span>        } catch (RetriesExhaustedWithDetailsException e) {<a name="line.304"></a>
+<span class="sourceLineNo">305</span>        } finally {<a name="line.305"></a>
+<span class="sourceLineNo">306</span>          admin.enableTable(TABLE_NAME1);<a name="line.306"></a>
+<span class="sourceLineNo">307</span>        }<a name="line.307"></a>
+<span class="sourceLineNo">308</span>      }<a name="line.308"></a>
+<span class="sourceLineNo">309</span>    }<a name="line.309"></a>
+<span class="sourceLineNo">310</span>  }<a name="line.310"></a>
+<span class="sourceLineNo">311</span><a name="line.311"></a>
+<span class="sourceLineNo">312</span>  /**<a name="line.312"></a>
+<span class="sourceLineNo">313</span>   * Test replicateEntries with a bulk load entry for 25 HFiles<a name="line.313"></a>
+<span class="sourceLineNo">314</span>   */<a name="line.314"></a>
+<span class="sourceLineNo">315</span>  @Test<a name="line.315"></a>
+<span class="sourceLineNo">316</span>  public void testReplicateEntriesForHFiles() throws Exception {<a name="line.316"></a>
+<span class="sourceLineNo">317</span>    Path dir = TEST_UTIL.getDataTestDirOnTestFS("testReplicateEntries");<a name="line.317"></a>
+<span class="sourceLineNo">318</span>    Path familyDir = new Path(dir, Bytes.toString(FAM_NAME1));<a name="line.318"></a>
+<span class="sourceLineNo">319</span>    int numRows = 10;<a name="line.319"></a>
+<span class="sourceLineNo">320</span><a name="line.320"></a>
+<span class="sourceLineNo">321</span>    List&lt;Path&gt; p = new ArrayList&lt;&gt;(1);<a name="line.321"></a>
+<span class="sourceLineNo">322</span><a name="line.322"></a>
+<span class="sourceLineNo">323</span>    // 1. Generate 25 hfile ranges<a name="line.323"></a>
+<span class="sourceLineNo">324</span>    Random rng = new SecureRandom();<a name="line.324"></a>
+<span class="sourceLineNo">325</span>    Set&lt;Integer&gt; numbers = new HashSet&lt;&gt;();<a name="line.325"></a>
+<span class="sourceLineNo">326</span>    while (numbers.size() &lt; 50) {<a name="line.326"></a>
+<span class="sourceLineNo">327</span>      numbers.add(rng.nextInt(1000));<a name="line.327"></a>
+<span class="sourceLineNo">328</span>    }<a name="line.328"></a>
+<span class="sourceLineNo">329</span>    List&lt;Integer&gt; numberList = new ArrayList&lt;&gt;(numbers);<a name="line.329"></a>
+<span class="sourceLineNo">330</span>    Collections.sort(numberList);<a name="line.330"></a>
+<span class="sourceLineNo">331</span>    Map&lt;String, Long&gt; storeFilesSize = new HashMap&lt;&gt;(1);<a name="line.331"></a>
+<span class="sourceLineNo">332</span><a name="line.332"></a>
+<span class="sourceLineNo">333</span>    // 2. Create 25 hfiles<a name="line.333"></a>
+<span class="sourceLineNo">334</span>    Configuration conf = TEST_UTIL.getConfiguration();<a name="line.334"></a>
+<span class="sourceLineNo">335</span>    FileSystem fs = dir.getFileSystem(conf);<a name="line.335"></a>
+<span class="sourceLineNo">336</span>    Iterator&lt;Integer&gt; numbersItr = numberList.iterator();<a name="line.336"></a>
+<span class="sourceLineNo">337</span>    for (int i = 0; i &lt; 25; i++) {<a name="line.337"></a>
+<span class="sourceLineNo">338</span>      Path hfilePath = new Path(familyDir, "hfile_" + i);<a name="line.338"></a>
+<span class="sourceLineNo">339</span>      HFileTestUtil.createHFile(conf, fs, hfilePath, FAM_NAME1, FAM_NAME1,<a name="line.339"></a>
+<span class="sourceLineNo">340</span>        Bytes.toBytes(numbersItr.next()), Bytes.toBytes(numbersItr.next()), numRows);<a name="line.340"></a>
+<span class="sourceLineNo">341</span>      p.add(hfilePath);<a name="line.341"></a>
+<span class="sourceLineNo">342</span>      storeFilesSize.put(hfilePath.getName(), fs.getFileStatus(hfilePath).getLen());<a name="line.342"></a>
+<span class="sourceLineNo">343</span>    }<a name="line.343"></a>
+<span class="sourceLineNo">344</span><a name="line.344"></a>
+<span class="sourceLineNo">345</span>    // 3. Create a BulkLoadDescriptor and a WALEdit<a name="line.345"></a>
+<span class="sourceLineNo">346</span>    Map&lt;byte[], List&lt;Path&gt;&gt; storeFiles = new HashMap&lt;&gt;(1);<a name="line.346"></a>
+<span class="sourceLineNo">347</span>    storeFiles.put(FAM_NAME1, p);<a name="line.347"></a>
+<span class="sourceLineNo">348</span>    org.apache.hadoop.hbase.wal.WALEdit edit = null;<a name="line.348"></a>
+<span class="sourceLineNo">349</span>    WALProtos.BulkLoadDescriptor loadDescriptor = null;<a name="line.349"></a>
+<span class="sourceLineNo">350</span><a name="line.350"></a>
+<span class="sourceLineNo">351</span>    try (Connection c = ConnectionFactory.createConnection(conf);<a name="line.351"></a>
+<span class="sourceLineNo">352</span>        RegionLocator l = c.getRegionLocator(TABLE_NAME1)) {<a name="line.352"></a>
+<span class="sourceLineNo">353</span>      HRegionInfo regionInfo = l.getAllRegionLocations().get(0).getRegionInfo();<a name="line.353"></a>
+<span class="sourceLineNo">354</span>      loadDescriptor =<a name="line.354"></a>
+<span class="sourceLineNo">355</span>          ProtobufUtil.toBulkLoadDescriptor(TABLE_NAME1,<a name="line.355"></a>
+<span class="sourceLineNo">356</span>              UnsafeByteOperations.unsafeWrap(regionInfo.getEncodedNameAsBytes()),<a name="line.356"></a>
+<span class="sourceLineNo">357</span>              storeFiles, storeFilesSize, 1);<a name="line.357"></a>
+<span class="sourceLineNo">358</span>      edit = org.apache.hadoop.hbase.wal.WALEdit.createBulkLoadEvent(regionInfo,<a name="line.358"></a>
+<span class="sourceLineNo">359</span>        loadDescriptor);<a name="line.359"></a>
+<span class="sourceLineNo">360</span>    }<a name="line.360"></a>
+<span class="sourceLineNo">361</span>    List&lt;WALEntry&gt; entries = new ArrayList&lt;&gt;(1);<a name="line.361"></a>
+<span class="sourceLineNo">362</span><a name="line.362"></a>
+<span class="sourceLineNo">363</span>    // 4. Create a WALEntryBuilder<a name="line.363"></a>
+<span class="sourceLineNo">364</span>    WALEntry.Builder builder = createWALEntryBuilder(TABLE_NAME1);<a name="line.364"></a>
+<span class="sourceLineNo">365</span><a name="line.365"></a>
+<span class="sourceLineNo">366</span>    // 5. Copy the hfile to the path as it is in reality<a name="line.366"></a>
+<span class="sourceLineNo">367</span>    for (int i = 0; i &lt; 25; i++) {<a name="line.367"></a>
+<span class="sourceLineNo">368</span>      String pathToHfileFromNS =<a name="line.368"></a>
+<span class="sourceLineNo">369</span>          new StringBuilder(100).append(TABLE_NAME1.getNamespaceAsString()).append(Path.SEPARATOR)<a name="line.369"></a>
+<span class="sourceLineNo">370</span>              .append(Bytes.toString(TABLE_NAME1.getName())).append(Path.SEPARATOR)<a name="line.370"></a>
+<span class="sourceLineNo">371</span>              .append(Bytes.toString(loadDescriptor.getEncodedRegionName().toByteArray()))<a name="line.371"></a>
+<span class="sourceLineNo">372</span>              .append(Path.SEPARATOR).append(Bytes.toString(FAM_NAME1)).append(Path.SEPARATOR)<a name="line.372"></a>
+<span class="sourceLineNo">373</span>              .append("hfile_" + i).toString();<a name="line.373"></a>
+<span class="sourceLineNo">374</span>      String dst = baseNamespaceDir + Path.SEPARATOR + pathToHfileFromNS;<a name="line.374"></a>
+<span class="sourceLineNo">375</span><a name="line.375"></a>
+<span class="sourceLineNo">376</span>      FileUtil.copy(fs, p.get(0), fs, new Path(dst), false, conf);<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>    entries.add(builder.build());<a name="line.379"></a>
+<span class="sourceLineNo">380</span>    try (ResultScanner scanner = table1.getScanner(new Scan())) {<a name="line.380"></a>
+<span class="sourceLineNo">381</span>      // 6. Assert no existing data in table<a name="line.381"></a>
+<span class="sourceLineNo">382</span>      assertEquals(0, scanner.next(numRows).length);<a name="line.382"></a>
+<span class="sourceLineNo">383</span>    }<a name="line.383"></a>
+<span class="sourceLineNo">384</span>    // 7. Replicate the bulk loaded entry<a name="line.384"></a>
+<span class="sourceLineNo">385</span>    SINK.replicateEntries(entries, CellUtil.createCellScanner(edit.getCells().iterator()),<a name="line.385"></a>
+<span class="sourceLineNo">386</span>      replicationClusterId, baseNamespaceDir, hfileArchiveDir);<a name="line.386"></a>
+<span class="sourceLineNo">387</span>    try (ResultScanner scanner = table1.getScanner(new Scan())) {<a name="line.387"></a>
+<span class="sourceLineNo">388</span>      // 8. Assert data is replicated<a name="line.388"></a>
+<span class="sourceLineNo">389</span>      assertEquals(numRows, scanner.next(numRows).length);<a name="line.389"></a>
+<span class="sourceLineNo">390</span>    }<a name="line.390"></a>
+<span class="sourceLineNo">391</span>  }<a name="line.391"></a>
+<span class="sourceLineNo">392</span><a name="line.392"></a>
+<span class="sourceLineNo">393</span>  private WALEntry createEntry(TableName table, int row,  KeyValue.Type type, List&lt;Cell&gt; cells) {<a name="line.393"></a>
+<span class="sourceLineNo">394</span>    byte[] fam = table.equals(TABLE_NAME1) ? FAM_NAME1 : FAM_NAME2;<a name="line.394"></a>
+<span class="sourceLineNo">395</span>    byte[] rowBytes = Bytes.toBytes(row);<a name="line.395"></a>
+<span class="sourceLineNo">396</span>    // Just make sure we don't get the same ts for two consecutive rows with<a name="line.396"></a>
+<span class="sourceLineNo">397</span>    // same key<a name="line.397"></a>
+<span class="sourceLineNo">398</span>    try {<a name="line.398"></a>
+<span class="sourceLineNo">399</span>      Thread.sleep(1);<a name="line.399"></a>
+<span class="sourceLineNo">400</span>    } catch (InterruptedException e) {<a name="line.400"></a>
+<span class="sourceLineNo">401</span>      LOG.info("Was interrupted while sleep, meh", e);<a name="line.401"></a>
+<span class="sourceLineNo">402</span>    }<a name="line.402"></a>
+<span class="sourceLineNo">403</span>    final long now = System.currentTimeMillis();<a name="line.403"></a>
+<span class="sourceLineNo">404</span>    KeyValue kv = null;<a name="line.404"></a>
+<span class="sourceLineNo">405</span>    if(type.getCode() == KeyValue.Type.Put.getCode()) {<a name="line.405"></a>
+<span class="sourceLineNo">406</span>      kv = new KeyValue(rowBytes, fam, fam, now,<a name="line.406"></a>
+<span class="sourceLineNo">407</span>          KeyValue.Type.Put, Bytes.toBytes(row));<a name="line.407"></a>
+<span class="sourceLineNo">408</span>    } else if (type.getCode() == KeyValue.Type.DeleteColumn.getCode()) {<a name="line.408"></a>
+<span class="sourceLineNo">409</span>        kv = new KeyValue(rowBytes, fam, fam,<a name="line.409"></a>
+<span class="sourceLineNo">410</span>            now, KeyValue.Type.DeleteColumn);<a name="line.410"></a>
+<span class="sourceLineNo">411</span>    } else if (type.getCode() == KeyValue.Type.DeleteFamily.getCode()) {<a name="line.411"></a>
+<span class="sourceLineNo">412</span>        kv = new KeyValue(rowBytes, fam, null,<a name="line.412"></a>
+<span class="sourceLineNo">413</span>            now, KeyValue.Type.DeleteFamily);<a name="line.413"></a>
+<span class="sourceLineNo">414</span>    }<a name="line.414"></a>
+<span class="sourceLineNo">415</span>    WALEntry.Builder builder = createWALEntryBuilder(table);<a name="line.415"></a>
+<span class="sourceLineNo">416</span>    cells.add(kv);<a name="line.416"></a>
+<span class="sourceLineNo">417</span><a name="line.417"></a>
+<span class="sourceLineNo">418</span>    return builder.build();<a name="line.418"></a>
+<span class="sourceLineNo">419</span>  }<a name="line.419"></a>
+<span class="sourceLineNo">420</span><a name="line.420"></a>
+<span class="sourceLineNo">421</span>  private WALEntry.Builder createWALEntryBuilder(TableName table) {<a name="line.421"></a>
+<span class="sourceLineNo">422</span>    WALEntry.Builder builder = WALEntry.newBuilder();<a name="line.422"></a>
+<span class="sourceLineNo">423</span>    builder.setAssociatedCellCount(1);<a name="line.423"></a>
+<span class="sourceLineNo">424</span>    WALKey.Builder keyBuilder = WALKey.newBuilder();<a name="line.424"></a>
+<span class="sourceLineNo">425</span>    UUID.Builder uuidBuilder = UUID.newBuilder();<a name="line.425"></a>
+<span class="sourceLineNo">426</span>    uuidBuilder.setLeastSigBits(HConstants.DEFAULT_CLUSTER_ID.getLeastSignificantBits());<a name="line.426"></a>
+<span class="sourceLineNo">427</span>    uuidBuilder.setMostSigBits(HConstants.DEFAULT_CLUSTER_ID.getMostSignificantBits());<a name="line.427"></a>
+<span class="sourceLineNo">428</span>    keyBuilder.setClusterId(uuidBuilder.build());<a name="line.428"></a>
+<span class="sourceLineNo">429</span>    keyBuilder.setTableName(UnsafeByteOperations.unsafeWrap(table.getName()));<a name="line.429"></a>
+<span class="sourceLineNo">430</span>    keyBuilder.setWriteTime(System.currentTimeMillis());<a name="line.430"></a>
+<span class="sourceLineNo">431</span>    keyBuilder.setEncodedRegionName(UnsafeByteOperations.unsafeWrap(HConstants.EMPTY_BYTE_ARRAY));<a name="line.431"></a>
+<span class="sourceLineNo">432</span>    keyBuilder.setLogSequenceNumber(-1);<a name="line.432"></a>
+<span class="sourceLineNo">433</span>    builder.setKey(keyBuilder.build());<a name="line.433"></a>
+<span class="sourceLineNo">434</span>    return builder;<a name="line.434"></a>
+<span class="sourceLineNo">435</span>  }<a name="line.435"></a>
+<span class="sourceLineNo">436</span>}<a name="line.436"></a>
 
 
 


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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/testdevapidocs/src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html b/testdevapidocs/src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html
index c02a436..cdcd37f 100644
--- a/testdevapidocs/src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html
+++ b/testdevapidocs/src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html
@@ -50,39 +50,39 @@
 <span class="sourceLineNo">042</span>import java.util.concurrent.TimeUnit;<a name="line.42"></a>
 <span class="sourceLineNo">043</span>import java.util.concurrent.TimeoutException;<a name="line.43"></a>
 <span class="sourceLineNo">044</span>import java.util.concurrent.atomic.LongAdder;<a name="line.44"></a>
-<span class="sourceLineNo">045</span><a name="line.45"></a>
-<span class="sourceLineNo">046</span>import org.apache.hadoop.conf.Configuration;<a name="line.46"></a>
-<span class="sourceLineNo">047</span>import org.apache.hadoop.fs.FSDataOutputStream;<a name="line.47"></a>
-<span class="sourceLineNo">048</span>import org.apache.hadoop.fs.FileStatus;<a name="line.48"></a>
-<span class="sourceLineNo">049</span>import org.apache.hadoop.fs.FileSystem;<a name="line.49"></a>
-<span class="sourceLineNo">050</span>import org.apache.hadoop.fs.Path;<a name="line.50"></a>
-<span class="sourceLineNo">051</span>import org.apache.hadoop.fs.PathFilter;<a name="line.51"></a>
-<span class="sourceLineNo">052</span>import org.apache.hadoop.hbase.HBaseTestingUtility;<a name="line.52"></a>
-<span class="sourceLineNo">053</span>import org.apache.hadoop.hbase.HConstants;<a name="line.53"></a>
-<span class="sourceLineNo">054</span>import org.apache.hadoop.hbase.KeyValue;<a name="line.54"></a>
-<span class="sourceLineNo">055</span>import org.apache.hadoop.hbase.MiniHBaseCluster;<a name="line.55"></a>
-<span class="sourceLineNo">056</span>import org.apache.hadoop.hbase.NamespaceDescriptor;<a name="line.56"></a>
-<span class="sourceLineNo">057</span>import org.apache.hadoop.hbase.ServerName;<a name="line.57"></a>
-<span class="sourceLineNo">058</span>import org.apache.hadoop.hbase.SplitLogCounters;<a name="line.58"></a>
-<span class="sourceLineNo">059</span>import org.apache.hadoop.hbase.TableName;<a name="line.59"></a>
-<span class="sourceLineNo">060</span>import org.apache.hadoop.hbase.Waiter;<a name="line.60"></a>
-<span class="sourceLineNo">061</span>import org.apache.hadoop.hbase.client.Put;<a name="line.61"></a>
-<span class="sourceLineNo">062</span>import org.apache.hadoop.hbase.client.RegionInfo;<a name="line.62"></a>
-<span class="sourceLineNo">063</span>import org.apache.hadoop.hbase.client.RegionInfoBuilder;<a name="line.63"></a>
-<span class="sourceLineNo">064</span>import org.apache.hadoop.hbase.client.RegionLocator;<a name="line.64"></a>
-<span class="sourceLineNo">065</span>import org.apache.hadoop.hbase.client.Table;<a name="line.65"></a>
-<span class="sourceLineNo">066</span>import org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination;<a name="line.66"></a>
-<span class="sourceLineNo">067</span>import org.apache.hadoop.hbase.ipc.ServerNotRunningYetException;<a name="line.67"></a>
-<span class="sourceLineNo">068</span>import org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch;<a name="line.68"></a>
-<span class="sourceLineNo">069</span>import org.apache.hadoop.hbase.master.assignment.RegionStates;<a name="line.69"></a>
-<span class="sourceLineNo">070</span>import org.apache.hadoop.hbase.regionserver.HRegion;<a name="line.70"></a>
-<span class="sourceLineNo">071</span>import org.apache.hadoop.hbase.regionserver.HRegionServer;<a name="line.71"></a>
-<span class="sourceLineNo">072</span>import org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl;<a name="line.72"></a>
-<span class="sourceLineNo">073</span>import org.apache.hadoop.hbase.regionserver.Region;<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.FSUtils;<a name="line.75"></a>
-<span class="sourceLineNo">076</span>import org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread;<a name="line.76"></a>
-<span class="sourceLineNo">077</span>import org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread;<a name="line.77"></a>
+<span class="sourceLineNo">045</span>import org.apache.hadoop.conf.Configuration;<a name="line.45"></a>
+<span class="sourceLineNo">046</span>import org.apache.hadoop.fs.FSDataOutputStream;<a name="line.46"></a>
+<span class="sourceLineNo">047</span>import org.apache.hadoop.fs.FileStatus;<a name="line.47"></a>
+<span class="sourceLineNo">048</span>import org.apache.hadoop.fs.FileSystem;<a name="line.48"></a>
+<span class="sourceLineNo">049</span>import org.apache.hadoop.fs.Path;<a name="line.49"></a>
+<span class="sourceLineNo">050</span>import org.apache.hadoop.fs.PathFilter;<a name="line.50"></a>
+<span class="sourceLineNo">051</span>import org.apache.hadoop.hbase.HBaseTestingUtility;<a name="line.51"></a>
+<span class="sourceLineNo">052</span>import org.apache.hadoop.hbase.HConstants;<a name="line.52"></a>
+<span class="sourceLineNo">053</span>import org.apache.hadoop.hbase.KeyValue;<a name="line.53"></a>
+<span class="sourceLineNo">054</span>import org.apache.hadoop.hbase.MiniHBaseCluster;<a name="line.54"></a>
+<span class="sourceLineNo">055</span>import org.apache.hadoop.hbase.NamespaceDescriptor;<a name="line.55"></a>
+<span class="sourceLineNo">056</span>import org.apache.hadoop.hbase.ServerName;<a name="line.56"></a>
+<span class="sourceLineNo">057</span>import org.apache.hadoop.hbase.SplitLogCounters;<a name="line.57"></a>
+<span class="sourceLineNo">058</span>import org.apache.hadoop.hbase.TableName;<a name="line.58"></a>
+<span class="sourceLineNo">059</span>import org.apache.hadoop.hbase.Waiter;<a name="line.59"></a>
+<span class="sourceLineNo">060</span>import org.apache.hadoop.hbase.client.Put;<a name="line.60"></a>
+<span class="sourceLineNo">061</span>import org.apache.hadoop.hbase.client.RegionInfo;<a name="line.61"></a>
+<span class="sourceLineNo">062</span>import org.apache.hadoop.hbase.client.RegionInfoBuilder;<a name="line.62"></a>
+<span class="sourceLineNo">063</span>import org.apache.hadoop.hbase.client.RegionLocator;<a name="line.63"></a>
+<span class="sourceLineNo">064</span>import org.apache.hadoop.hbase.client.Table;<a name="line.64"></a>
+<span class="sourceLineNo">065</span>import org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination;<a name="line.65"></a>
+<span class="sourceLineNo">066</span>import org.apache.hadoop.hbase.ipc.ServerNotRunningYetException;<a name="line.66"></a>
+<span class="sourceLineNo">067</span>import org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch;<a name="line.67"></a>
+<span class="sourceLineNo">068</span>import org.apache.hadoop.hbase.master.assignment.RegionStates;<a name="line.68"></a>
+<span class="sourceLineNo">069</span>import org.apache.hadoop.hbase.regionserver.HRegion;<a name="line.69"></a>
+<span class="sourceLineNo">070</span>import org.apache.hadoop.hbase.regionserver.HRegionServer;<a name="line.70"></a>
+<span class="sourceLineNo">071</span>import org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl;<a name="line.71"></a>
+<span class="sourceLineNo">072</span>import org.apache.hadoop.hbase.regionserver.Region;<a name="line.72"></a>
+<span class="sourceLineNo">073</span>import org.apache.hadoop.hbase.util.Bytes;<a name="line.73"></a>
+<span class="sourceLineNo">074</span>import org.apache.hadoop.hbase.util.FSUtils;<a name="line.74"></a>
+<span class="sourceLineNo">075</span>import org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread;<a name="line.75"></a>
+<span class="sourceLineNo">076</span>import org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread;<a name="line.76"></a>
+<span class="sourceLineNo">077</span>import org.apache.hadoop.hbase.util.Threads;<a name="line.77"></a>
 <span class="sourceLineNo">078</span>import org.apache.hadoop.hbase.wal.AbstractFSWALProvider;<a name="line.78"></a>
 <span class="sourceLineNo">079</span>import org.apache.hadoop.hbase.wal.WAL;<a name="line.79"></a>
 <span class="sourceLineNo">080</span>import org.apache.hadoop.hbase.wal.WALEdit;<a name="line.80"></a>
@@ -100,693 +100,701 @@
 <span class="sourceLineNo">092</span>import org.junit.rules.TestName;<a name="line.92"></a>
 <span class="sourceLineNo">093</span>import org.slf4j.Logger;<a name="line.93"></a>
 <span class="sourceLineNo">094</span>import org.slf4j.LoggerFactory;<a name="line.94"></a>
-<span class="sourceLineNo">095</span>import org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil;<a name="line.95"></a>
-<span class="sourceLineNo">096</span><a name="line.96"></a>
-<span class="sourceLineNo">097</span>/**<a name="line.97"></a>
-<span class="sourceLineNo">098</span> * Base class for testing distributed log splitting.<a name="line.98"></a>
-<span class="sourceLineNo">099</span> */<a name="line.99"></a>
-<span class="sourceLineNo">100</span>public abstract class AbstractTestDLS {<a name="line.100"></a>
-<span class="sourceLineNo">101</span>  private static final Logger LOG = LoggerFactory.getLogger(TestSplitLogManager.class);<a name="line.101"></a>
-<span class="sourceLineNo">102</span><a name="line.102"></a>
-<span class="sourceLineNo">103</span>  private static final HBaseTestingUtility TEST_UTIL = new HBaseTestingUtility();<a name="line.103"></a>
-<span class="sourceLineNo">104</span><a name="line.104"></a>
-<span class="sourceLineNo">105</span>  // Start a cluster with 2 masters and 5 regionservers<a name="line.105"></a>
-<span class="sourceLineNo">106</span>  private static final int NUM_MASTERS = 2;<a name="line.106"></a>
-<span class="sourceLineNo">107</span>  private static final int NUM_RS = 5;<a name="line.107"></a>
-<span class="sourceLineNo">108</span>  private static byte[] COLUMN_FAMILY = Bytes.toBytes("family");<a name="line.108"></a>
-<span class="sourceLineNo">109</span><a name="line.109"></a>
-<span class="sourceLineNo">110</span>  @Rule<a name="line.110"></a>
-<span class="sourceLineNo">111</span>  public TestName testName = new TestName();<a name="line.111"></a>
-<span class="sourceLineNo">112</span><a name="line.112"></a>
-<span class="sourceLineNo">113</span>  private TableName tableName;<a name="line.113"></a>
-<span class="sourceLineNo">114</span>  private MiniHBaseCluster cluster;<a name="line.114"></a>
-<span class="sourceLineNo">115</span>  private HMaster master;<a name="line.115"></a>
-<span class="sourceLineNo">116</span>  private Configuration conf;<a name="line.116"></a>
-<span class="sourceLineNo">117</span><a name="line.117"></a>
-<span class="sourceLineNo">118</span>  @Rule<a name="line.118"></a>
-<span class="sourceLineNo">119</span>  public TestName name = new TestName();<a name="line.119"></a>
-<span class="sourceLineNo">120</span><a name="line.120"></a>
-<span class="sourceLineNo">121</span>  @BeforeClass<a name="line.121"></a>
-<span class="sourceLineNo">122</span>  public static void setup() throws Exception {<a name="line.122"></a>
-<span class="sourceLineNo">123</span>    // Uncomment the following line if more verbosity is needed for<a name="line.123"></a>
-<span class="sourceLineNo">124</span>    // debugging (see HBASE-12285 for details).<a name="line.124"></a>
-<span class="sourceLineNo">125</span>    // Logger.getLogger("org.apache.hadoop.hbase").setLevel(Level.DEBUG);<a name="line.125"></a>
-<span class="sourceLineNo">126</span>    TEST_UTIL.startMiniZKCluster();<a name="line.126"></a>
-<span class="sourceLineNo">127</span>    TEST_UTIL.startMiniDFSCluster(3);<a name="line.127"></a>
-<span class="sourceLineNo">128</span>  }<a name="line.128"></a>
-<span class="sourceLineNo">129</span><a name="line.129"></a>
-<span class="sourceLineNo">130</span>  @AfterClass<a name="line.130"></a>
-<span class="sourceLineNo">131</span>  public static void tearDown() throws Exception {<a name="line.131"></a>
-<span class="sourceLineNo">132</span>    TEST_UTIL.shutdownMiniCluster();<a name="line.132"></a>
-<span class="sourceLineNo">133</span>  }<a name="line.133"></a>
-<span class="sourceLineNo">134</span><a name="line.134"></a>
-<span class="sourceLineNo">135</span>  protected abstract String getWalProvider();<a name="line.135"></a>
-<span class="sourceLineNo">136</span><a name="line.136"></a>
-<span class="sourceLineNo">137</span>  private void startCluster(int numRS) throws Exception {<a name="line.137"></a>
-<span class="sourceLineNo">138</span>    SplitLogCounters.resetCounters();<a name="line.138"></a>
-<span class="sourceLineNo">139</span>    LOG.info("Starting cluster");<a name="line.139"></a>
-<span class="sourceLineNo">140</span>    conf.setLong("hbase.splitlog.max.resubmit", 0);<a name="line.140"></a>
-<span class="sourceLineNo">141</span>    // Make the failure test faster<a name="line.141"></a>
-<span class="sourceLineNo">142</span>    conf.setInt("zookeeper.recovery.retry", 0);<a name="line.142"></a>
-<span class="sourceLineNo">143</span>    conf.setInt(HConstants.REGIONSERVER_INFO_PORT, -1);<a name="line.143"></a>
-<span class="sourceLineNo">144</span>    conf.setFloat(HConstants.LOAD_BALANCER_SLOP_KEY, (float) 100.0); // no load balancing<a name="line.144"></a>
-<span class="sourceLineNo">145</span>    conf.setInt("hbase.regionserver.wal.max.splitters", 3);<a name="line.145"></a>
-<span class="sourceLineNo">146</span>    conf.setInt(HConstants.REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT, 10);<a name="line.146"></a>
-<span class="sourceLineNo">147</span>    conf.set("hbase.wal.provider", getWalProvider());<a name="line.147"></a>
-<span class="sourceLineNo">148</span>    TEST_UTIL.startMiniHBaseCluster(NUM_MASTERS, numRS);<a name="line.148"></a>
-<span class="sourceLineNo">149</span>    cluster = TEST_UTIL.getHBaseCluster();<a name="line.149"></a>
-<span class="sourceLineNo">150</span>    LOG.info("Waiting for active/ready master");<a name="line.150"></a>
-<span class="sourceLineNo">151</span>    cluster.waitForActiveAndReadyMaster();<a name="line.151"></a>
-<span class="sourceLineNo">152</span>    master = cluster.getMaster();<a name="line.152"></a>
-<span class="sourceLineNo">153</span>    TEST_UTIL.waitFor(120000, 200, new Waiter.Predicate&lt;Exception&gt;() {<a name="line.153"></a>
-<span class="sourceLineNo">154</span>      @Override<a name="line.154"></a>
-<span class="sourceLineNo">155</span>      public boolean evaluate() throws Exception {<a name="line.155"></a>
-<span class="sourceLineNo">156</span>        return cluster.getLiveRegionServerThreads().size() &gt;= numRS;<a name="line.156"></a>
-<span class="sourceLineNo">157</span>      }<a name="line.157"></a>
-<span class="sourceLineNo">158</span>    });<a name="line.158"></a>
-<span class="sourceLineNo">159</span>  }<a name="line.159"></a>
-<span class="sourceLineNo">160</span><a name="line.160"></a>
-<span class="sourceLineNo">161</span>  @Before<a name="line.161"></a>
-<span class="sourceLineNo">162</span>  public void before() throws Exception {<a name="line.162"></a>
-<span class="sourceLineNo">163</span>    conf = TEST_UTIL.getConfiguration();<a name="line.163"></a>
-<span class="sourceLineNo">164</span>    tableName = TableName.valueOf(testName.getMethodName());<a name="line.164"></a>
-<span class="sourceLineNo">165</span>  }<a name="line.165"></a>
-<span class="sourceLineNo">166</span><a name="line.166"></a>
-<span class="sourceLineNo">167</span>  @After<a name="line.167"></a>
-<span class="sourceLineNo">168</span>  public void after() throws Exception {<a name="line.168"></a>
-<span class="sourceLineNo">169</span>    TEST_UTIL.shutdownMiniHBaseCluster();<a name="line.169"></a>
-<span class="sourceLineNo">170</span>    TEST_UTIL.getTestFileSystem().delete(FSUtils.getRootDir(TEST_UTIL.getConfiguration()), true);<a name="line.170"></a>
-<span class="sourceLineNo">171</span>    ZKUtil.deleteNodeRecursively(TEST_UTIL.getZooKeeperWatcher(), "/hbase");<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>  @Test<a name="line.174"></a>
-<span class="sourceLineNo">175</span>  public void testRecoveredEdits() throws Exception {<a name="line.175"></a>
-<span class="sourceLineNo">176</span>    conf.setLong("hbase.regionserver.hlog.blocksize", 30 * 1024); // create more than one wal<a name="line.176"></a>
-<span class="sourceLineNo">177</span>    startCluster(NUM_RS);<a name="line.177"></a>
-<span class="sourceLineNo">178</span><a name="line.178"></a>
-<span class="sourceLineNo">179</span>    int numLogLines = 10000;<a name="line.179"></a>
-<span class="sourceLineNo">180</span>    SplitLogManager slm = master.getMasterWalManager().getSplitLogManager();<a name="line.180"></a>
-<span class="sourceLineNo">181</span>    // turn off load balancing to prevent regions from moving around otherwise<a name="line.181"></a>
-<span class="sourceLineNo">182</span>    // they will consume recovered.edits<a name="line.182"></a>
-<span class="sourceLineNo">183</span>    master.balanceSwitch(false);<a name="line.183"></a>
-<span class="sourceLineNo">184</span>    FileSystem fs = master.getMasterFileSystem().getFileSystem();<a name="line.184"></a>
-<span class="sourceLineNo">185</span><a name="line.185"></a>
-<span class="sourceLineNo">186</span>    List&lt;RegionServerThread&gt; rsts = cluster.getLiveRegionServerThreads();<a name="line.186"></a>
-<span class="sourceLineNo">187</span><a name="line.187"></a>
-<span class="sourceLineNo">188</span>    Path rootdir = FSUtils.getRootDir(conf);<a name="line.188"></a>
-<span class="sourceLineNo">189</span><a name="line.189"></a>
-<span class="sourceLineNo">190</span>    int numRegions = 50;<a name="line.190"></a>
-<span class="sourceLineNo">191</span>    try (ZKWatcher zkw = new ZKWatcher(conf, "table-creation", null);<a name="line.191"></a>
-<span class="sourceLineNo">192</span>        Table t = installTable(zkw, numRegions)) {<a name="line.192"></a>
-<span class="sourceLineNo">193</span>      TableName table = t.getName();<a name="line.193"></a>
-<span class="sourceLineNo">194</span>      List&lt;RegionInfo&gt; regions = null;<a name="line.194"></a>
-<span class="sourceLineNo">195</span>      HRegionServer hrs = null;<a name="line.195"></a>
-<span class="sourceLineNo">196</span>      for (int i = 0; i &lt; NUM_RS; i++) {<a name="line.196"></a>
-<span class="sourceLineNo">197</span>        hrs = rsts.get(i).getRegionServer();<a name="line.197"></a>
-<span class="sourceLineNo">198</span>        regions = ProtobufUtil.getOnlineRegions(hrs.getRSRpcServices());<a name="line.198"></a>
-<span class="sourceLineNo">199</span>        // At least one RS will have &gt;= to average number of regions.<a name="line.199"></a>
-<span class="sourceLineNo">200</span>        if (regions.size() &gt;= numRegions / NUM_RS) {<a name="line.200"></a>
-<span class="sourceLineNo">201</span>          break;<a name="line.201"></a>
-<span class="sourceLineNo">202</span>        }<a name="line.202"></a>
-<span class="sourceLineNo">203</span>      }<a name="line.203"></a>
-<span class="sourceLineNo">204</span>      Path logDir = new Path(rootdir,<a name="line.204"></a>
-<span class="sourceLineNo">205</span>          AbstractFSWALProvider.getWALDirectoryName(hrs.getServerName().toString()));<a name="line.205"></a>
-<span class="sourceLineNo">206</span><a name="line.206"></a>
-<span class="sourceLineNo">207</span>      LOG.info("#regions = " + regions.size());<a name="line.207"></a>
-<span class="sourceLineNo">208</span>      Iterator&lt;RegionInfo&gt; it = regions.iterator();<a name="line.208"></a>
-<span class="sourceLineNo">209</span>      while (it.hasNext()) {<a name="line.209"></a>
-<span class="sourceLineNo">210</span>        RegionInfo region = it.next();<a name="line.210"></a>
-<span class="sourceLineNo">211</span>        if (region.getTable().getNamespaceAsString()<a name="line.211"></a>
-<span class="sourceLineNo">212</span>            .equals(NamespaceDescriptor.SYSTEM_NAMESPACE_NAME_STR)) {<a name="line.212"></a>
-<span class="sourceLineNo">213</span>          it.remove();<a name="line.213"></a>
-<span class="sourceLineNo">214</span>        }<a name="line.214"></a>
-<span class="sourceLineNo">215</span>      }<a name="line.215"></a>
-<span class="sourceLineNo">216</span><a name="line.216"></a>
-<span class="sourceLineNo">217</span>      makeWAL(hrs, regions, numLogLines, 100);<a name="line.217"></a>
-<span class="sourceLineNo">218</span><a name="line.218"></a>
-<span class="sourceLineNo">219</span>      slm.splitLogDistributed(logDir);<a name="line.219"></a>
-<span class="sourceLineNo">220</span><a name="line.220"></a>
-<span class="sourceLineNo">221</span>      int count = 0;<a name="line.221"></a>
-<span class="sourceLineNo">222</span>      for (RegionInfo hri : regions) {<a name="line.222"></a>
-<span class="sourceLineNo">223</span>        Path tdir = FSUtils.getTableDir(rootdir, table);<a name="line.223"></a>
-<span class="sourceLineNo">224</span>        @SuppressWarnings("deprecation")<a name="line.224"></a>
-<span class="sourceLineNo">225</span>        Path editsdir = WALSplitter<a name="line.225"></a>
-<span class="sourceLineNo">226</span>            .getRegionDirRecoveredEditsDir(HRegion.getRegionDir(tdir, hri.getEncodedName()));<a name="line.226"></a>
-<span class="sourceLineNo">227</span>        LOG.debug("checking edits dir " + editsdir);<a name="line.227"></a>
-<span class="sourceLineNo">228</span>        FileStatus[] files = fs.listStatus(editsdir, new PathFilter() {<a name="line.228"></a>
-<span class="sourceLineNo">229</span>          @Override<a name="line.229"></a>
-<span class="sourceLineNo">230</span>          public boolean accept(Path p) {<a name="line.230"></a>
-<span class="sourceLineNo">231</span>            if (WALSplitter.isSequenceIdFile(p)) {<a name="line.231"></a>
-<span class="sourceLineNo">232</span>              return false;<a name="line.232"></a>
-<span class="sourceLineNo">233</span>            }<a name="line.233"></a>
-<span class="sourceLineNo">234</span>            return true;<a name="line.234"></a>
-<span class="sourceLineNo">235</span>          }<a name="line.235"></a>
-<span class="sourceLineNo">236</span>        });<a name="line.236"></a>
-<span class="sourceLineNo">237</span>        assertTrue(<a name="line.237"></a>
-<span class="sourceLineNo">238</span>          "edits dir should have more than a single file in it. instead has " + files.length,<a name="line.238"></a>
-<span class="sourceLineNo">239</span>          files.length &gt; 1);<a name="line.239"></a>
-<span class="sourceLineNo">240</span>        for (int i = 0; i &lt; files.length; i++) {<a name="line.240"></a>
-<span class="sourceLineNo">241</span>          int c = countWAL(files[i].getPath(), fs, conf);<a name="line.241"></a>
-<span class="sourceLineNo">242</span>          count += c;<a name="line.242"></a>
-<span class="sourceLineNo">243</span>        }<a name="line.243"></a>
-<span class="sourceLineNo">244</span>        LOG.info(count + " edits in " + files.length + " recovered edits files.");<a name="line.244"></a>
-<span class="sourceLineNo">245</span>      }<a name="line.245"></a>
-<span class="sourceLineNo">246</span><a name="line.246"></a>
-<span class="sourceLineNo">247</span>      // check that the log file is moved<a name="line.247"></a>
-<span class="sourceLineNo">248</span>      assertFalse(fs.exists(logDir));<a name="line.248"></a>
-<span class="sourceLineNo">249</span>      assertEquals(numLogLines, count);<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><a name="line.252"></a>
-<span class="sourceLineNo">253</span>  @Test<a name="line.253"></a>
-<span class="sourceLineNo">254</span>  public void testMasterStartsUpWithLogSplittingWork() throws Exception {<a name="line.254"></a>
-<span class="sourceLineNo">255</span>    conf.setInt(ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART, NUM_RS - 1);<a name="line.255"></a>
-<span class="sourceLineNo">256</span>    startCluster(NUM_RS);<a name="line.256"></a>
-<span class="sourceLineNo">257</span><a name="line.257"></a>
-<span class="sourceLineNo">258</span>    int numRegionsToCreate = 40;<a name="line.258"></a>
-<span class="sourceLineNo">259</span>    int numLogLines = 1000;<a name="line.259"></a>
-<span class="sourceLineNo">260</span>    // turn off load balancing to prevent regions from moving around otherwise<a name="line.260"></a>
-<span class="sourceLineNo">261</span>    // they will consume recovered.edits<a name="line.261"></a>
-<span class="sourceLineNo">262</span>    master.balanceSwitch(false);<a name="line.262"></a>
-<span class="sourceLineNo">263</span><a name="line.263"></a>
-<span class="sourceLineNo">264</span>    try (ZKWatcher zkw = new ZKWatcher(conf, "table-creation", null);<a name="line.264"></a>
-<span class="sourceLineNo">265</span>        Table ht = installTable(zkw, numRegionsToCreate)) {<a name="line.265"></a>
-<span class="sourceLineNo">266</span>      HRegionServer hrs = findRSToKill(false);<a name="line.266"></a>
-<span class="sourceLineNo">267</span>      List&lt;RegionInfo&gt; regions = ProtobufUtil.getOnlineRegions(hrs.getRSRpcServices());<a name="line.267"></a>
-<span class="sourceLineNo">268</span>      makeWAL(hrs, regions, numLogLines, 100);<a name="line.268"></a>
-<span class="sourceLineNo">269</span><a name="line.269"></a>
-<span class="sourceLineNo">270</span>      // abort master<a name="line.270"></a>
-<span class="sourceLineNo">271</span>      abortMaster(cluster);<a name="line.271"></a>
-<span class="sourceLineNo">272</span><a name="line.272"></a>
-<span class="sourceLineNo">273</span>      // abort RS<a name="line.273"></a>
-<span class="sourceLineNo">274</span>      LOG.info("Aborting region server: " + hrs.getServerName());<a name="line.274"></a>
-<span class="sourceLineNo">275</span>      hrs.abort("testing");<a name="line.275"></a>
-<span class="sourceLineNo">276</span><a name="line.276"></a>
-<span class="sourceLineNo">277</span>      // wait for abort completes<a name="line.277"></a>
-<span class="sourceLineNo">278</span>      TEST_UTIL.waitFor(120000, 200, new Waiter.Predicate&lt;Exception&gt;() {<a name="line.278"></a>
-<span class="sourceLineNo">279</span>        @Override<a name="line.279"></a>
-<span class="sourceLineNo">280</span>        public boolean evaluate() throws Exception {<a name="line.280"></a>
-<span class="sourceLineNo">281</span>          return cluster.getLiveRegionServerThreads().size() &lt;= NUM_RS - 1;<a name="line.281"></a>
-<span class="sourceLineNo">282</span>        }<a name="line.282"></a>
-<span class="sourceLineNo">283</span>      });<a name="line.283"></a>
-<span class="sourceLineNo">284</span><a name="line.284"></a>
-<span class="sourceLineNo">285</span>      Thread.sleep(2000);<a name="line.285"></a>
-<span class="sourceLineNo">286</span>      LOG.info("Current Open Regions:" + HBaseTestingUtility.getAllOnlineRegions(cluster).size());<a name="line.286"></a>
-<span class="sourceLineNo">287</span><a name="line.287"></a>
-<span class="sourceLineNo">288</span>      // wait for abort completes<a name="line.288"></a>
-<span class="sourceLineNo">289</span>      TEST_UTIL.waitFor(120000, 200, new Waiter.Predicate&lt;Exception&gt;() {<a name="line.289"></a>
-<span class="sourceLineNo">290</span>        @Override<a name="line.290"></a>
-<span class="sourceLineNo">291</span>        public boolean evaluate() throws Exception {<a name="line.291"></a>
-<span class="sourceLineNo">292</span>          return (HBaseTestingUtility.getAllOnlineRegions(cluster)<a name="line.292"></a>
-<span class="sourceLineNo">293</span>              .size() &gt;= (numRegionsToCreate + 1));<a name="line.293"></a>
-<span class="sourceLineNo">294</span>        }<a name="line.294"></a>
-<span class="sourceLineNo">295</span>      });<a name="line.295"></a>
-<span class="sourceLineNo">296</span><a name="line.296"></a>
-<span class="sourceLineNo">297</span>      LOG.info("Current Open Regions After Master Node Starts Up:" +<a name="line.297"></a>
-<span class="sourceLineNo">298</span>          HBaseTestingUtility.getAllOnlineRegions(cluster).size());<a name="line.298"></a>
-<span class="sourceLineNo">299</span><a name="line.299"></a>
-<span class="sourceLineNo">300</span>      assertEquals(numLogLines, TEST_UTIL.countRows(ht));<a name="line.300"></a>
-<span class="sourceLineNo">301</span>    }<a name="line.301"></a>
-<span class="sourceLineNo">302</span>  }<a name="line.302"></a>
-<span class="sourceLineNo">303</span><a name="line.303"></a>
-<span class="sourceLineNo">304</span>  /**<a name="line.304"></a>
-<span class="sourceLineNo">305</span>   * The original intention of this test was to force an abort of a region server and to make sure<a name="line.305"></a>
-<span class="sourceLineNo">306</span>   * that the failure path in the region servers is properly evaluated. But it is difficult to<a name="line.306"></a>
-<span class="sourceLineNo">307</span>   * ensure that the region server doesn't finish the log splitting before it aborts. Also now,<a name="line.307"></a>
-<span class="sourceLineNo">308</span>   * there is this code path where the master will preempt the region server when master detects<a name="line.308"></a>
-<span class="sourceLineNo">309</span>   * that the region server has aborted.<a name="line.309"></a>
-<span class="sourceLineNo">310</span>   * @throws Exception<a name="line.310"></a>
-<span class="sourceLineNo">311</span>   */<a name="line.311"></a>
-<span class="sourceLineNo">312</span>  // Was marked flaky before Distributed Log Replay cleanup.<a name="line.312"></a>
-<span class="sourceLineNo">313</span>  @Test<a name="line.313"></a>
-<span class="sourceLineNo">314</span>  public void testWorkerAbort() throws Exception {<a name="line.314"></a>
-<span class="sourceLineNo">315</span>    LOG.info("testWorkerAbort");<a name="line.315"></a>
-<span class="sourceLineNo">316</span>    startCluster(3);<a name="line.316"></a>
-<span class="sourceLineNo">317</span>    int numLogLines = 10000;<a name="line.317"></a>
-<span class="sourceLineNo">318</span>    SplitLogManager slm = master.getMasterWalManager().getSplitLogManager();<a name="line.318"></a>
-<span class="sourceLineNo">319</span>    FileSystem fs = master.getMasterFileSystem().getFileSystem();<a name="line.319"></a>
-<span class="sourceLineNo">320</span><a name="line.320"></a>
-<span class="sourceLineNo">321</span>    List&lt;RegionServerThread&gt; rsts = cluster.getLiveRegionServerThreads();<a name="line.321"></a>
-<span class="sourceLineNo">322</span>    HRegionServer hrs = findRSToKill(false);<a name="line.322"></a>
-<span class="sourceLineNo">323</span>    Path rootdir = FSUtils.getRootDir(conf);<a name="line.323"></a>
-<span class="sourceLineNo">324</span>    final Path logDir = new Path(rootdir,<a name="line.324"></a>
-<span class="sourceLineNo">325</span>        AbstractFSWALProvider.getWALDirectoryName(hrs.getServerName().toString()));<a name="line.325"></a>
-<span class="sourceLineNo">326</span><a name="line.326"></a>
-<span class="sourceLineNo">327</span>    try (ZKWatcher zkw = new ZKWatcher(conf, "table-creation", null);<a name="line.327"></a>
-<span class="sourceLineNo">328</span>        Table t = installTable(zkw, 40)) {<a name="line.328"></a>
-<span class="sourceLineNo">329</span>      makeWAL(hrs, ProtobufUtil.getOnlineRegions(hrs.getRSRpcServices()), numLogLines, 100);<a name="line.329"></a>
-<span class="sourceLineNo">330</span><a name="line.330"></a>
-<span class="sourceLineNo">331</span>      new Thread() {<a name="line.331"></a>
-<span class="sourceLineNo">332</span>        @Override<a name="line.332"></a>
-<span class="sourceLineNo">333</span>        public void run() {<a name="line.333"></a>
-<span class="sourceLineNo">334</span>          try {<a name="line.334"></a>
-<span class="sourceLineNo">335</span>            waitForCounter(tot_wkr_task_acquired, 0, 1, 1000);<a name="line.335"></a>
-<span class="sourceLineNo">336</span>          } catch (InterruptedException e) {<a name="line.336"></a>
-<span class="sourceLineNo">337</span>          }<a name="line.337"></a>
-<span class="sourceLineNo">338</span>          for (RegionServerThread rst : rsts) {<a name="line.338"></a>
-<span class="sourceLineNo">339</span>            rst.getRegionServer().abort("testing");<a name="line.339"></a>
-<span class="sourceLineNo">340</span>            break;<a name="line.340"></a>
-<span class="sourceLineNo">341</span>          }<a name="line.341"></a>
-<span class="sourceLineNo">342</span>        }<a name="line.342"></a>
-<span class="sourceLineNo">343</span>      }.start();<a name="line.343"></a>
-<span class="sourceLineNo">344</span>      FileStatus[] logfiles = fs.listStatus(logDir);<a name="line.344"></a>
-<span class="sourceLineNo">345</span>      TaskBatch batch = new TaskBatch();<a name="line.345"></a>
-<span class="sourceLineNo">346</span>      slm.enqueueSplitTask(logfiles[0].getPath().toString(), batch);<a name="line.346"></a>
-<span class="sourceLineNo">347</span>      // waitForCounter but for one of the 2 counters<a name="line.347"></a>
-<span class="sourceLineNo">348</span>      long curt = System.currentTimeMillis();<a name="line.348"></a>
-<span class="sourceLineNo">349</span>      long waitTime = 80000;<a name="line.349"></a>
-<span class="sourceLineNo">350</span>      long endt = curt + waitTime;<a name="line.350"></a>
-<span class="sourceLineNo">351</span>      while (curt &lt; endt) {<a name="line.351"></a>
-<span class="sourceLineNo">352</span>        if ((tot_wkr_task_resigned.sum() + tot_wkr_task_err.sum() +<a name="line.352"></a>
-<span class="sourceLineNo">353</span>            tot_wkr_final_transition_failed.sum() + tot_wkr_task_done.sum() +<a name="line.353"></a>
-<span class="sourceLineNo">354</span>            tot_wkr_preempt_task.sum()) == 0) {<a name="line.354"></a>
-<span class="sourceLineNo">355</span>          Thread.sleep(100);<a name="line.355"></a>
-<span class="sourceLineNo">356</span>          curt = System.currentTimeMillis();<a name="line.356"></a>
-<span class="sourceLineNo">357</span>        } else {<a name="line.357"></a>
-<span class="sourceLineNo">358</span>          assertTrue(1 &lt;= (tot_wkr_task_resigned.sum() + tot_wkr_task_err.sum() +<a name="line.358"></a>
-<span class="sourceLineNo">359</span>              tot_wkr_final_transition_failed.sum() + tot_wkr_task_done.sum() +<a name="line.359"></a>
-<span class="sourceLineNo">360</span>              tot_wkr_preempt_task.sum()));<a name="line.360"></a>
-<span class="sourceLineNo">361</span>          return;<a name="line.361"></a>
-<span class="sourceLineNo">362</span>        }<a name="line.362"></a>
-<span class="sourceLineNo">363</span>      }<a name="line.363"></a>
-<span class="sourceLineNo">364</span>      fail("none of the following counters went up in " + waitTime + " milliseconds - " +<a name="line.364"></a>
-<span class="sourceLineNo">365</span>          "tot_wkr_task_resigned, tot_wkr_task_err, " +<a name="line.365"></a>
-<span class="sourceLineNo">366</span>          "tot_wkr_final_transition_failed, tot_wkr_task_done, " + "tot_wkr_preempt_task");<a name="line.366"></a>
-<span class="sourceLineNo">367</span>    }<a name="line.367"></a>
-<span class="sourceLineNo">368</span>  }<a name="line.368"></a>
-<span class="sourceLineNo">369</span><a name="line.369"></a>
-<span class="sourceLineNo">370</span>  @Test<a name="line.370"></a>
-<span class="sourceLineNo">371</span>  public void testThreeRSAbort() throws Exception {<a name="line.371"></a>
-<span class="sourceLineNo">372</span>    LOG.info("testThreeRSAbort");<a name="line.372"></a>
-<span class="sourceLineNo">373</span>    int numRegionsToCreate = 40;<a name="line.373"></a>
-<span class="sourceLineNo">374</span>    int numRowsPerRegion = 100;<a name="line.374"></a>
-<span class="sourceLineNo">375</span><a name="line.375"></a>
-<span class="sourceLineNo">376</span>    startCluster(NUM_RS); // NUM_RS=6.<a name="line.376"></a>
-<span class="sourceLineNo">377</span><a name="line.377"></a>
-<span class="sourceLineNo">378</span>    try (ZKWatcher zkw = new ZKWatcher(conf, "distributed log splitting test", null);<a name="line.378"></a>
-<span class="sourceLineNo">379</span>        Table table = installTable(zkw, numRegionsToCreate)) {<a name="line.379"></a>
-<span class="sourceLineNo">380</span>      populateDataInTable(numRowsPerRegion);<a name="line.380"></a>
-<span class="sourceLineNo">381</span><a name="line.381"></a>
-<span class="sourceLineNo">382</span>      List&lt;RegionServerThread&gt; rsts = cluster.getLiveRegionServerThreads();<a name="line.382"></a>
-<span class="sourceLineNo">383</span>      assertEquals(NUM_RS, rsts.size());<a name="line.383"></a>
-<span class="sourceLineNo">384</span>      cluster.killRegionServer(rsts.get(0).getRegionServer().getServerName());<a name="line.384"></a>
-<span class="sourceLineNo">385</span>      cluster.killRegionServer(rsts.get(1).getRegionServer().getServerName());<a name="line.385"></a>
-<span class="sourceLineNo">386</span>      cluster.killRegionServer(rsts.get(2).getRegionServer().getServerName());<a name="line.386"></a>
-<span class="sourceLineNo">387</span><a name="line.387"></a>
-<span class="sourceLineNo">388</span>      TEST_UTIL.waitFor(60000, new Waiter.ExplainingPredicate&lt;Exception&gt;() {<a name="line.388"></a>
-<span class="sourceLineNo">389</span><a name="line.389"></a>
-<span class="sourceLineNo">390</span>        @Override<a name="line.390"></a>
-<span class="sourceLineNo">391</span>        public boolean evaluate() throws Exception {<a name="line.391"></a>
-<span class="sourceLineNo">392</span>          return cluster.getLiveRegionServerThreads().size() &lt;= NUM_RS - 3;<a name="line.392"></a>
-<span class="sourceLineNo">393</span>        }<a name="line.393"></a>
-<span class="sourceLineNo">394</span><a name="line.394"></a>
-<span class="sourceLineNo">395</span>        @Override<a name="line.395"></a>
-<span class="sourceLineNo">396</span>        public String explainFailure() throws Exception {<a name="line.396"></a>
-<span class="sourceLineNo">397</span>          return "Timed out waiting for server aborts.";<a name="line.397"></a>
-<span class="sourceLineNo">398</span>        }<a name="line.398"></a>
-<span class="sourceLineNo">399</span>      });<a name="line.399"></a>
-<span class="sourceLineNo">400</span>      TEST_UTIL.waitUntilAllRegionsAssigned(tableName);<a name="line.400"></a>
-<span class="sourceLineNo">401</span>      assertEquals(numRegionsToCreate * numRowsPerRegion, TEST_UTIL.countRows(table));<a name="line.401"></a>
-<span class="sourceLineNo">402</span>    }<a name="line.402"></a>
-<span class="sourceLineNo">403</span>  }<a name="line.403"></a>
-<span class="sourceLineNo">404</span><a name="line.404"></a>
-<span class="sourceLineNo">405</span>  @Test<a name="line.405"></a>
-<span class="sourceLineNo">406</span>  public void testDelayedDeleteOnFailure() throws Exception {<a name="line.406"></a>
-<span class="sourceLineNo">407</span>    LOG.info("testDelayedDeleteOnFailure");<a name="line.407"></a>
-<span class="sourceLineNo">408</span>    startCluster(1);<a name="line.408"></a>
-<span class="sourceLineNo">409</span>    final SplitLogManager slm = master.getMasterWalManager().getSplitLogManager();<a name="line.409"></a>
-<span class="sourceLineNo">410</span>    final FileSystem fs = master.getMasterFileSystem().getFileSystem();<a name="line.410"></a>
-<span class="sourceLineNo">411</span>    final Path logDir = new Path(new Path(FSUtils.getRootDir(conf), HConstants.HREGION_LOGDIR_NAME),<a name="line.411"></a>
-<span class="sourceLineNo">412</span>        ServerName.valueOf("x", 1, 1).toString());<a name="line.412"></a>
-<span class="sourceLineNo">413</span>    fs.mkdirs(logDir);<a name="line.413"></a>
-<span class="sourceLineNo">414</span>    ExecutorService executor = null;<a name="line.414"></a>
-<span class="sourceLineNo">415</span>    try {<a name="line.415"></a>
-<span class="sourceLineNo">416</span>      final Path corruptedLogFile = new Path(logDir, "x");<a name="line.416"></a>
-<span class="sourceLineNo">417</span>      FSDataOutputStream out;<a name="line.417"></a>
-<span class="sourceLineNo">418</span>      out = fs.create(corruptedLogFile);<a name="line.418"></a>
-<span class="sourceLineNo">419</span>      out.write(0);<a name="line.419"></a>
-<span class="sourceLineNo">420</span>      out.write(Bytes.toBytes("corrupted bytes"));<a name="line.420"></a>
-<span class="sourceLineNo">421</span>      out.close();<a name="line.421"></a>
-<span class="sourceLineNo">422</span>      ZKSplitLogManagerCoordination coordination =<a name="line.422"></a>
-<span class="sourceLineNo">423</span>          (ZKSplitLogManagerCoordination) (master.getCoordinatedStateManager())<a name="line.423"></a>
-<span class="sourceLineNo">424</span>              .getSplitLogManagerCoordination();<a name="line.424"></a>
-<span class="sourceLineNo">425</span>      coordination.setIgnoreDeleteForTesting(true);<a name="line.425"></a>
-<span class="sourceLineNo">426</span>      executor = Executors.newSingleThreadExecutor();<a name="line.426"></a>
-<span class="sourceLineNo">427</span>      Runnable runnable = new Runnable() {<a name="line.427"></a>
-<span class="sourceLineNo">428</span>        @Override<a name="line.428"></a>
-<span class="sourceLineNo">429</span>        public void run() {<a name="line.429"></a>
-<span class="sourceLineNo">430</span>          try {<a name="line.430"></a>
-<span class="sourceLineNo">431</span>            // since the logDir is a fake, corrupted one, so the split log worker<a name="line.431"></a>
-<span class="sourceLineNo">432</span>            // will finish it quickly with error, and this call will fail and throw<a name="line.432"></a>
-<span class="sourceLineNo">433</span>            // an IOException.<a name="line.433"></a>
-<span class="sourceLineNo">434</span>            slm.splitLogDistributed(logDir);<a name="line.434"></a>
-<span class="sourceLineNo">435</span>          } catch (IOException ioe) {<a name="line.435"></a>
-<span class="sourceLineNo">436</span>            try {<a name="line.436"></a>
-<span class="sourceLineNo">437</span>              assertTrue(fs.exists(corruptedLogFile));<a name="line.437"></a>
-<span class="sourceLineNo">438</span>              // this call will block waiting for the task to be removed from the<a name="line.438"></a>
-<span class="sourceLineNo">439</span>              // tasks map which is not going to happen since ignoreZKDeleteForTesting<a name="line.439"></a>
-<span class="sourceLineNo">440</span>              // is set to true, until it is interrupted.<a name="line.440"></a>
-<span class="sourceLineNo">441</span>              slm.splitLogDistributed(logDir);<a name="line.441"></a>
-<span class="sourceLineNo">442</span>            } catch (IOException e) {<a name="line.442"></a>
-<span class="sourceLineNo">443</span>              assertTrue(Thread.currentThread().isInterrupted());<a name="line.443"></a>
-<span class="sourceLineNo">444</span>              return;<a name="line.444"></a>
-<span class="sourceLineNo">445</span>            }<a name="line.445"></a>
-<span class="sourceLineNo">446</span>            fail("did not get the expected IOException from the 2nd call");<a name="line.446"></a>
-<span class="sourceLineNo">447</span>          }<a name="line.447"></a>
-<span class="sourceLineNo">448</span>          fail("did not get the expected IOException from the 1st call");<a name="line.448"></a>
-<span class="sourceLineNo">449</span>        }<a name="line.449"></a>
-<span class="sourceLineNo">450</span>      };<a name="line.450"></a>
-<span class="sourceLineNo">451</span>      Future&lt;?&gt; result = executor.submit(runnable);<a name="line.451"></a>
-<span class="sourceLineNo">452</span>      try {<a name="line.452"></a>
-<span class="sourceLineNo">453</span>        result.get(2000, TimeUnit.MILLISECONDS);<a name="line.453"></a>
-<span class="sourceLineNo">454</span>      } catch (TimeoutException te) {<a name="line.454"></a>
-<span class="sourceLineNo">455</span>        // it is ok, expected.<a name="line.455"></a>
-<span class="sourceLineNo">456</span>      }<a name="line.456"></a>
-<span class="sourceLineNo">457</span>      waitForCounter(tot_mgr_wait_for_zk_delete, 0, 1, 10000);<a name="line.457"></a>
-<span class="sourceLineNo">458</span>      executor.shutdownNow();<a name="line.458"></a>
-<span class="sourceLineNo">459</span>      executor = null;<a name="line.459"></a>
-<span class="sourceLineNo">460</span><a name="line.460"></a>
-<span class="sourceLineNo">461</span>      // make sure the runnable is finished with no exception thrown.<a name="line.461"></a>
-<span class="sourceLineNo">462</span>      result.get();<a name="line.462"></a>
-<span class="sourceLineNo">463</span>    } finally {<a name="line.463"></a>
-<span class="sourceLineNo">464</span>      if (executor != null) {<a name="line.464"></a>
-<span class="sourceLineNo">465</span>        // interrupt the thread in case the test fails in the middle.<a name="line.465"></a>
-<span class="sourceLineNo">466</span>        // it has no effect if the thread is already terminated.<a name="line.466"></a>
-<span class="sourceLineNo">467</span>        executor.shutdownNow();<a name="line.467"></a>
-<span class="sourceLineNo">468</span>      }<a name="line.468"></a>
-<span class="sourceLineNo">469</span>      fs.delete(logDir, true);<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><a name="line.472"></a>
-<span class="sourceLineNo">473</span>  @Test<a name="line.473"></a>
-<span class="sourceLineNo">474</span>  public void testReadWriteSeqIdFiles() throws Exception {<a name="line.474"></a>
-<span class="sourceLineNo">475</span>    LOG.info("testReadWriteSeqIdFiles");<a name="line.475"></a>
-<span class="sourceLineNo">476</span>    startCluster(2);<a name="line.476"></a>
-<span class="sourceLineNo">477</span>    final ZKWatcher zkw = new ZKWatcher(conf, "table-creation", null);<a name="line.477"></a>
-<span class="sourceLineNo">478</span>    Table ht = installTable(zkw, 10);<a name="line.478"></a>
-<span class="sourceLineNo">479</span>    try {<a name="line.479"></a>
-<span class="sourceLineNo">480</span>      FileSystem fs = master.getMasterFileSystem().getFileSystem();<a name="line.480"></a>
-<span class="sourceLineNo">481</span>      Path tableDir =<a name="line.481"></a>
-<span class="sourceLineNo">482</span>          FSUtils.getTableDir(FSUtils.getRootDir(conf), TableName.valueOf(name.getMethodName()));<a name="line.482"></a>
-<span class="sourceLineNo">483</span>      List&lt;Path&gt; regionDirs = FSUtils.getRegionDirs(fs, tableDir);<a name="line.483"></a>
-<span class="sourceLineNo">484</span>      long newSeqId = WALSplitter.writeRegionSequenceIdFile(fs, regionDirs.get(0), 1L, 1000L);<a name="line.484"></a>
-<span class="sourceLineNo">485</span>      WALSplitter.writeRegionSequenceIdFile(fs, regionDirs.get(0), 1L, 1000L);<a name="line.485"></a>
-<span class="sourceLineNo">486</span>      assertEquals(newSeqId + 2000,<a name="line.486"></a>
-<span class="sourceLineNo">487</span>        WALSplitter.writeRegionSequenceIdFile(fs, regionDirs.get(0), 3L, 1000L));<a name="line.487"></a>
-<span class="sourceLineNo">488</span><a name="line.488"></a>
-<span class="sourceLineNo">489</span>      Path editsdir = WALSplitter.getRegionDirRecoveredEditsDir(regionDirs.get(0));<a name="line.489"></a>
-<span class="sourceLineNo">490</span>      FileStatus[] files = FSUtils.listStatus(fs, editsdir, new PathFilter() {<a name="line.490"></a>
-<span class="sourceLineNo">491</span>        @Override<a name="line.491"></a>
-<span class="sourceLineNo">492</span>        public boolean accept(Path p) {<a name="line.492"></a>
-<span class="sourceLineNo">493</span>          return WALSplitter.isSequenceIdFile(p);<a name="line.493"></a>
-<span class="sourceLineNo">494</span>        }<a name="line.494"></a>
-<span class="sourceLineNo">495</span>      });<a name="line.495"></a>
-<span class="sourceLineNo">496</span>      // only one seqid file should exist<a name="line.496"></a>
-<span class="sourceLineNo">497</span>      assertEquals(1, files.length);<a name="line.497"></a>
-<span class="sourceLineNo">498</span><a name="line.498"></a>
-<span class="sourceLineNo">499</span>      // verify all seqId files aren't treated as recovered.edits files<a name="line.499"></a>
-<span class="sourceLineNo">500</span>      NavigableSet&lt;Path&gt; recoveredEdits =<a name="line.500"></a>
-<span class="sourceLineNo">501</span>          WALSplitter.getSplitEditFilesSorted(fs, regionDirs.get(0));<a name="line.501"></a>
-<span class="sourceLineNo">502</span>      assertEquals(0, recoveredEdits.size());<a name="line.502"></a>
-<span class="sourceLineNo">503</span>    } finally {<a name="line.503"></a>
-<span class="sourceLineNo">504</span>      if (ht != null) ht.close();<a name="line.504"></a>
-<span class="sourceLineNo">505</span>      if (zkw != null) zkw.close();<a name="line.505"></a>
-<span class="sourceLineNo">506</span>    }<a name="line.506"></a>
-<span class="sourceLineNo">507</span>  }<a name="line.507"></a>
-<span class="sourceLineNo">508</span><a name="line.508"></a>
-<span class="sourceLineNo">509</span>  private Table installTable(ZKWatcher zkw, int nrs) throws Exception {<a name="line.509"></a>
-<span class="sourceLineNo">510</span>    return installTable(zkw, nrs, 0);<a name="line.510"></a>
-<span class="sourceLineNo">511</span>  }<a name="line.511"></a>
-<span class="sourceLineNo">512</span><a name="line.512"></a>
-<span class="sourceLineNo">513</span>  private Table installTable(ZKWatcher zkw, int nrs, int existingRegions) throws Exception {<a name="line.513"></a>
-<span class="sourceLineNo">514</span>    // Create a table with regions<a name="line.514"></a>
-<span class="sourceLineNo">515</span>    byte[] family = Bytes.toBytes("family");<a name="line.515"></a>
-<span class="sourceLineNo">516</span>    LOG.info("Creating table with " + nrs + " regions");<a name="line.516"></a>
-<span class="sourceLineNo">517</span>    Table table = TEST_UTIL.createMultiRegionTable(tableName, family, nrs);<a name="line.517"></a>
-<span class="sourceLineNo">518</span>    int numRegions = -1;<a name="line.518"></a>
-<span class="sourceLineNo">519</span>    try (RegionLocator r = TEST_UTIL.getConnection().getRegionLocator(tableName)) {<a name="line.519"></a>
-<span class="sourceLineNo">520</span>      numRegions = r.getStartKeys().length;<a name="line.520"></a>
-<span class="sourceLineNo">521</span>    }<a name="line.521"></a>
-<span class="sourceLineNo">522</span>    assertEquals(nrs, numRegions);<a name="line.522"></a>
-<span class="sourceLineNo">523</span>    LOG.info("Waiting for no more RIT\n");<a name="line.523"></a>
-<span class="sourceLineNo">524</span>    blockUntilNoRIT(zkw, master);<a name="line.524"></a>
-<span class="sourceLineNo">525</span>    // disable-enable cycle to get rid of table's dead regions left behind<a name="line.525"></a>
-<span class="sourceLineNo">526</span>    // by createMultiRegions<a name="line.526"></a>
-<span class="sourceLineNo">527</span>    LOG.debug("Disabling table\n");<a name="line.527"></a>
-<span class="sourceLineNo">528</span>    TEST_UTIL.getAdmin().disableTable(tableName);<a name="line.528"></a>
-<span class="sourceLineNo">529</span>    LOG.debug("Waiting for no more RIT\n");<a name="line.529"></a>
-<span class="sourceLineNo">530</span>    blockUntilNoRIT(zkw, master);<a name="line.530"></a>
-<span class="sourceLineNo">531</span>    NavigableSet&lt;String&gt; regions = HBaseTestingUtility.getAllOnlineRegions(cluster);<a name="line.531"></a>
-<span class="sourceLineNo">532</span>    LOG.debug("Verifying only catalog and namespace regions are assigned\n");<a name="line.532"></a>
-<span class="sourceLineNo">533</span>    if (regions.size() != 2) {<a name="line.533"></a>
-<span class="sourceLineNo">534</span>      for (String oregion : regions)<a name="line.534"></a>
-<span class="sourceLineNo">535</span>        LOG.debug("Region still online: " + oregion);<a name="line.535"></a>
-<span class="sourceLineNo">536</span>    }<a name="line.536"></a>
-<span class="sourceLineNo">537</span>    assertEquals(2 + existingRegions, regions.size());<a name="line.537"></a>
-<span class="sourceLineNo">538</span>    LOG.debug("Enabling table\n");<a name="line.538"></a>
-<span class="sourceLineNo">539</span>    TEST_UTIL.getAdmin().enableTable(tableName);<a name="line.539"></a>
-<span class="sourceLineNo">540</span>    LOG.debug("Waiting for no more RIT\n");<a name="line.540"></a>
-<span class="sourceLineNo">541</span>    blockUntilNoRIT(zkw, master);<a name="line.541"></a>
-<span class="sourceLineNo">542</span>    LOG.debug("Verifying there are " + numRegions + " assigned on cluster\n");<a name="line.542"></a>
-<span class="sourceLineNo">543</span>    regions = HBaseTestingUtility.getAllOnlineRegions(cluster);<a name="line.543"></a>
-<span class="sourceLineNo">544</span>    assertEquals(numRegions + 2 + existingRegions, regions.size());<a name="line.544"></a>
-<span class="sourceLineNo">545</span>    return table;<a name="line.545"></a>
-<span class="sourceLineNo">546</span>  }<a name="line.546"></a>
-<span class="sourceLineNo">547</span><a name="line.547"></a>
-<span class="sourceLineNo">548</span>  void populateDataInTable(int nrows) throws Exception {<a name="line.548"></a>
-<span class="sourceLineNo">549</span>    List&lt;RegionServerThread&gt; rsts = cluster.getLiveRegionServerThreads();<a name="line.549"></a>
-<span class="sourceLineNo">550</span>    assertEquals(NUM_RS, rsts.size());<a name="line.550"></a>
-<span class="sourceLineNo">551</span><a name="line.551"></a>
-<span class="sourceLineNo">552</span>    for (RegionServerThread rst : rsts) {<a name="line.552"></a>
-<span class="sourceLineNo">553</span>      HRegionServer hrs = rst.getRegionServer();<a name="line.553"></a>
-<span class="sourceLineNo">554</span>      List&lt;RegionInfo&gt; hris = ProtobufUtil.getOnlineRegions(hrs.getRSRpcServices());<a name="line.554"></a>
-<span class="sourceLineNo">555</span>      for (RegionInfo hri : hris) {<a name="line.555"></a>
-<span class="sourceLineNo">556</span>        if (hri.getTable().isSystemTable()) {<a name="line.556"></a>
-<span class="sourceLineNo">557</span>          continue;<a name="line.557"></a>
-<span class="sourceLineNo">558</span>        }<a name="line.558"></a>
-<span class="sourceLineNo">559</span>        LOG.debug(<a name="line.559"></a>
-<span class="sourceLineNo">560</span>          "adding data to rs = " + rst.getName() + " region = " + hri.getRegionNameAsString());<a name="line.560"></a>
-<span class="sourceLineNo">561</span>        Region region = hrs.getOnlineRegion(hri.getRegionName());<a name="line.561"></a>
-<span class="sourceLineNo">562</span>        assertTrue(region != null);<a name="line.562"></a>
-<span class="sourceLineNo">563</span>        putData(region, hri.getStartKey(), nrows, Bytes.toBytes("q"), COLUMN_FAMILY);<a name="line.563"></a>
-<span class="sourceLineNo">564</span>      }<a name="line.564"></a>
-<span class="sourceLineNo">565</span>    }<a name="line.565"></a>
-<span class="sourceLineNo">566</span><a name="line.566"></a>
-<span class="sourceLineNo">567</span>    for (MasterThread mt : cluster.getLiveMasterThreads()) {<a name="line.567"></a>
-<span class="sourceLineNo">568</span>      HRegionServer hrs = mt.getMaster();<a name="line.568"></a>
-<span class="sourceLineNo">569</span>      List&lt;RegionInfo&gt; hris;<a name="line.569"></a>
-<span class="sourceLineNo">570</span>      try {<a name="line.570"></a>
-<span class="sourceLineNo">571</span>        hris = ProtobufUtil.getOnlineRegions(hrs.getRSRpcServices());<a name="line.571"></a>
-<span class="sourceLineNo">572</span>      } catch (ServerNotRunningYetException e) {<a name="line.572"></a>
-<span class="sourceLineNo">573</span>        // It's ok: this master may be a backup. Ignored.<a name="line.573"></a>
-<span class="sourceLineNo">574</span>        continue;<a name="line.574"></a>
-<span class="sourceLineNo">575</span>      }<a name="line.575"></a>
-<span class="sourceLineNo">576</span>      for (RegionInfo hri : hris) {<a name="line.576"></a>
-<span class="sourceLineNo">577</span>        if (hri.getTable().isSystemTable()) {<a name="line.577"></a>
-<span class="sourceLineNo">578</span>          continue;<a name="line.578"></a>
-<span class="sourceLineNo">579</span>        }<a name="line.579"></a>
-<span class="sourceLineNo">580</span>        LOG.debug(<a name="line.580"></a>
-<span class="sourceLineNo">581</span>          "adding data to rs = " + mt.getName() + " region = " + hri.getRegionNameAsString());<a name="line.581"></a>
-<span class="sourceLineNo">582</span>        Region region = hrs.getOnlineRegion(hri.getRegionName());<a name="line.582"></a>
-<span class="sourceLineNo">583</span>        assertTrue(region != null);<a name="line.583"></a>
-<span class="sourceLineNo">584</span>        putData(region, hri.getStartKey(), nrows, Bytes.toBytes("q"), COLUMN_FAMILY);<a name="line.584"></a>
-<span class="sourceLineNo">585</span>      }<a name="line.585"></a>
-<span class="sourceLineNo">586</span>    }<a name="line.586"></a>
-<span class="sourceLineNo">587</span>  }<a name="line.587"></a>
-<span class="sourceLineNo">588</span><a name="line.588"></a>
-<span class="sourceLineNo">589</span>  public void makeWAL(HRegionServer hrs, List&lt;RegionInfo&gt; regions, int num_edits, int edit_size)<a name="line.589"></a>
-<span class="sourceLineNo">590</span>      throws IOException {<a name="line.590"></a>
-<span class="sourceLineNo">591</span>    makeWAL(hrs, regions, num_edits, edit_size, true);<a name="line.591"></a>
-<span class="sourceLineNo">592</span>  }<a name="line.592"></a>
-<span class="sourceLineNo">593</span><a name="line.593"></a>
-<span class="sourceLineNo">594</span>  public void makeWAL(HRegionServer hrs, List&lt;RegionInfo&gt; regions, int numEdits, int editSize,<a name="line.594"></a>
-<span class="sourceLineNo">595</span>      boolean cleanShutdown) throws IOException {<a name="line.595"></a>
-<span class="sourceLineNo">596</span>    // remove root and meta region<a name="line.596"></a>
-<span class="sourceLineNo">597</span>    regions.remove(RegionInfoBuilder.FIRST_META_REGIONINFO);<a name="line.597"></a>
-<span class="sourceLineNo">598</span><a name="line.598"></a>
-<span class="sourceLineNo">599</span>    for (Iterator&lt;RegionInfo&gt; iter = regions.iterator(); iter.hasNext();) {<a name="line.599"></a>
-<span class="sourceLineNo">600</span>      RegionInfo regionInfo = iter.next();<a name="line.600"></a>
-<span class="sourceLineNo">601</span>      if (regionInfo.getTable().isSystemTable()) {<a name="line.601"></a>
-<span class="sourceLineNo">602</span>        iter.remove();<a name="line.602"></a>
-<span class="sourceLineNo">603</span>      }<a name="line.603"></a>
-<span class="sourceLineNo">604</span>    }<a name="line.604"></a>
-<span class="sourceLineNo">605</span>    byte[] value = new byte[editSize];<a name="line.605"></a>
+<span class="sourceLineNo">095</span><a name="line.95"></a>
+<span class="sourceLineNo">096</span>import org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil;<a name="line.96"></a>
+<span class="sourceLineNo">097</span><a name="line.97"></a>
+<span class="sourceLineNo">098</span>/**<a name="line.98"></a>
+<span class="sourceLineNo">099</span> * Base class for testing distributed log splitting.<a name="line.99"></a>
+<span class="sourceLineNo">100</span> */<a name="line.100"></a>
+<span class="sourceLineNo">101</span>public abstract class AbstractTestDLS {<a name="line.101"></a>
+<span class="sourceLineNo">102</span>  private static final Logger LOG = LoggerFactory.getLogger(TestSplitLogManager.class);<a name="line.102"></a>
+<span class="sourceLineNo">103</span><a name="line.103"></a>
+<span class="sourceLineNo">104</span>  private static final HBaseTestingUtility TEST_UTIL = new HBaseTestingUtility();<a name="line.104"></a>
+<span class="sourceLineNo">105</span><a name="line.105"></a>
+<span class="sourceLineNo">106</span>  // Start a cluster with 2 masters and 5 regionservers<a name="line.106"></a>
+<span class="sourceLineNo">107</span>  private static final int NUM_MASTERS = 2;<a name="line.107"></a>
+<span class="sourceLineNo">108</span>  private static final int NUM_RS = 5;<a name="line.108"></a>
+<span class="sourceLineNo">109</span>  private static byte[] COLUMN_FAMILY = Bytes.toBytes("family");<a name="line.109"></a>
+<span class="sourceLineNo">110</span><a name="line.110"></a>
+<span class="sourceLineNo">111</span>  @Rule<a name="line.111"></a>
+<span class="sourceLineNo">112</span>  public TestName testName = new TestName();<a name="line.112"></a>
+<span class="sourceLineNo">113</span><a name="line.113"></a>
+<span class="sourceLineNo">114</span>  private TableName tableName;<a name="line.114"></a>
+<span class="sourceLineNo">115</span>  private MiniHBaseCluster cluster;<a name="line.115"></a>
+<span class="sourceLineNo">116</span>  private HMaster master;<a name="line.116"></a>
+<span class="sourceLineNo">117</span>  private Configuration conf;<a name="line.117"></a>
+<span class="sourceLineNo">118</span><a name="line.118"></a>
+<span class="sourceLineNo">119</span>  @Rule<a name="line.119"></a>
+<span class="sourceLineNo">120</span>  public TestName name = new TestName();<a name="line.120"></a>
+<span class="sourceLineNo">121</span><a name="line.121"></a>
+<span class="sourceLineNo">122</span>  @BeforeClass<a name="line.122"></a>
+<span class="sourceLineNo">123</span>  public static void setup() throws Exception {<a name="line.123"></a>
+<span class="sourceLineNo">124</span>    // Uncomment the following line if more verbosity is needed for<a name="line.124"></a>
+<span class="sourceLineNo">125</span>    // debugging (see HBASE-12285 for details).<a name="line.125"></a>
+<span class="sourceLineNo">126</span>    // Logger.getLogger("org.apache.hadoop.hbase").setLevel(Level.DEBUG);<a name="line.126"></a>
+<span class="sourceLineNo">127</span>    TEST_UTIL.startMiniZKCluster();<a name="line.127"></a>
+<span class="sourceLineNo">128</span>    TEST_UTIL.startMiniDFSCluster(3);<a name="line.128"></a>
+<span class="sourceLineNo">129</span>  }<a name="line.129"></a>
+<span class="sourceLineNo">130</span><a name="line.130"></a>
+<span class="sourceLineNo">131</span>  @AfterClass<a name="line.131"></a>
+<span class="sourceLineNo">132</span>  public static void tearDown() throws Exception {<a name="line.132"></a>
+<span class="sourceLineNo">133</span>    TEST_UTIL.shutdownMiniCluster();<a name="line.133"></a>
+<span class="sourceLineNo">134</span>  }<a name="line.134"></a>
+<span class="sourceLineNo">135</span><a name="line.135"></a>
+<span class="sourceLineNo">136</span>  protected abstract String getWalProvider();<a name="line.136"></a>
+<span class="sourceLineNo">137</span><a name="line.137"></a>
+<span class="sourceLineNo">138</span>  private void startCluster(int numRS) throws Exception {<a name="line.138"></a>
+<span class="sourceLineNo">139</span>    SplitLogCounters.resetCounters();<a name="line.139"></a>
+<span class="sourceLineNo">140</span>    LOG.info("Starting cluster");<a name="line.140"></a>
+<span class="sourceLineNo">141</span>    conf.setLong("hbase.splitlog.max.resubmit", 0);<a name="line.141"></a>
+<span class="sourceLineNo">142</span>    // Make the failure test faster<a name="line.142"></a>
+<span class="sourceLineNo">143</span>    conf.setInt("zookeeper.recovery.retry", 0);<a name="line.143"></a>
+<span class="sourceLineNo">144</span>    conf.setInt(HConstants.REGIONSERVER_INFO_PORT, -1);<a name="line.144"></a>
+<span class="sourceLineNo">145</span>    conf.setFloat(HConstants.LOAD_BALANCER_SLOP_KEY, (float) 100.0); // no load balancing<a name="line.145"></a>
+<span class="sourceLineNo">146</span>    conf.setInt("hbase.regionserver.wal.max.splitters", 3);<a name="line.146"></a>
+<span class="sourceLineNo">147</span>    conf.setInt(HConstants.REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT, 10);<a name="line.147"></a>
+<span class="sourceLineNo">148</span>    conf.set("hbase.wal.provider", getWalProvider());<a name="line.148"></a>
+<span class="sourceLineNo">149</span>    TEST_UTIL.startMiniHBaseCluster(NUM_MASTERS, numRS);<a name="line.149"></a>
+<span class="sourceLineNo">150</span>    cluster = TEST_UTIL.getHBaseCluster();<a name="line.150"></a>
+<span class="sourceLineNo">151</span>    LOG.info("Waiting for active/ready master");<a name="line.151"></a>
+<span class="sourceLineNo">152</span>    cluster.waitForActiveAndReadyMaster();<a name="line.152"></a>
+<span class="sourceLineNo">153</span>    master = cluster.getMaster();<a name="line.153"></a>
+<span class="sourceLineNo">154</span>    TEST_UTIL.waitFor(120000, 200, new Waiter.Predicate&lt;Exception&gt;() {<a name="line.154"></a>
+<span class="sourceLineNo">155</span>      @Override<a name="line.155"></a>
+<span class="sourceLineNo">156</span>      public boolean evaluate() throws Exception {<a name="line.156"></a>
+<span class="sourceLineNo">157</span>        return cluster.getLiveRegionServerThreads().size() &gt;= numRS;<a name="line.157"></a>
+<span class="sourceLineNo">158</span>      }<a name="line.158"></a>
+<span class="sourceLineNo">159</span>    });<a name="line.159"></a>
+<span class="sourceLineNo">160</span>  }<a name="line.160"></a>
+<span class="sourceLineNo">161</span><a name="line.161"></a>
+<span class="sourceLineNo">162</span>  @Before<a name="line.162"></a>
+<span class="sourceLineNo">163</span>  public void before() throws Exception {<a name="line.163"></a>
+<span class="sourceLineNo">164</span>    conf = TEST_UTIL.getConfiguration();<a name="line.164"></a>
+<span class="sourceLineNo">165</span>    tableName = TableName.valueOf(testName.getMethodName());<a name="line.165"></a>
+<span class="sourceLineNo">166</span>  }<a name="line.166"></a>
+<span class="sourceLineNo">167</span><a name="line.167"></a>
+<span class="sourceLineNo">168</span>  @After<a name="line.168"></a>
+<span class="sourceLineNo">169</span>  public void after() throws Exception {<a name="line.169"></a>
+<span class="sourceLineNo">170</span>    TEST_UTIL.shutdownMiniHBaseCluster();<a name="line.170"></a>
+<span class="sourceLineNo">171</span>    TEST_UTIL.getTestFileSystem().delete(FSUtils.getRootDir(TEST_UTIL.getConfiguration()), true);<a name="line.171"></a>
+<span class="sourceLineNo">172</span>    ZKUtil.deleteNodeRecursively(TEST_UTIL.getZooKeeperWatcher(), "/hbase");<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>  @Test<a name="line.175"></a>
+<span class="sourceLineNo">176</span>  public void testRecoveredEdits() throws Exception {<a name="line.176"></a>
+<span class="sourceLineNo">177</span>    conf.setLong("hbase.regionserver.hlog.blocksize", 30 * 1024); // create more than one wal<a name="line.177"></a>
+<span class="sourceLineNo">178</span>    startCluster(NUM_RS);<a name="line.178"></a>
+<span class="sourceLineNo">179</span><a name="line.179"></a>
+<span class="sourceLineNo">180</span>    int numLogLines = 10000;<a name="line.180"></a>
+<span class="sourceLineNo">181</span>    SplitLogManager slm = master.getMasterWalManager().getSplitLogManager();<a name="line.181"></a>
+<span class="sourceLineNo">182</span>    // turn off load balancing to prevent regions from moving around otherwise<a name="line.182"></a>
+<span class="sourceLineNo">183</span>    // they will consume recovered.edits<a name="line.183"></a>
+<span class="sourceLineNo">184</span>    master.balanceSwitch(false);<a name="line.184"></a>
+<span class="sourceLineNo">185</span>    FileSystem fs = master.getMasterFileSystem().getFileSystem();<a name="line.185"></a>
+<span class="sourceLineNo">186</span><a name="line.186"></a>
+<span class="sourceLineNo">187</span>    List&lt;RegionServerThread&gt; rsts = cluster.getLiveRegionServerThreads();<a name="line.187"></a>
+<span class="sourceLineNo">188</span><a name="line.188"></a>
+<span class="sourceLineNo">189</span>    Path rootdir = FSUtils.getRootDir(conf);<a name="line.189"></a>
+<span class="sourceLineNo">190</span><a name="line.190"></a>
+<span class="sourceLineNo">191</span>    int numRegions = 50;<a name="line.191"></a>
+<span class="sourceLineNo">192</span>    try (ZKWatcher zkw = new ZKWatcher(conf, "table-creation", null);<a name="line.192"></a>
+<span class="sourceLineNo">193</span>        Table t = installTable(zkw, numRegions)) {<a name="line.193"></a>
+<span class="sourceLineNo">194</span>      TableName table = t.getName();<a name="line.194"></a>
+<span class="sourceLineNo">195</span>      List&lt;RegionInfo&gt; regions = null;<a name="line.195"></a>
+<span class="sourceLineNo">196</span>      HRegionServer hrs = null;<a name="line.196"></a>
+<span class="sourceLineNo">197</span>      for (int i = 0; i &lt; NUM_RS; i++) {<a name="line.197"></a>
+<span class="sourceLineNo">198</span>        hrs = rsts.get(i).getRegionServer();<a name="line.198"></a>
+<span class="sourceLineNo">199</span>        regions = ProtobufUtil.getOnlineRegions(hrs.getRSRpcServices());<a name="line.199"></a>
+<span class="sourceLineNo">200</span>        // At least one RS will have &gt;= to average number of regions.<a name="line.200"></a>
+<span class="sourceLineNo">201</span>        if (regions.size() &gt;= numRegions / NUM_RS) {<a name="line.201"></a>
+<span class="sourceLineNo">202</span>          break;<a name="line.202"></a>
+<span class="sourceLineNo">203</span>        }<a name="line.203"></a>
+<span class="sourceLineNo">204</span>      }<a name="line.204"></a>
+<span class="sourceLineNo">205</span>      Path logDir = new Path(rootdir,<a name="line.205"></a>
+<span class="sourceLineNo">206</span>          AbstractFSWALProvider.getWALDirectoryName(hrs.getServerName().toString()));<a name="line.206"></a>
+<span class="sourceLineNo">207</span><a name="line.207"></a>
+<span class="sourceLineNo">208</span>      LOG.info("#regions = " + regions.size());<a name="line.208"></a>
+<span class="sourceLineNo">209</span>      Iterator&lt;RegionInfo&gt; it = regions.iterator();<a name="line.209"></a>
+<span class="sourceLineNo">210</span>      while (it.hasNext()) {<a name="line.210"></a>
+<span class="sourceLineNo">211</span>        RegionInfo region = it.next();<a name="line.211"></a>
+<span class="sourceLineNo">212</span>        if (region.getTable().getNamespaceAsString()<a name="line.212"></a>
+<span class="sourceLineNo">213</span>            .equals(NamespaceDescriptor.SYSTEM_NAMESPACE_NAME_STR)) {<a name="line.213"></a>
+<span class="sourceLineNo">214</span>          it.remove();<a name="line.214"></a>
+<span class="sourceLineNo">215</span>        }<a name="line.215"></a>
+<span class="sourceLineNo">216</span>      }<a name="line.216"></a>
+<span class="sourceLineNo">217</span><a name="line.217"></a>
+<span class="sourceLineNo">218</span>      makeWAL(hrs, regions, numLogLines, 100);<a name="line.218"></a>
+<span class="sourceLineNo">219</span><a name="line.219"></a>
+<span class="sourceLineNo">220</span>      slm.splitLogDistributed(logDir);<a name="line.220"></a>
+<span class="sourceLineNo">221</span><a name="line.221"></a>
+<span class="sourceLineNo">222</span>      int count = 0;<a name="line.222"></a>
+<span class="sourceLineNo">223</span>      for (RegionInfo hri : regions) {<a name="line.223"></a>
+<span class="sourceLineNo">224</span>        Path tdir = FSUtils.getTableDir(rootdir, table);<a name="line.224"></a>
+<span class="sourceLineNo">225</span>        @SuppressWarnings("deprecation")<a name="line.225"></a>
+<span class="sourceLineNo">226</span>        Path editsdir = WALSplitter<a name="line.226"></a>
+<span class="sourceLineNo">227</span>            .getRegionDirRecoveredEditsDir(HRegion.getRegionDir(tdir, hri.getEncodedName()));<a name="line.227"></a>
+<span class="sourceLineNo">228</span>        LOG.debug("checking edits dir " + editsdir);<a name="line.228"></a>
+<span class="sourceLineNo">229</span>        FileStatus[] files = fs.listStatus(editsdir, new PathFilter() {<a name="line.229"></a>
+<span class="sourceLineNo">230</span>          @Override<a name="line.230"></a>
+<span class="sourceLineNo">231</span>          public boolean accept(Path p) {<a name="line.231"></a>
+<span class="sourceLineNo">232</span>            if (WALSplitter.isSequenceIdFile(p)) {<a name="line.232"></a>
+<span class="sourceLineNo">233</span>              return false;<a name="line.233"></a>
+<span class="sourceLineNo">234</span>            }<a name="line.234"></a>
+<span class="sourceLineNo">235</span>            return true;<a name="line.235"></a>
+<span class="sourceLineNo">236</span>          }<a name="line.236"></a>
+<span class="sourceLineNo">237</span>        });<a name="line.237"></a>
+<span class="sourceLineNo">238</span>        assertTrue(<a name="line.238"></a>
+<span class="sourceLineNo">239</span>          "edits dir should have more than a single file in it. instead has " + files.length,<a name="line.239"></a>
+<span class="sourceLineNo">240</span>          files.length &gt; 1);<a name="line.240"></a>
+<span class="sourceLineNo">241</span>        for (int i = 0; i &lt; files.length; i++) {<a name="line.241"></a>
+<span class="sourceLineNo">242</span>          int c = countWAL(files[i].getPath(), fs, conf);<a name="line.242"></a>
+<span class="sourceLineNo">243</span>          count += c;<a name="line.243"></a>
+<span class="sourceLineNo">244</span>        }<a name="line.244"></a>
+<span class="sourceLineNo">245</span>        LOG.info(count + " edits in " + files.length + " recovered edits files.");<a name="line.245"></a>
+<span class="sourceLineNo">246</span>      }<a name="line.246"></a>
+<span class="sourceLineNo">247</span><a name="line.247"></a>
+<span class="sourceLineNo">248</span>      // check that the log file is moved<a name="line.248"></a>
+<span class="sourceLineNo">249</span>      assertFalse(fs.exists(logDir));<a name="line.249"></a>
+<span class="sourceLineNo">250</span>      assertEquals(numLogLines, count);<a name="line.250"></a>
+<span class="sourceLineNo">251</span>    }<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>  @Test<a name="line.254"></a>
+<span class="sourceLineNo">255</span>  public void testMasterStartsUpWithLogSplittingWork() throws Exception {<a name="line.255"></a>
+<span class="sourceLineNo">256</span>    conf.setInt(ServerManager.WAIT_ON_REGIONSERVERS_MINTOSTART, NUM_RS - 1);<a name="line.256"></a>
+<span class="sourceLineNo">257</span>    startCluster(NUM_RS);<a name="line.257"></a>
+<span class="sourceLineNo">258</span><a name="line.258"></a>
+<span class="sourceLineNo">259</span>    int numRegionsToCreate = 40;<a name="line.259"></a>
+<span class="sourceLineNo">260</span>    int numLogLines = 1000;<a name="line.260"></a>
+<span class="sourceLineNo">261</span>    // turn off load balancing to prevent regions from moving around otherwise<a name="line.261"></a>
+<span class="sourceLineNo">262</span>    // they will consume recovered.edits<a name="line.262"></a>
+<span class="sourceLineNo">263</span>    master.balanceSwitch(false);<a name="line.263"></a>
+<span class="sourceLineNo">264</span><a name="line.264"></a>
+<span class="sourceLineNo">265</span>    try (ZKWatcher zkw = new ZKWatcher(conf, "table-creation", null);<a name="line.265"></a>
+<span class="sourceLineNo">266</span>        Table ht = installTable(zkw, numRegionsToCreate)) {<a name="line.266"></a>
+<span class="sourceLineNo">267</span>      HRegionServer hrs = findRSToKill(false);<a name="line.267"></a>
+<span class="sourceLineNo">268</span>      List&lt;RegionInfo&gt; regions = ProtobufUtil.getOnlineRegions(hrs.getRSRpcServices());<a name="line.268"></a>
+<span class="sourceLineNo">269</span>      makeWAL(hrs, regions, numLogLines, 100);<a name="line.269"></a>
+<span class="sourceLineNo">270</span><a name="line.270"></a>
+<span class="sourceLineNo">271</span>      // abort master<a name="line.271"></a>
+<span class="sourceLineNo">272</span>      abortMaster(cluster);<a name="line.272"></a>
+<span class="sourceLineNo">273</span><a name="line.273"></a>
+<span class="sourceLineNo">274</span>      // abort RS<a name="line.274"></a>
+<span class="sourceLineNo">275</span>      LOG.info("Aborting region server: " + hrs.getServerName());<a name="line.275"></a>
+<span class="sourceLineNo">276</span>      hrs.abort("testing");<a name="line.276"></a>
+<span class="sourceLineNo">277</span><a name="line.277"></a>
+<span class="sourceLineNo">278</span>      // wait for abort completes<a name="line.278"></a>
+<span class="sourceLineNo">279</span>      TEST_UTIL.waitFor(120000, 200, new Waiter.Predicate&lt;Exception&gt;() {<a name="line.279"></a>
+<span class="sourceLineNo">280</span>        @Override<a name="line.280"></a>
+<span class="sourceLineNo">281</span>        public boolean evaluate() throws Exception {<a name="line.281"></a>
+<span class="sourceLineNo">282</span>          return cluster.getLiveRegionServerThreads().size() &lt;= NUM_RS - 1;<a name="line.282"></a>
+<span class="sourceLineNo">283</span>        }<a name="line.283"></a>
+<span class="sourceLineNo">284</span>      });<a name="line.284"></a>
+<span class="sourceLineNo">285</span><a name="line.285"></a>
+<span class="sourceLineNo">286</span>      Thread.sleep(2000);<a name="line.286"></a>
+<span class="sourceLineNo">287</span>      LOG.info("Current Open Regions:" + HBaseTestingUtility.getAllOnlineRegions(cluster).size());<a name="line.287"></a>
+<span class="sourceLineNo">288</span><a name="line.288"></a>
+<span class="sourceLineNo">289</span>      // wait for abort completes<a name="line.289"></a>
+<span class="sourceLineNo">290</span>      TEST_UTIL.waitFor(120000, 200, new Waiter.Predicate&lt;Exception&gt;() {<a name="line.290"></a>
+<span class="sourceLineNo">291</span>        @Override<a name="line.291"></a>
+<span class="sourceLineNo">292</span>        public boolean evaluate() throws Exception {<a name="line.292"></a>
+<span class="sourceLineNo">293</span>          return (HBaseTestingUtility.getAllOnlineRegions(cluster)<a name="line.293"></a>
+<span class="sourceLineNo">294</span>              .size() &gt;= (numRegionsToCreate + 1));<a name="line.294"></a>
+<span class="sourceLineNo">295</span>        }<a name="line.295"></a>
+<span class="sourceLineNo">296</span>      });<a name="line.296"></a>
+<span class="sourceLineNo">297</span><a name="line.297"></a>
+<span class="sourceLineNo">298</span>      LOG.info("Current Open Regions After Master Node Starts Up:" +<a name="line.298"></a>
+<span class="sourceLineNo">299</span>          HBaseTestingUtility.getAllOnlineRegions(cluster).size());<a name="line.299"></a>
+<span class="sourceLineNo">300</span><a name="line.300"></a>
+<span class="sourceLineNo">301</span>      assertEquals(numLogLines, TEST_UTIL.countRows(ht));<a name="line.301"></a>
+<span class="sourceLineNo">302</span>    }<a name="line.302"></a>
+<span class="sourceLineNo">303</span>  }<a name="line.303"></a>
+<span class="sourceLineNo">304</span><a name="line.304"></a>
+<span class="sourceLineNo">305</span>  /**<a name="line.305"></a>
+<span class="sourceLineNo">306</span>   * The original intention of this test was to force an abort of a region server and to make sure<a name="line.306"></a>
+<span class="sourceLineNo">307</span>   * that the failure path in the region servers is properly evaluated. But it is difficult to<a name="line.307"></a>
+<span class="sourceLineNo">308</span>   * ensure that the region server doesn't finish the log splitting before it aborts. Also now,<a name="line.308"></a>
+<span class="sourceLineNo">309</span>   * there is this code path where the master will preempt the region server when master detects<a name="line.309"></a>
+<span class="sourceLineNo">310</span>   * that the region server has aborted.<a name="line.310"></a>
+<span class="sourceLineNo">311</span>   * @throws Exception<a name="line.311"></a>
+<span class="sourceLineNo">312</span>   */<a name="line.312"></a>
+<span class="sourceLineNo">313</span>  // Was marked flaky before Distributed Log Replay cleanup.<a name="line.313"></a>
+<span class="sourceLineNo">314</span>  @Test<a name="line.314"></a>
+<span class="sourceLineNo">315</span>  public void testWorkerAbort() throws Exception {<a name="line.315"></a>
+<span class="sourceLineNo">316</span>    LOG.info("testWorkerAbort");<a name="line.316"></a>
+<span class="sourceLineNo">317</span>    startCluster(3);<a name="line.317"></a>
+<span class="sourceLineNo">318</span>    int numLogLines = 10000;<a name="line.318"></a>
+<span class="sourceLineNo">319</span>    SplitLogManager slm = master.getMasterWalManager().getSplitLogManager();<a name="line.319"></a>
+<span class="sourceLineNo">320</span>    FileSystem fs = master.getMasterFileSystem().getFileSystem();<a name="line.320"></a>
+<span class="sourceLineNo">321</span><a name="line.321"></a>
+<span class="sourceLineNo">322</span>    List&lt;RegionServerThread&gt; rsts = cluster.getLiveRegionServerThreads();<a name="line.322"></a>
+<span class="sourceLineNo">323</span>    HRegionServer hrs = findRSToKill(false);<a name="line.323"></a>
+<span class="sourceLineNo">324</span>    Path rootdir = FSUtils.getRootDir(conf);<a name="line.324"></a>
+<span class="sourceLineNo">325</span>    final Path logDir = new Path(rootdir,<a name="line.325"></a>
+<span class="sourceLineNo">326</span>        AbstractFSWALProvider.getWALDirectoryName(hrs.getServerName().toString()));<a name="line.326"></a>
+<span class="sourceLineNo">327</span><a name="line.327"></a>
+<span class="sourceLineNo">328</span>    try (ZKWatcher zkw = new ZKWatcher(conf, "table-creation", null);<a name="line.328"></a>
+<span class="sourceLineNo">329</span>        Table t = installTable(zkw, 40)) {<a name="line.329"></a>
+<span class="sourceLineNo">330</span>      makeWAL(hrs, ProtobufUtil.getOnlineRegions(hrs.getRSRpcServices()), numLogLines, 100);<a name="line.330"></a>
+<span class="sourceLineNo">331</span><a name="line.331"></a>
+<span class="sourceLineNo">332</span>      new Thread() {<a name="line.332"></a>
+<span class="sourceLineNo">333</span>        @Override<a name="line.333"></a>
+<span class="sourceLineNo">334</span>        public void run() {<a name="line.334"></a>
+<span class="sourceLineNo">335</span>          try {<a name="line.335"></a>
+<span class="sourceLineNo">336</span>            waitForCounter(tot_wkr_task_acquired, 0, 1, 1000);<a name="line.336"></a>
+<span class="sourceLineNo">337</span>          } catch (InterruptedException e) {<a name="line.337"></a>
+<span class="sourceLineNo">338</span>          }<a name="line.338"></a>
+<span class="sourceLineNo">339</span>          for (RegionServerThread rst : rsts) {<a name="line.339"></a>
+<span class="sourceLineNo">340</span>            rst.getRegionServer().abort("testing");<a name="line.340"></a>
+<span class="sourceLineNo">341</span>            break;<a name="line.341"></a>
+<span class="sourceLineNo">342</span>          }<a name="line.342"></a>
+<span class="sourceLineNo">343</span>        }<a name="line.343"></a>
+<span class="sourceLineNo">344</span>      }.start();<a name="line.344"></a>
+<span class="sourceLineNo">345</span>      FileStatus[] logfiles = fs.listStatus(logDir);<a name="line.345"></a>
+<span class="sourceLineNo">346</span>      TaskBatch batch = new TaskBatch();<a name="line.346"></a>
+<span class="sourceLineNo">347</span>      slm.enqueueSplitTask(logfiles[0].getPath().toString(), batch);<a name="line.347"></a>
+<span class="sourceLineNo">348</span>      // waitForCounter but for one of the 2 counters<a name="line.348"></a>
+<span class="sourceLineNo">349</span>      long curt = System.currentTimeMillis();<a name="line.349"></a>
+<span class="sourceLineNo">350</span>      long waitTime = 80000;<a name="line.350"></a>
+<span class="sourceLineNo">351</span>      long endt = curt + waitTime;<a name="line.351"></a>
+<span class="sourceLineNo">352</span>      while (curt &lt; endt) {<a name="line.352"></a>
+<span class="sourceLineNo">353</span>        if ((tot_wkr_task_resigned.sum() + tot_wkr_task_err.sum() +<a name="line.353"></a>
+<span class="sourceLineNo">354</span>            tot_wkr_final_transition_failed.sum() + tot_wkr_task_done.sum() +<a name="line.354"></a>
+<span class="sourceLineNo">355</span>            tot_wkr_preempt_task.sum()) == 0) {<a name="line.355"></a>
+<span class="sourceLineNo">356</span>          Thread.sleep(100);<a name="line.356"></a>
+<span class="sourceLineNo">357</span>          curt = System.currentTimeMillis();<a name="line.357"></a>
+<span class="sourceLineNo">358</span>        } else {<a name="line.358"></a>
+<span class="sourceLineNo">359</span>          assertTrue(1 &lt;= (tot_wkr_task_resigned.sum() + tot_wkr_task_err.sum() +<a name="line.359"></a>
+<span class="sourceLineNo">360</span>              tot_wkr_final_transition_failed.sum() + tot_wkr_task_done.sum() +<a name="line.360"></a>
+<span class="sourceLineNo">361</span>              tot_wkr_preempt_task.sum()));<a name="line.361"></a>
+<span class="sourceLineNo">362</span>          return;<a name="line.362"></a>
+<span class="sourceLineNo">363</span>        }<a name="line.363"></a>
+<span class="sourceLineNo">364</span>      }<a name="line.364"></a>
+<span class="sourceLineNo">365</span>      fail("none of the following counters went up in " + waitTime + " milliseconds - " +<a name="line.365"></a>
+<span class="sourceLineNo">366</span>          "tot_wkr_task_resigned, tot_wkr_task_err, " +<a name="line.366"></a>
+<span class="sourceLineNo">367</span>          "tot_wkr_final_transition_failed, tot_wkr_task_done, " + "tot_wkr_preempt_task");<a name="line.367"></a>
+<span class="sourceLineNo">368</span>    }<a name="line.368"></a>
+<span class="sourceLineNo">369</span>  }<a name="line.369"></a>
+<span class="sourceLineNo">370</span><a name="line.370"></a>
+<span class="sourceLineNo">371</span>  @Test<a name="line.371"></a>
+<span class="sourceLineNo">372</span>  public void testThreeRSAbort() throws Exception {<a name="line.372"></a>
+<span class="sourceLineNo">373</span>    LOG.info("testThreeRSAbort");<a name="line.373"></a>
+<span class="sourceLineNo">374</span>    int numRegionsToCreate = 40;<a name="line.374"></a>
+<span class="sourceLineNo">375</span>    int numRowsPerRegion = 100;<a name="line.375"></a>
+<span class="sourceLineNo">376</span><a name="line.376"></a>
+<span class="sourceLineNo">377</span>    startCluster(NUM_RS); // NUM_RS=6.<a name="line.377"></a>
+<span class="sourceLineNo">378</span><a name="line.378"></a>
+<span class="sourceLineNo">379</span>    try (ZKWatcher zkw = new ZKWatcher(conf, "distributed log splitting test", null);<a name="line.379"></a>
+<span class="sourceLineNo">380</span>        Table table = installTable(zkw, numRegionsToCreate)) {<a name="line.380"></a>
+<span class="sourceLineNo">381</span>      populateDataInTable(numRowsPerRegion);<a name="line.381"></a>
+<span class="sourceLineNo">382</span><a name="line.382"></a>
+<span class="sourceLineNo">383</span>      List&lt;RegionServerThread&gt; rsts = cluster.getLiveRegionServerThreads();<a name="line.383"></a>
+<span class="sourceLineNo">384</span>      assertEquals(NUM_RS, rsts.size());<a name="line.384"></a>
+<span class="sourceLineNo">385</span>      cluster.killRegionServer(rsts.get(0).getRegionServer().getServerName());<a name="line.385"></a>
+<span class="sourceLineNo">386</span>      cluster.killRegionServer(rsts.get(1).getRegionServer().getServerName());<a name="line.386"></a>
+<span class="sourceLineNo">387</span>      cluster.killRegionServer(rsts.get(2).getRegionServer().getServerName());<a name="line.387"></a>
+<span class="sourceLineNo">388</span><a name="line.388"></a>
+<span class="sourceLineNo">389</span>      TEST_UTIL.waitFor(60000, new Waiter.ExplainingPredicate&lt;Exception&gt;() {<a name="line.389"></a>
+<span class="sourceLineNo">390</span><a name="line.390"></a>
+<span class="sourceLineNo">391</span>        @Override<a name="line.391"></a>
+<span class="sourceLineNo">392</span>        public boolean evaluate() throws Exception {<a name="line.392"></a>
+<span class="sourceLineNo">393</span>          return cluster.getLiveRegionServerThreads().size() &lt;= NUM_RS - 3;<a name="line.393"></a>
+<span class="sourceLineNo">394</span>        }<a name="line.394"></a>
+<span class="sourceLineNo">395</span><a name="line.395"></a>
+<span class="sourceLineNo">396</span>        @Override<a na

<TRUNCATED>

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

Branch: refs/heads/asf-site
Commit: 2fda40d6cca74e538fd8a98c1a7fff59df3e9348
Parents: 0f5c75b
Author: jenkins <bu...@apache.org>
Authored: Mon Feb 12 15:16:46 2018 +0000
Committer: jenkins <bu...@apache.org>
Committed: Mon Feb 12 15:16:46 2018 +0000

----------------------------------------------------------------------
 acid-semantics.html                             |    4 +-
 apache_hbase_reference_guide.pdf                |    4 +-
 book.html                                       |    2 +-
 bulk-loads.html                                 |    4 +-
 checkstyle-aggregate.html                       |   38 +-
 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                 |    6 +-
 .../regionserver/ReplicationSink.html           |    6 +-
 .../org/apache/hadoop/hbase/Version.html        |    6 +-
 .../regionserver/ReplicationSink.html           |   87 +-
 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/master/AbstractTestDLS.html    |   72 +-
 .../org/apache/hadoop/hbase/package-tree.html   |   10 +-
 .../hadoop/hbase/regionserver/package-tree.html |    4 +-
 .../regionserver/TestReplicationSink.html       |   76 +-
 .../apache/hadoop/hbase/test/package-tree.html  |    4 +-
 .../apache/hadoop/hbase/wal/package-tree.html   |    2 +-
 .../hadoop/hbase/master/AbstractTestDLS.html    | 1444 +++++++++---------
 .../regionserver/TestReplicationSink.html       |  732 ++++-----
 176 files changed, 1600 insertions(+), 1533 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/acid-semantics.html
----------------------------------------------------------------------
diff --git a/acid-semantics.html b/acid-semantics.html
index a4ff67d..bccb18f 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/apache_hbase_reference_guide.pdf
----------------------------------------------------------------------
diff --git a/apache_hbase_reference_guide.pdf b/apache_hbase_reference_guide.pdf
index e7bc480..1334d2a 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:20180211144632+00'00')
-/CreationDate (D:20180211144632+00'00')
+/ModDate (D:20180212144952+00'00')
+/CreationDate (D:20180212144952+00'00')
 >>
 endobj
 2 0 obj

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/book.html
----------------------------------------------------------------------
diff --git a/book.html b/book.html
index b62e64a..399814c 100644
--- a/book.html
+++ b/book.html
@@ -37262,7 +37262,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 2018-02-11 14:29:47 UTC
+Last updated 2018-02-12 14:32:58 UTC
 </div>
 </div>
 </body>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/bulk-loads.html
----------------------------------------------------------------------
diff --git a/bulk-loads.html b/bulk-loads.html
index 004564b..84d1546 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/checkstyle-aggregate.html
----------------------------------------------------------------------
diff --git a/checkstyle-aggregate.html b/checkstyle-aggregate.html
index 525cfe4..ecc2bbd 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -62127,25 +62127,25 @@
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>310</td></tr>
+<td>311</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>blocks</td>
 <td>NeedBraces</td>
 <td>'if' construct must use '{}'s.</td>
-<td>504</td></tr>
+<td>512</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>blocks</td>
 <td>NeedBraces</td>
 <td>'if' construct must use '{}'s.</td>
-<td>505</td></tr>
+<td>513</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>blocks</td>
 <td>NeedBraces</td>
 <td>'for' construct must use '{}'s.</td>
-<td>534</td></tr></table></div>
+<td>542</td></tr></table></div>
 <div class="section">
 <h3 id="org.apache.hadoop.hbase.master.ActiveMasterManager.java">org/apache/hadoop/hbase/master/ActiveMasterManager.java</h3>
 <table border="0" class="table table-striped">
@@ -98961,13 +98961,13 @@
 <td>coding</td>
 <td>InnerAssignment</td>
 <td>Inner assignments should be avoided.</td>
-<td>426</td></tr>
+<td>427</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>JavadocTagContinuationIndentation</td>
 <td>Line continuation have incorrect indentation level, expected level should be 2.</td>
-<td>436</td></tr></table></div>
+<td>437</td></tr></table></div>
 <div class="section">
 <h3 id="org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceFactory.java">org/apache/hadoop/hbase/replication/regionserver/ReplicationSourceFactory.java</h3>
 <table border="0" class="table table-striped">
@@ -99234,67 +99234,67 @@
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>120</td></tr>
+<td>124</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>139</td></tr>
+<td>143</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>148</td></tr>
+<td>152</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>158</td></tr>
+<td>162</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>176</td></tr>
+<td>180</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>204</td></tr>
+<td>208</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>whitespace</td>
 <td>ParenPad</td>
 <td>'(' is followed by whitespace.</td>
-<td>211</td></tr>
+<td>215</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>226</td></tr>
+<td>230</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>javadoc</td>
 <td>NonEmptyAtclauseDescription</td>
 <td>At-clause should have a non-empty description.</td>
-<td>254</td></tr>
+<td>258</td></tr>
 <tr class="b">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'if' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>371</td></tr>
+<td>409</td></tr>
 <tr class="a">
 <td><img src="images/icon_error_sml.gif" alt="" />&#160;Error</td>
 <td>indentation</td>
 <td>Indentation</td>
 <td>'if' child have incorrect indentation level 8, expected level should be 6.</td>
-<td>374</td></tr></table></div>
+<td>412</td></tr></table></div>
 <div class="section">
 <h3 id="org.apache.hadoop.hbase.replication.regionserver.TestReplicationSourceManager.java">org/apache/hadoop/hbase/replication/regionserver/TestReplicationSourceManager.java</h3>
 <table border="0" class="table table-striped">
@@ -127804,7 +127804,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/coc.html
----------------------------------------------------------------------
diff --git a/coc.html b/coc.html
index 434a99c..bb8167e 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/cygwin.html
----------------------------------------------------------------------
diff --git a/cygwin.html b/cygwin.html
index 8640a38..8f2820a 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/dependencies.html
----------------------------------------------------------------------
diff --git a/dependencies.html b/dependencies.html
index fc870f9..841bd86 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/dependency-convergence.html b/dependency-convergence.html
index 580aeeb..867de6d 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -1035,7 +1035,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/dependency-info.html
----------------------------------------------------------------------
diff --git a/dependency-info.html b/dependency-info.html
index 9614106..eb96b60 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/dependency-management.html
----------------------------------------------------------------------
diff --git a/dependency-management.html b/dependency-management.html
index 4005813..2cb8f1f 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/devapidocs/constant-values.html
----------------------------------------------------------------------
diff --git a/devapidocs/constant-values.html b/devapidocs/constant-values.html
index b2a724a..95d57d6 100644
--- a/devapidocs/constant-values.html
+++ b/devapidocs/constant-values.html
@@ -3754,21 +3754,21 @@
 <!--   -->
 </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 Feb 11 14:41:14 UTC 2018"</code></td>
+<td class="colLast"><code>"Mon Feb 12 14:44:33 UTC 2018"</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>"0593dda66359dbd1ba3a06dbd12b8f2521eef6b9"</code></td>
+<td class="colLast"><code>"8ff783f76d370199b81a24c48feaad1aa980285e"</code></td>
 </tr>
 <tr class="altColor">
 <td class="colFirst"><a name="org.apache.hadoop.hbase.Version.srcChecksum">
 <!--   -->
 </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#srcChecksum">srcChecksum</a></code></td>
-<td class="colLast"><code>"a7bbcf8ce663eefc4932a368ecbd0eeb"</code></td>
+<td class="colLast"><code>"8d46e82182829863752473d418828345"</code></td>
 </tr>
 <tr class="rowColor">
 <td class="colFirst"><a name="org.apache.hadoop.hbase.Version.url">

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/devapidocs/org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.html
----------------------------------------------------------------------
diff --git a/devapidocs/org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.html b/devapidocs/org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.html
index 6381307..19d5a9c 100644
--- a/devapidocs/org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.html
+++ b/devapidocs/org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.html
@@ -635,7 +635,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>getConnection</h4>
-<pre>private&nbsp;<a href="../../../../../../org/apache/hadoop/hbase/client/Connection.html" title="interface in org.apache.hadoop.hbase.client">Connection</a>&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.html#line.419">getConnection</a>()
+<pre>private&nbsp;<a href="../../../../../../org/apache/hadoop/hbase/client/Connection.html" title="interface in org.apache.hadoop.hbase.client">Connection</a>&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.html#line.420">getConnection</a>()
                           throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
 <dl>
 <dt><span class="throwsLabel">Throws:</span></dt>
@@ -649,7 +649,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>getStats</h4>
-<pre>public&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>&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.html#line.438">getStats</a>()</pre>
+<pre>public&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>&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.html#line.439">getStats</a>()</pre>
 <div class="block">Get a string representation of this sink's metrics</div>
 <dl>
 <dt><span class="returnLabel">Returns:</span></dt>
@@ -664,7 +664,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>getSinkMetrics</h4>
-<pre>public&nbsp;<a href="../../../../../../org/apache/hadoop/hbase/replication/regionserver/MetricsSink.html" title="class in org.apache.hadoop.hbase.replication.regionserver">MetricsSink</a>&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.html#line.448">getSinkMetrics</a>()</pre>
+<pre>public&nbsp;<a href="../../../../../../org/apache/hadoop/hbase/replication/regionserver/MetricsSink.html" title="class in org.apache.hadoop.hbase.replication.regionserver">MetricsSink</a>&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.html#line.449">getSinkMetrics</a>()</pre>
 <div class="block">Get replication Sink Metrics</div>
 <dl>
 <dt><span class="returnLabel">Returns:</span></dt>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 1cc284b..091d401 100644
--- a/devapidocs/src-html/org/apache/hadoop/hbase/Version.html
+++ b/devapidocs/src-html/org/apache/hadoop/hbase/Version.html
@@ -16,11 +16,11 @@
 <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 = "0593dda66359dbd1ba3a06dbd12b8f2521eef6b9";<a name="line.11"></a>
+<span class="sourceLineNo">011</span>  public static final String revision = "8ff783f76d370199b81a24c48feaad1aa980285e";<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 Feb 11 14:41:14 UTC 2018";<a name="line.13"></a>
+<span class="sourceLineNo">013</span>  public static final String date = "Mon Feb 12 14:44:33 UTC 2018";<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 = "a7bbcf8ce663eefc4932a368ecbd0eeb";<a name="line.15"></a>
+<span class="sourceLineNo">015</span>  public static final String srcChecksum = "8d46e82182829863752473d418828345";<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/2fda40d6/devapidocs/src-html/org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.html
----------------------------------------------------------------------
diff --git a/devapidocs/src-html/org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.html b/devapidocs/src-html/org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.html
index 54f609b..3ae3ba8 100644
--- a/devapidocs/src-html/org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.html
+++ b/devapidocs/src-html/org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.html
@@ -412,51 +412,52 @@
 <span class="sourceLineNo">404</span>    } catch (RetriesExhaustedWithDetailsException rewde) {<a name="line.404"></a>
 <span class="sourceLineNo">405</span>      for (Throwable ex : rewde.getCauses()) {<a name="line.405"></a>
 <span class="sourceLineNo">406</span>        if (ex instanceof TableNotFoundException) {<a name="line.406"></a>
-<span class="sourceLineNo">407</span>          throw new TableNotFoundException("'"+tableName+"'");<a name="line.407"></a>
+<span class="sourceLineNo">407</span>          throw new TableNotFoundException("'" + tableName + "'");<a name="line.407"></a>
 <span class="sourceLineNo">408</span>        }<a name="line.408"></a>
 <span class="sourceLineNo">409</span>      }<a name="line.409"></a>
-<span class="sourceLineNo">410</span>    } catch (InterruptedException ix) {<a name="line.410"></a>
-<span class="sourceLineNo">411</span>      throw (InterruptedIOException) new InterruptedIOException().initCause(ix);<a name="line.411"></a>
-<span class="sourceLineNo">412</span>    } finally {<a name="line.412"></a>
-<span class="sourceLineNo">413</span>      if (table != null) {<a name="line.413"></a>
-<span class="sourceLineNo">414</span>        table.close();<a name="line.414"></a>
-<span class="sourceLineNo">415</span>      }<a name="line.415"></a>
-<span class="sourceLineNo">416</span>    }<a name="line.416"></a>
-<span class="sourceLineNo">417</span>  }<a name="line.417"></a>
-<span class="sourceLineNo">418</span><a name="line.418"></a>
-<span class="sourceLineNo">419</span>  private Connection getConnection() throws IOException {<a name="line.419"></a>
-<span class="sourceLineNo">420</span>    // See https://en.wikipedia.org/wiki/Double-checked_locking<a name="line.420"></a>
-<span class="sourceLineNo">421</span>    Connection connection = sharedHtableCon;<a name="line.421"></a>
-<span class="sourceLineNo">422</span>    if (connection == null) {<a name="line.422"></a>
-<span class="sourceLineNo">423</span>      synchronized (sharedHtableConLock) {<a name="line.423"></a>
-<span class="sourceLineNo">424</span>        connection = sharedHtableCon;<a name="line.424"></a>
-<span class="sourceLineNo">425</span>        if (connection == null) {<a name="line.425"></a>
-<span class="sourceLineNo">426</span>          connection = sharedHtableCon = ConnectionFactory.createConnection(conf);<a name="line.426"></a>
-<span class="sourceLineNo">427</span>        }<a name="line.427"></a>
-<span class="sourceLineNo">428</span>      }<a name="line.428"></a>
-<span class="sourceLineNo">429</span>    }<a name="line.429"></a>
-<span class="sourceLineNo">430</span>    return connection;<a name="line.430"></a>
-<span class="sourceLineNo">431</span>  }<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>   * Get a string representation of this sink's metrics<a name="line.434"></a>
-<span class="sourceLineNo">435</span>   * @return string with the total replicated edits count and the date<a name="line.435"></a>
-<span class="sourceLineNo">436</span>   * of the last edit that was applied<a name="line.436"></a>
-<span class="sourceLineNo">437</span>   */<a name="line.437"></a>
-<span class="sourceLineNo">438</span>  public String getStats() {<a name="line.438"></a>
-<span class="sourceLineNo">439</span>    return this.totalReplicatedEdits.get() == 0 ? "" : "Sink: " +<a name="line.439"></a>
-<span class="sourceLineNo">440</span>      "age in ms of last applied edit: " + this.metrics.refreshAgeOfLastAppliedOp() +<a name="line.440"></a>
-<span class="sourceLineNo">441</span>      ", total replicated edits: " + this.totalReplicatedEdits;<a name="line.441"></a>
-<span class="sourceLineNo">442</span>  }<a name="line.442"></a>
-<span class="sourceLineNo">443</span><a name="line.443"></a>
-<span class="sourceLineNo">444</span>  /**<a name="line.444"></a>
-<span class="sourceLineNo">445</span>   * Get replication Sink Metrics<a name="line.445"></a>
-<span class="sourceLineNo">446</span>   * @return MetricsSink<a name="line.446"></a>
-<span class="sourceLineNo">447</span>   */<a name="line.447"></a>
-<span class="sourceLineNo">448</span>  public MetricsSink getSinkMetrics() {<a name="line.448"></a>
-<span class="sourceLineNo">449</span>    return this.metrics;<a name="line.449"></a>
-<span class="sourceLineNo">450</span>  }<a name="line.450"></a>
-<span class="sourceLineNo">451</span>}<a name="line.451"></a>
+<span class="sourceLineNo">410</span>      throw rewde;<a name="line.410"></a>
+<span class="sourceLineNo">411</span>    } catch (InterruptedException ix) {<a name="line.411"></a>
+<span class="sourceLineNo">412</span>      throw (InterruptedIOException) new InterruptedIOException().initCause(ix);<a name="line.412"></a>
+<span class="sourceLineNo">413</span>    } finally {<a name="line.413"></a>
+<span class="sourceLineNo">414</span>      if (table != null) {<a name="line.414"></a>
+<span class="sourceLineNo">415</span>        table.close();<a name="line.415"></a>
+<span class="sourceLineNo">416</span>      }<a name="line.416"></a>
+<span class="sourceLineNo">417</span>    }<a name="line.417"></a>
+<span class="sourceLineNo">418</span>  }<a name="line.418"></a>
+<span class="sourceLineNo">419</span><a name="line.419"></a>
+<span class="sourceLineNo">420</span>  private Connection getConnection() throws IOException {<a name="line.420"></a>
+<span class="sourceLineNo">421</span>    // See https://en.wikipedia.org/wiki/Double-checked_locking<a name="line.421"></a>
+<span class="sourceLineNo">422</span>    Connection connection = sharedHtableCon;<a name="line.422"></a>
+<span class="sourceLineNo">423</span>    if (connection == null) {<a name="line.423"></a>
+<span class="sourceLineNo">424</span>      synchronized (sharedHtableConLock) {<a name="line.424"></a>
+<span class="sourceLineNo">425</span>        connection = sharedHtableCon;<a name="line.425"></a>
+<span class="sourceLineNo">426</span>        if (connection == null) {<a name="line.426"></a>
+<span class="sourceLineNo">427</span>          connection = sharedHtableCon = ConnectionFactory.createConnection(conf);<a name="line.427"></a>
+<span class="sourceLineNo">428</span>        }<a name="line.428"></a>
+<span class="sourceLineNo">429</span>      }<a name="line.429"></a>
+<span class="sourceLineNo">430</span>    }<a name="line.430"></a>
+<span class="sourceLineNo">431</span>    return connection;<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>   * Get a string representation of this sink's metrics<a name="line.435"></a>
+<span class="sourceLineNo">436</span>   * @return string with the total replicated edits count and the date<a name="line.436"></a>
+<span class="sourceLineNo">437</span>   * of the last edit that was applied<a name="line.437"></a>
+<span class="sourceLineNo">438</span>   */<a name="line.438"></a>
+<span class="sourceLineNo">439</span>  public String getStats() {<a name="line.439"></a>
+<span class="sourceLineNo">440</span>    return this.totalReplicatedEdits.get() == 0 ? "" : "Sink: " +<a name="line.440"></a>
+<span class="sourceLineNo">441</span>      "age in ms of last applied edit: " + this.metrics.refreshAgeOfLastAppliedOp() +<a name="line.441"></a>
+<span class="sourceLineNo">442</span>      ", total replicated edits: " + this.totalReplicatedEdits;<a name="line.442"></a>
+<span class="sourceLineNo">443</span>  }<a name="line.443"></a>
+<span class="sourceLineNo">444</span><a name="line.444"></a>
+<span class="sourceLineNo">445</span>  /**<a name="line.445"></a>
+<span class="sourceLineNo">446</span>   * Get replication Sink Metrics<a name="line.446"></a>
+<span class="sourceLineNo">447</span>   * @return MetricsSink<a name="line.447"></a>
+<span class="sourceLineNo">448</span>   */<a name="line.448"></a>
+<span class="sourceLineNo">449</span>  public MetricsSink getSinkMetrics() {<a name="line.449"></a>
+<span class="sourceLineNo">450</span>    return this.metrics;<a name="line.450"></a>
+<span class="sourceLineNo">451</span>  }<a name="line.451"></a>
+<span class="sourceLineNo">452</span>}<a name="line.452"></a>
 
 
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/export_control.html
----------------------------------------------------------------------
diff --git a/export_control.html b/export_control.html
index dd5888d..c4223be 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/checkstyle.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/checkstyle.html b/hbase-annotations/checkstyle.html
index bce3480..4918ca4 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependencies.html b/hbase-annotations/dependencies.html
index e754669..eee2e21 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-convergence.html b/hbase-annotations/dependency-convergence.html
index ea7372a..34b1a7c 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -865,7 +865,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-info.html b/hbase-annotations/dependency-info.html
index e54edbc..23ee051 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/dependency-management.html b/hbase-annotations/dependency-management.html
index c61f59a..50b7a57 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/index.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/index.html b/hbase-annotations/index.html
index fb2ecb0..b85f9d3 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/integration.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/integration.html b/hbase-annotations/integration.html
index 2ec48d2..085f6fd 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/issue-tracking.html b/hbase-annotations/issue-tracking.html
index 2ff23c1..dd6ed07 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/license.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/license.html b/hbase-annotations/license.html
index fabb194..0348e36 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/mail-lists.html b/hbase-annotations/mail-lists.html
index 44ef40f..b790c00 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/plugin-management.html b/hbase-annotations/plugin-management.html
index 8d5c166..d532619 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/plugins.html b/hbase-annotations/plugins.html
index 6b7cebe..e710888 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/project-info.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-info.html b/hbase-annotations/project-info.html
index 072b4b0..57ac224 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/project-reports.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-reports.html b/hbase-annotations/project-reports.html
index 73c24a1..997a721 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/project-summary.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/project-summary.html b/hbase-annotations/project-summary.html
index ab2c7f4..d54c39f 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/source-repository.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/source-repository.html b/hbase-annotations/source-repository.html
index d8e0d99..83483b4 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-annotations/team-list.html
----------------------------------------------------------------------
diff --git a/hbase-annotations/team-list.html b/hbase-annotations/team-list.html
index 12d2276..d280c0d 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -553,7 +553,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-build-configuration/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependencies.html b/hbase-build-configuration/dependencies.html
index a87cd06..24a568b 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-build-configuration/dependency-convergence.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-convergence.html b/hbase-build-configuration/dependency-convergence.html
index 49ba008..c266d6f 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -865,7 +865,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-build-configuration/dependency-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-info.html b/hbase-build-configuration/dependency-info.html
index 161b3b6..659c82c 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-build-configuration/dependency-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/dependency-management.html b/hbase-build-configuration/dependency-management.html
index 9b3dc38..28ad802 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 7619c04..be4cec4 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 425718b..011f1c0 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -865,7 +865,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 f92d4a2..f724a19 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 c327552..8ed6dbc 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 567aa49..f0ccbae 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 6610d2b..3f4b682 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -865,7 +865,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 b612652..2d9c752 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 fcc8f5b..cc9b601 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 408329a..ee8da1c 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 b7f5a38..68519eb 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 4eca79a..dbab913 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 f437ff3..1a42dfd 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 


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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/testdevapidocs/org/apache/hadoop/hbase/master/AbstractTestDLS.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/master/AbstractTestDLS.html b/testdevapidocs/org/apache/hadoop/hbase/master/AbstractTestDLS.html
index b922b2e..b48c274 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/master/AbstractTestDLS.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/master/AbstractTestDLS.html
@@ -113,7 +113,7 @@ var activeTableTab = "activeTableTab";
 </dl>
 <hr>
 <br>
-<pre>public abstract class <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.100">AbstractTestDLS</a>
+<pre>public abstract class <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.101">AbstractTestDLS</a>
 extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?is-external=true" title="class or interface in java.lang">Object</a></pre>
 <div class="block">Base class for testing distributed log splitting.</div>
 </li>
@@ -355,7 +355,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.slf4j.Logger <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.101">LOG</a></pre>
+<pre>private static final&nbsp;org.slf4j.Logger <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.102">LOG</a></pre>
 </li>
 </ul>
 <a name="TEST_UTIL">
@@ -364,7 +364,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>TEST_UTIL</h4>
-<pre>private static final&nbsp;<a href="../../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility</a> <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.103">TEST_UTIL</a></pre>
+<pre>private static final&nbsp;<a href="../../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility</a> <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.104">TEST_UTIL</a></pre>
 </li>
 </ul>
 <a name="NUM_MASTERS">
@@ -373,7 +373,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>NUM_MASTERS</h4>
-<pre>private static final&nbsp;int <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.106">NUM_MASTERS</a></pre>
+<pre>private static final&nbsp;int <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.107">NUM_MASTERS</a></pre>
 <dl>
 <dt><span class="seeLabel">See Also:</span></dt>
 <dd><a href="../../../../../constant-values.html#org.apache.hadoop.hbase.master.AbstractTestDLS.NUM_MASTERS">Constant Field Values</a></dd>
@@ -386,7 +386,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>NUM_RS</h4>
-<pre>private static final&nbsp;int <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.107">NUM_RS</a></pre>
+<pre>private static final&nbsp;int <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.108">NUM_RS</a></pre>
 <dl>
 <dt><span class="seeLabel">See Also:</span></dt>
 <dd><a href="../../../../../constant-values.html#org.apache.hadoop.hbase.master.AbstractTestDLS.NUM_RS">Constant Field Values</a></dd>
@@ -399,7 +399,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>COLUMN_FAMILY</h4>
-<pre>private static&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.108">COLUMN_FAMILY</a></pre>
+<pre>private static&nbsp;byte[] <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.109">COLUMN_FAMILY</a></pre>
 </li>
 </ul>
 <a name="testName">
@@ -408,7 +408,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testName</h4>
-<pre>public&nbsp;org.junit.rules.TestName <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.111">testName</a></pre>
+<pre>public&nbsp;org.junit.rules.TestName <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.112">testName</a></pre>
 </li>
 </ul>
 <a name="tableName">
@@ -417,7 +417,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&nbsp;org.apache.hadoop.hbase.TableName <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.113">tableName</a></pre>
+<pre>private&nbsp;org.apache.hadoop.hbase.TableName <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.114">tableName</a></pre>
 </li>
 </ul>
 <a name="cluster">
@@ -426,7 +426,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>cluster</h4>
-<pre>private&nbsp;<a href="../../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a> <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.114">cluster</a></pre>
+<pre>private&nbsp;<a href="../../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a> <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.115">cluster</a></pre>
 </li>
 </ul>
 <a name="master">
@@ -435,7 +435,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>master</h4>
-<pre>private&nbsp;org.apache.hadoop.hbase.master.HMaster <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.115">master</a></pre>
+<pre>private&nbsp;org.apache.hadoop.hbase.master.HMaster <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.116">master</a></pre>
 </li>
 </ul>
 <a name="conf">
@@ -444,7 +444,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>conf</h4>
-<pre>private&nbsp;org.apache.hadoop.conf.Configuration <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.116">conf</a></pre>
+<pre>private&nbsp;org.apache.hadoop.conf.Configuration <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.117">conf</a></pre>
 </li>
 </ul>
 <a name="name">
@@ -453,7 +453,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>name</h4>
-<pre>public&nbsp;org.junit.rules.TestName <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.119">name</a></pre>
+<pre>public&nbsp;org.junit.rules.TestName <a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.120">name</a></pre>
 </li>
 </ul>
 </li>
@@ -470,7 +470,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>AbstractTestDLS</h4>
-<pre>public&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.100">AbstractTestDLS</a>()</pre>
+<pre>public&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.101">AbstractTestDLS</a>()</pre>
 </li>
 </ul>
 </li>
@@ -487,7 +487,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 static&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.122">setup</a>()
+<pre>public static&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.123">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>
@@ -501,7 +501,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 static&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.131">tearDown</a>()
+<pre>public static&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.132">tearDown</a>()
                      throws <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
 <dl>
 <dt><span class="throwsLabel">Throws:</span></dt>
@@ -515,7 +515,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>getWalProvider</h4>
-<pre>protected abstract&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>&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.135">getWalProvider</a>()</pre>
+<pre>protected abstract&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>&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.136">getWalProvider</a>()</pre>
 </li>
 </ul>
 <a name="startCluster-int-">
@@ -524,7 +524,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>startCluster</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.137">startCluster</a>(int&nbsp;numRS)
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.138">startCluster</a>(int&nbsp;numRS)
                    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>
@@ -538,7 +538,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>before</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.162">before</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.163">before</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>
@@ -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>after</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.168">after</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.169">after</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>
@@ -566,7 +566,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testRecoveredEdits</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.175">testRecoveredEdits</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.176">testRecoveredEdits</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>
@@ -580,7 +580,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testMasterStartsUpWithLogSplittingWork</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.254">testMasterStartsUpWithLogSplittingWork</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.255">testMasterStartsUpWithLogSplittingWork</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>
@@ -594,7 +594,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testWorkerAbort</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.314">testWorkerAbort</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.315">testWorkerAbort</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">The original intention of this test was to force an abort of a region server and to make sure
  that the failure path in the region servers is properly evaluated. But it is difficult to
@@ -613,7 +613,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testThreeRSAbort</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.371">testThreeRSAbort</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.372">testThreeRSAbort</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>
@@ -627,7 +627,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testDelayedDeleteOnFailure</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.406">testDelayedDeleteOnFailure</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.414">testDelayedDeleteOnFailure</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>
@@ -641,7 +641,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testReadWriteSeqIdFiles</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.474">testReadWriteSeqIdFiles</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.482">testReadWriteSeqIdFiles</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>
@@ -655,7 +655,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>installTable</h4>
-<pre>private&nbsp;org.apache.hadoop.hbase.client.Table&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.509">installTable</a>(org.apache.hadoop.hbase.zookeeper.ZKWatcher&nbsp;zkw,
+<pre>private&nbsp;org.apache.hadoop.hbase.client.Table&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.517">installTable</a>(org.apache.hadoop.hbase.zookeeper.ZKWatcher&nbsp;zkw,
                                                           int&nbsp;nrs)
                                                    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>
@@ -670,7 +670,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>installTable</h4>
-<pre>private&nbsp;org.apache.hadoop.hbase.client.Table&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.513">installTable</a>(org.apache.hadoop.hbase.zookeeper.ZKWatcher&nbsp;zkw,
+<pre>private&nbsp;org.apache.hadoop.hbase.client.Table&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.521">installTable</a>(org.apache.hadoop.hbase.zookeeper.ZKWatcher&nbsp;zkw,
                                                           int&nbsp;nrs,
                                                           int&nbsp;existingRegions)
                                                    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>
@@ -686,7 +686,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>populateDataInTable</h4>
-<pre>void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.548">populateDataInTable</a>(int&nbsp;nrows)
+<pre>void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.556">populateDataInTable</a>(int&nbsp;nrows)
                   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>
@@ -700,7 +700,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>makeWAL</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.589">makeWAL</a>(org.apache.hadoop.hbase.regionserver.HRegionServer&nbsp;hrs,
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.597">makeWAL</a>(org.apache.hadoop.hbase.regionserver.HRegionServer&nbsp;hrs,
                     <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.client.RegionInfo&gt;&nbsp;regions,
                     int&nbsp;num_edits,
                     int&nbsp;edit_size)
@@ -717,7 +717,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>makeWAL</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.594">makeWAL</a>(org.apache.hadoop.hbase.regionserver.HRegionServer&nbsp;hrs,
+<pre>public&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.602">makeWAL</a>(org.apache.hadoop.hbase.regionserver.HRegionServer&nbsp;hrs,
                     <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.client.RegionInfo&gt;&nbsp;regions,
                     int&nbsp;numEdits,
                     int&nbsp;editSize,
@@ -735,7 +735,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>countWAL</h4>
-<pre>private&nbsp;int&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.664">countWAL</a>(org.apache.hadoop.fs.Path&nbsp;log,
+<pre>private&nbsp;int&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.672">countWAL</a>(org.apache.hadoop.fs.Path&nbsp;log,
                      org.apache.hadoop.fs.FileSystem&nbsp;fs,
                      org.apache.hadoop.conf.Configuration&nbsp;conf)
               throws <a href="http://docs.oracle.com/javase/8/docs/api/java/io/IOException.html?is-external=true" title="class or interface in java.io">IOException</a></pre>
@@ -751,7 +751,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>blockUntilNoRIT</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.677">blockUntilNoRIT</a>(org.apache.hadoop.hbase.zookeeper.ZKWatcher&nbsp;zkw,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.685">blockUntilNoRIT</a>(org.apache.hadoop.hbase.zookeeper.ZKWatcher&nbsp;zkw,
                              org.apache.hadoop.hbase.master.HMaster&nbsp;master)
                       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>
@@ -766,7 +766,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>putData</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.681">putData</a>(org.apache.hadoop.hbase.regionserver.Region&nbsp;region,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.689">putData</a>(org.apache.hadoop.hbase.regionserver.Region&nbsp;region,
                      byte[]&nbsp;startRow,
                      int&nbsp;numRows,
                      byte[]&nbsp;qf,
@@ -784,7 +784,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>waitForCounter</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.692">waitForCounter</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/util/concurrent/atomic/LongAdder.html?is-external=true" title="class or interface in java.util.concurrent.atomic">LongAdder</a>&nbsp;ctr,
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.700">waitForCounter</a>(<a href="http://docs.oracle.com/javase/8/docs/api/java/util/concurrent/atomic/LongAdder.html?is-external=true" title="class or interface in java.util.concurrent.atomic">LongAdder</a>&nbsp;ctr,
                             long&nbsp;oldval,
                             long&nbsp;newval,
                             long&nbsp;timems)
@@ -801,7 +801,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>abortMaster</h4>
-<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.708">abortMaster</a>(<a href="../../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a>&nbsp;cluster)
+<pre>private&nbsp;void&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.716">abortMaster</a>(<a href="../../../../../org/apache/hadoop/hbase/MiniHBaseCluster.html" title="class in org.apache.hadoop.hbase">MiniHBaseCluster</a>&nbsp;cluster)
                   throws <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/InterruptedException.html?is-external=true" title="class or interface in java.lang">InterruptedException</a></pre>
 <dl>
 <dt><span class="throwsLabel">Throws:</span></dt>
@@ -815,7 +815,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>findRSToKill</h4>
-<pre>private&nbsp;org.apache.hadoop.hbase.regionserver.HRegionServer&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.723">findRSToKill</a>(boolean&nbsp;hasMetaRegion)
+<pre>private&nbsp;org.apache.hadoop.hbase.regionserver.HRegionServer&nbsp;<a href="../../../../../src-html/org/apache/hadoop/hbase/master/AbstractTestDLS.html#line.731">findRSToKill</a>(boolean&nbsp;hasMetaRegion)
                                                                  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">Find a RS that has regions of a table.</div>
 <dl>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 313cf5f..cff8267 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/package-tree.html
@@ -573,15 +573,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/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/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/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/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/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.RoleCommand.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">RESTApiClusterManager.RoleCommand</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/ClusterManager.ServiceType.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">ClusterManager.ServiceType</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/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/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/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/ScanPerformanceEvaluation.ScanCounter.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">ScanPerformanceEvaluation.ScanCounter</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.<a href="../../../../org/apache/hadoop/hbase/RESTApiClusterManager.Service.html" title="enum in org.apache.hadoop.hbase"><span class="typeNameLink">RESTApiClusterManager.Service</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 ee5d159..1a3d547 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/regionserver/package-tree.html
@@ -651,11 +651,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/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/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/DataBlockEncodingTool.Manipulation.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">DataBlockEncodingTool.Manipulation</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/TestAtomicOperation.TestStep.html" title="enum in org.apache.hadoop.hbase.regionserver"><span class="typeNameLink">TestAtomicOperation.TestStep</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.regionserver.<a href="../../../../../org/apache/hadoop/hbase/regionserver/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/2fda40d6/testdevapidocs/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html b/testdevapidocs/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html
index 0213c7d..c57c81b 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html
@@ -18,7 +18,7 @@
     catch(err) {
     }
 //-->
-var methods = {"i0":10,"i1":10,"i2":10,"i3":9,"i4":9,"i5":10,"i6":10,"i7":10,"i8":10,"i9":10,"i10":10};
+var methods = {"i0":10,"i1":10,"i2":10,"i3":9,"i4":9,"i5":10,"i6":10,"i7":10,"i8":10,"i9":10,"i10":10,"i11":10};
 var tabs = {65535:["t0","All Methods"],1:["t1","Static Methods"],2:["t2","Instance Methods"],8:["t4","Concrete Methods"]};
 var altColor = "altColor";
 var rowColor = "rowColor";
@@ -109,7 +109,7 @@ var activeTableTab = "activeTableTab";
 <li class="blockList">
 <hr>
 <br>
-<pre>public class <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.78">TestReplicationSink</a>
+<pre>public class <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.82">TestReplicationSink</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>
@@ -281,6 +281,10 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <div class="block">Test replicateEntries with a bulk load entry for 25 HFiles</div>
 </td>
 </tr>
+<tr id="i11" class="rowColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><span class="memberNameLink"><a href="../../../../../../org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#testRethrowRetriesExhaustedWithDetailsException--">testRethrowRetriesExhaustedWithDetailsException</a></span>()</code>&nbsp;</td>
+</tr>
 </table>
 <ul class="blockList">
 <li class="blockList"><a name="methods.inherited.from.class.java.lang.Object">
@@ -309,7 +313,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>CLASS_RULE</h4>
-<pre>public static final&nbsp;<a href="../../../../../../org/apache/hadoop/hbase/HBaseClassTestRule.html" title="class in org.apache.hadoop.hbase">HBaseClassTestRule</a> <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.81">CLASS_RULE</a></pre>
+<pre>public static final&nbsp;<a href="../../../../../../org/apache/hadoop/hbase/HBaseClassTestRule.html" title="class in org.apache.hadoop.hbase">HBaseClassTestRule</a> <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.85">CLASS_RULE</a></pre>
 </li>
 </ul>
 <a name="LOG">
@@ -318,7 +322,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.slf4j.Logger <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.84">LOG</a></pre>
+<pre>private static final&nbsp;org.slf4j.Logger <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.88">LOG</a></pre>
 </li>
 </ul>
 <a name="BATCH_SIZE">
@@ -327,7 +331,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>BATCH_SIZE</h4>
-<pre>private static final&nbsp;int <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.85">BATCH_SIZE</a></pre>
+<pre>private static final&nbsp;int <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.89">BATCH_SIZE</a></pre>
 <dl>
 <dt><span class="seeLabel">See Also:</span></dt>
 <dd><a href="../../../../../../constant-values.html#org.apache.hadoop.hbase.replication.regionserver.TestReplicationSink.BATCH_SIZE">Constant Field Values</a></dd>
@@ -340,7 +344,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>TEST_UTIL</h4>
-<pre>protected static final&nbsp;<a href="../../../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility</a> <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.87">TEST_UTIL</a></pre>
+<pre>protected static final&nbsp;<a href="../../../../../../org/apache/hadoop/hbase/HBaseTestingUtility.html" title="class in org.apache.hadoop.hbase">HBaseTestingUtility</a> <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.91">TEST_UTIL</a></pre>
 </li>
 </ul>
 <a name="SINK">
@@ -349,7 +353,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>SINK</h4>
-<pre>protected static&nbsp;org.apache.hadoop.hbase.replication.regionserver.ReplicationSink <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.89">SINK</a></pre>
+<pre>protected static&nbsp;org.apache.hadoop.hbase.replication.regionserver.ReplicationSink <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.93">SINK</a></pre>
 </li>
 </ul>
 <a name="TABLE_NAME1">
@@ -358,7 +362,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>TABLE_NAME1</h4>
-<pre>protected static final&nbsp;org.apache.hadoop.hbase.TableName <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.91">TABLE_NAME1</a></pre>
+<pre>protected static final&nbsp;org.apache.hadoop.hbase.TableName <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.95">TABLE_NAME1</a></pre>
 </li>
 </ul>
 <a name="TABLE_NAME2">
@@ -367,7 +371,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>TABLE_NAME2</h4>
-<pre>protected static final&nbsp;org.apache.hadoop.hbase.TableName <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.92">TABLE_NAME2</a></pre>
+<pre>protected static final&nbsp;org.apache.hadoop.hbase.TableName <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.96">TABLE_NAME2</a></pre>
 </li>
 </ul>
 <a name="FAM_NAME1">
@@ -376,7 +380,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>FAM_NAME1</h4>
-<pre>protected static final&nbsp;byte[] <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.94">FAM_NAME1</a></pre>
+<pre>protected static final&nbsp;byte[] <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.98">FAM_NAME1</a></pre>
 </li>
 </ul>
 <a name="FAM_NAME2">
@@ -385,7 +389,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>FAM_NAME2</h4>
-<pre>protected static final&nbsp;byte[] <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.95">FAM_NAME2</a></pre>
+<pre>protected static final&nbsp;byte[] <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.99">FAM_NAME2</a></pre>
 </li>
 </ul>
 <a name="table1">
@@ -394,7 +398,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>table1</h4>
-<pre>protected static&nbsp;org.apache.hadoop.hbase.client.Table <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.97">table1</a></pre>
+<pre>protected static&nbsp;org.apache.hadoop.hbase.client.Table <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.101">table1</a></pre>
 </li>
 </ul>
 <a name="STOPPABLE">
@@ -403,7 +407,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>STOPPABLE</h4>
-<pre>protected static&nbsp;org.apache.hadoop.hbase.Stoppable <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.98">STOPPABLE</a></pre>
+<pre>protected static&nbsp;org.apache.hadoop.hbase.Stoppable <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.102">STOPPABLE</a></pre>
 </li>
 </ul>
 <a name="table2">
@@ -412,7 +416,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>table2</h4>
-<pre>protected static&nbsp;org.apache.hadoop.hbase.client.Table <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.114">table2</a></pre>
+<pre>protected static&nbsp;org.apache.hadoop.hbase.client.Table <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.118">table2</a></pre>
 </li>
 </ul>
 <a name="baseNamespaceDir">
@@ -421,7 +425,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>baseNamespaceDir</h4>
-<pre>protected static&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> <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.115">baseNamespaceDir</a></pre>
+<pre>protected static&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> <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.119">baseNamespaceDir</a></pre>
 </li>
 </ul>
 <a name="hfileArchiveDir">
@@ -430,7 +434,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>hfileArchiveDir</h4>
-<pre>protected static&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> <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.116">hfileArchiveDir</a></pre>
+<pre>protected static&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> <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.120">hfileArchiveDir</a></pre>
 </li>
 </ul>
 <a name="replicationClusterId">
@@ -439,7 +443,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>replicationClusterId</h4>
-<pre>protected static&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> <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.117">replicationClusterId</a></pre>
+<pre>protected static&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> <a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.121">replicationClusterId</a></pre>
 </li>
 </ul>
 </li>
@@ -456,7 +460,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>TestReplicationSink</h4>
-<pre>public&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.78">TestReplicationSink</a>()</pre>
+<pre>public&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.82">TestReplicationSink</a>()</pre>
 </li>
 </ul>
 </li>
@@ -473,7 +477,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>setUpBeforeClass</h4>
-<pre>public static&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.123">setUpBeforeClass</a>()
+<pre>public static&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.127">setUpBeforeClass</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>
@@ -487,7 +491,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>tearDownAfterClass</h4>
-<pre>public static&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.142">tearDownAfterClass</a>()
+<pre>public static&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.146">tearDownAfterClass</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>
@@ -501,7 +505,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/regionserver/TestReplicationSink.html#line.151">setUp</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.155">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>
@@ -515,7 +519,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testBatchSink</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.161">testBatchSink</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.165">testBatchSink</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">Insert a whole batch of entries</div>
 <dl>
@@ -530,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>testMixedPutDelete</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.179">testMixedPutDelete</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.183">testMixedPutDelete</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">Insert a mix of puts and deletes</div>
 <dl>
@@ -545,7 +549,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testMixedPutTables</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.207">testMixedPutTables</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.211">testMixedPutTables</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">Insert to 2 different tables</div>
 <dl>
@@ -560,7 +564,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>testMixedDeletes</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.229">testMixedDeletes</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.233">testMixedDeletes</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">Insert then do different types of deletes</div>
 <dl>
@@ -575,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>testApplyDeleteBeforePut</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.257">testApplyDeleteBeforePut</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.261">testApplyDeleteBeforePut</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">Puts are buffered, but this tests when a delete (not-buffered) is applied
  before the actual Put that creates it.</div>
@@ -585,13 +589,27 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 </dl>
 </li>
 </ul>
+<a name="testRethrowRetriesExhaustedWithDetailsException--">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testRethrowRetriesExhaustedWithDetailsException</h4>
+<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.279">testRethrowRetriesExhaustedWithDetailsException</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>
+<dd><code><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></code></dd>
+</dl>
+</li>
+</ul>
 <a name="testReplicateEntriesForHFiles--">
 <!--   -->
 </a>
 <ul class="blockList">
 <li class="blockList">
 <h4>testReplicateEntriesForHFiles</h4>
-<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.278">testReplicateEntriesForHFiles</a>()
+<pre>public&nbsp;void&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.316">testReplicateEntriesForHFiles</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">Test replicateEntries with a bulk load entry for 25 HFiles</div>
 <dl>
@@ -606,7 +624,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockList">
 <li class="blockList">
 <h4>createEntry</h4>
-<pre>private&nbsp;org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.355">createEntry</a>(org.apache.hadoop.hbase.TableName&nbsp;table,
+<pre>private&nbsp;org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.393">createEntry</a>(org.apache.hadoop.hbase.TableName&nbsp;table,
                                                                                            int&nbsp;row,
                                                                                            org.apache.hadoop.hbase.KeyValue.Type&nbsp;type,
                                                                                            <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;cells)</pre>
@@ -618,7 +636,7 @@ extends <a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Object.html?
 <ul class="blockListLast">
 <li class="blockList">
 <h4>createWALEntryBuilder</h4>
-<pre>private&nbsp;org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry.Builder&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.383">createWALEntryBuilder</a>(org.apache.hadoop.hbase.TableName&nbsp;table)</pre>
+<pre>private&nbsp;org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.WALEntry.Builder&nbsp;<a href="../../../../../../src-html/org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#line.421">createWALEntryBuilder</a>(org.apache.hadoop.hbase.TableName&nbsp;table)</pre>
 </li>
 </ul>
 </li>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 eb297ed..eac75aa 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/test/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/test/package-tree.html
@@ -253,9 +253,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.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/IntegrationTestLoadAndVerify.Counters.html" title="enum in org.apache.hadoop.hbase.test"><span class="typeNameLink">IntegrationTestLoadAndVerify.Counters</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.test.<a href="../../../../../org/apache/hadoop/hbase/test/IntegrationTestBigLinkedList.Verify.Counts.html" title="enum in org.apache.hadoop.hbase.test"><span class="typeNameLink">IntegrationTestBigLinkedList.Verify.Counts</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.test.<a href="../../../../../org/apache/hadoop/hbase/test/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/IntegrationTestWithCellVisibilityLoadAndVerify.Counters.html" title="enum in org.apache.hadoop.hbase.test"><span class="typeNameLink">IntegrationTestWithCellVisibilityLoadAndVerify.Counters</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.test.<a href="../../../../../org/apache/hadoop/hbase/test/IntegrationTestBigLinkedList.Generator.Counts.html" title="enum in org.apache.hadoop.hbase.test"><span class="typeNameLink">IntegrationTestBigLinkedList.Generator.Counts</span></a></li>
 </ul>
 </li>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 c0134a2..9911b91 100644
--- a/testdevapidocs/org/apache/hadoop/hbase/wal/package-tree.html
+++ b/testdevapidocs/org/apache/hadoop/hbase/wal/package-tree.html
@@ -138,8 +138,8 @@
 <li type="circle">java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Enum.html?is-external=true" title="class or interface in java.lang"><span class="typeNameLink">Enum</span></a>&lt;E&gt; (implements java.lang.<a href="http://docs.oracle.com/javase/8/docs/api/java/lang/Comparable.html?is-external=true" title="class or interface in java.lang">Comparable</a>&lt;T&gt;, java.io.<a href="http://docs.oracle.com/javase/8/docs/api/java/io/Serializable.html?is-external=true" title="class or interface in java.io">Serializable</a>)
 <ul>
 <li type="circle">org.apache.hadoop.hbase.wal.<a href="../../../../../org/apache/hadoop/hbase/wal/FaultyFSLog.FailureType.html" title="enum in org.apache.hadoop.hbase.wal"><span class="typeNameLink">FaultyFSLog.FailureType</span></a></li>
-<li type="circle">org.apache.hadoop.hbase.wal.<a href="../../../../../org/apache/hadoop/hbase/wal/TestWALSplit.Corruptions.html" title="enum in org.apache.hadoop.hbase.wal"><span class="typeNameLink">TestWALSplit.Corruptions</span></a></li>
 <li type="circle">org.apache.hadoop.hbase.wal.<a href="../../../../../org/apache/hadoop/hbase/wal/IOTestProvider.AllowedOperations.html" title="enum in org.apache.hadoop.hbase.wal"><span class="typeNameLink">IOTestProvider.AllowedOperations</span></a></li>
+<li type="circle">org.apache.hadoop.hbase.wal.<a href="../../../../../org/apache/hadoop/hbase/wal/TestWALSplit.Corruptions.html" title="enum in org.apache.hadoop.hbase.wal"><span class="typeNameLink">TestWALSplit.Corruptions</span></a></li>
 </ul>
 </li>
 </ul>


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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 e81ea2b..2b78475 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 062cd3f..95d48ce 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 5bc60c3..0b5ceef 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 cdc540a..8ee1c42 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 ec25da4..62a5962 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 5843b63..3c2180c 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 a7b45d4..426b519 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 bd8821d..fe7b281 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -553,7 +553,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-build-configuration/index.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/index.html b/hbase-build-configuration/index.html
index 9dbd57c..b28f26e 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-build-configuration/integration.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/integration.html b/hbase-build-configuration/integration.html
index b23a645..e720592 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-build-configuration/issue-tracking.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/issue-tracking.html b/hbase-build-configuration/issue-tracking.html
index a0c4ff2..521d0b5 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-build-configuration/license.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/license.html b/hbase-build-configuration/license.html
index 5c13d13..86da734 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-build-configuration/mail-lists.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/mail-lists.html b/hbase-build-configuration/mail-lists.html
index f262dd1..71cdb38 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-build-configuration/plugin-management.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/plugin-management.html b/hbase-build-configuration/plugin-management.html
index 16e9bfb..5dfc21b 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-build-configuration/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/plugins.html b/hbase-build-configuration/plugins.html
index 7e933b1..7b3d45c 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-build-configuration/project-info.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/project-info.html b/hbase-build-configuration/project-info.html
index 654f2c7..f305019 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-build-configuration/project-summary.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/project-summary.html b/hbase-build-configuration/project-summary.html
index 59200f1..8e2f231 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-build-configuration/source-repository.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/source-repository.html b/hbase-build-configuration/source-repository.html
index 8afe3d3..8047c08 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-build-configuration/team-list.html
----------------------------------------------------------------------
diff --git a/hbase-build-configuration/team-list.html b/hbase-build-configuration/team-list.html
index eccf4ba..276bd21 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -553,7 +553,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-shaded-check-invariants/checkstyle.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/checkstyle.html b/hbase-shaded-check-invariants/checkstyle.html
index 093428d..1202e61 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-shaded-check-invariants/dependencies.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/dependencies.html b/hbase-shaded-check-invariants/dependencies.html
index 4ef169d..1e1480e 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 07e84e2..82d94cf 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -865,7 +865,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 8ed7014..151be4e 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 db196b7..48070ff 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-shaded-check-invariants/index.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/index.html b/hbase-shaded-check-invariants/index.html
index d72be8b..979cb37 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-shaded-check-invariants/integration.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/integration.html b/hbase-shaded-check-invariants/integration.html
index 3aab4e5..c86e559 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 8d92b21..2522bb7 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-shaded-check-invariants/license.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/license.html b/hbase-shaded-check-invariants/license.html
index 6855312..475287d 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 452a92e..5cdfa84 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 b88ccdf..1d3d3e8 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/hbase-shaded-check-invariants/plugins.html
----------------------------------------------------------------------
diff --git a/hbase-shaded-check-invariants/plugins.html b/hbase-shaded-check-invariants/plugins.html
index f147a02..3e1dc66 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 7b7cbc9..9dd0c63 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 dba1f66..7c525b7 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 aee5f87..297b9f4 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 8ed6dca..f580a93 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 2e2e9df..4b55c65 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -553,7 +553,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/index.html
----------------------------------------------------------------------
diff --git a/index.html b/index.html
index 1f5ee2a..8bbc519 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/integration.html
----------------------------------------------------------------------
diff --git a/integration.html b/integration.html
index f76b64e..97794ac 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/issue-tracking.html
----------------------------------------------------------------------
diff --git a/issue-tracking.html b/issue-tracking.html
index 4d58408..f4e126b 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/license.html
----------------------------------------------------------------------
diff --git a/license.html b/license.html
index 4dd7fbb..b9f6c05 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/mail-lists.html
----------------------------------------------------------------------
diff --git a/mail-lists.html b/mail-lists.html
index 6d818a7..37bc706 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/metrics.html
----------------------------------------------------------------------
diff --git a/metrics.html b/metrics.html
index 64b590a..a25d412 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/old_news.html
----------------------------------------------------------------------
diff --git a/old_news.html b/old_news.html
index 0472562..73ae4b2 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/plugin-management.html
----------------------------------------------------------------------
diff --git a/plugin-management.html b/plugin-management.html
index 035b73f..901af6d 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/plugins.html
----------------------------------------------------------------------
diff --git a/plugins.html b/plugins.html
index af8d0bf..83ea498 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/poweredbyhbase.html
----------------------------------------------------------------------
diff --git a/poweredbyhbase.html b/poweredbyhbase.html
index b6a9be0..fab0ebd 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/project-info.html
----------------------------------------------------------------------
diff --git a/project-info.html b/project-info.html
index c376e03..1aa5348 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/project-reports.html
----------------------------------------------------------------------
diff --git a/project-reports.html b/project-reports.html
index 80eb540..5c54a08 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/project-summary.html
----------------------------------------------------------------------
diff --git a/project-summary.html b/project-summary.html
index 4f12b00..bb433f3 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/pseudo-distributed.html
----------------------------------------------------------------------
diff --git a/pseudo-distributed.html b/pseudo-distributed.html
index e02f1c6..6a51f42 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/replication.html
----------------------------------------------------------------------
diff --git a/replication.html b/replication.html
index 764d480..0ce216d 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/resources.html
----------------------------------------------------------------------
diff --git a/resources.html b/resources.html
index 2ff36f6..f16ce7b 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/source-repository.html
----------------------------------------------------------------------
diff --git a/source-repository.html b/source-repository.html
index 527d8a6..72be6d1 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/sponsors.html
----------------------------------------------------------------------
diff --git a/sponsors.html b/sponsors.html
index 5a283e0..ba275e3 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/supportingprojects.html
----------------------------------------------------------------------
diff --git a/supportingprojects.html b/supportingprojects.html
index aa2f51e..a6d74bd 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/team-list.html
----------------------------------------------------------------------
diff --git a/team-list.html b/team-list.html
index e5a75d5..f6e1fda 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -723,7 +723,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/testdevapidocs/index-all.html
----------------------------------------------------------------------
diff --git a/testdevapidocs/index-all.html b/testdevapidocs/index-all.html
index 91a7a41..a6b47ae 100644
--- a/testdevapidocs/index-all.html
+++ b/testdevapidocs/index-all.html
@@ -56663,6 +56663,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/regionserver/TestDefaultMemStore.html#testRetainsDeleteVersion--">testRetainsDeleteVersion()</a></span> - Method in class org.apache.hadoop.hbase.regionserver.<a href="org/apache/hadoop/hbase/regionserver/TestDefaultMemStore.html" title="class in org.apache.hadoop.hbase.regionserver">TestDefaultMemStore</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html#testRethrowRetriesExhaustedWithDetailsException--">testRethrowRetriesExhaustedWithDetailsException()</a></span> - Method in class org.apache.hadoop.hbase.replication.regionserver.<a href="org/apache/hadoop/hbase/replication/regionserver/TestReplicationSink.html" title="class in org.apache.hadoop.hbase.replication.regionserver">TestReplicationSink</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="memberNameLink"><a href="org/apache/hadoop/hbase/master/assignment/TestAssignmentManager.html#testRetriesExhaustedFailure-org.apache.hadoop.hbase.TableName-org.apache.hadoop.hbase.master.assignment.TestAssignmentManager.MockRSExecutor-">testRetriesExhaustedFailure(TableName, TestAssignmentManager.MockRSExecutor)</a></span> - Method in class org.apache.hadoop.hbase.master.assignment.<a href="org/apache/hadoop/hbase/master/assignment/TestAssignmentManager.html" title="class in org.apache.hadoop.hbase.master.assignment">TestAssignmentManager</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="org/apache/hadoop/hbase/client/TestRetriesExhaustedWithDetailsException.html" title="class in org.apache.hadoop.hbase.client"><span class="typeNameLink">TestRetriesExhaustedWithDetailsException</span></a> - Class in <a href="org/apache/hadoop/hbase/client/package-summary.html">org.apache.hadoop.hbase.client</a></dt>

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 dc2a8e8..3630ba9 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>


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

Posted by gi...@apache.org.
http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 d46d5a4..eb8456d 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 06713e5..b301714 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 d7f9e4a..20d629a 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 d73be3e..09e7bd5 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 a6012db..e6b4007 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 406d985..1019026 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 bc80d3f..ab22c15 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -553,7 +553,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 f20bdb9..032a622 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 c03633b..117884d 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-client archetype &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -4144,7 +4144,7 @@ The following provides more details on the included cryptographic software:
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 eecb7ff..ac480f8 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -865,7 +865,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 f2dcd41..6d49e44 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 1f2cb49..aaa5e6c 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 5b5ca54..9055f4a 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 c66f38f..3a76821 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 82e2daa..a06a9d8 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 261e00b..4b85077 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 e1e3613..20bcc1a 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 538609b..90c72a4 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 41a4da3..3d386fb 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 3dcb80d..6371ce7 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 e19373e..a329936 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 b7766ae..b31b743 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 f787e2b..c1bb5e9 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 e6b78c3..f7cf62a 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -553,7 +553,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 4bcfe52..cbb3d44 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 ec73064..213104c 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <meta http-equiv="Content-Language" content="en" />
     <title>Apache HBase - Exemplar for hbase-shaded-client archetype &#x2013; Project Dependencies</title>
     <link rel="stylesheet" href="./css/apache-maven-fluido-1.5-HBASE.min.css" />
@@ -4169,7 +4169,7 @@ built on Jackson JSON processor</p>
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 7454051..838ee03 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -865,7 +865,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 70a480c..eff09a3 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 7c247fa..ea41c17 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 4b74e81..cce64a1 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 36f5c03..1d24554 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 2a6e077..4282848 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 2f85e79..a80623b 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 bdf42bc..000b7a4 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 154cbfd..7324cdd 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 79f6897..9804fcd 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 c9dbcf3..b6aee60 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 ff50796..75d1721 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 c40197a..1fa5f63 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 0061bce..dcbf86c 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 6b70d7a..22e5787 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -553,7 +553,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 df3358e..3feb3e1 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 dc8e0a8..104d807 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 026e2d5..3af38a9 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 7431f80..968a22e 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 7bb42be..4d1b8c3 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 a3bf5bc..c1ab8a7 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 01146ca..33cf28c 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 6c4f9d4..628e196 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 5b446b9..3a490d6 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 8eaea7e..5bca204 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 d31a88f..332331b 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -553,7 +553,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 f39f019..26f23a6 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 1e1dbcb..3712288 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 3a742b4..d5b74db 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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" />
@@ -865,7 +865,7 @@
                         <a href="https://www.apache.org/">The Apache Software Foundation</a>.
             All rights reserved.      
                     
-                  <li id="publishDate" class="pull-right">Last Published: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 7103639..a4071fb 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 8a5f859..c779ace 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 63730e4..5d297b0 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 bb5c9e8..9e99c04 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 e53deb7..a684291 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>
 

http://git-wip-us.apache.org/repos/asf/hbase-site/blob/2fda40d6/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 d83c519..652b765 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="20180211" />
+    <meta name="Date-Revision-yyyymmdd" content="20180212" />
     <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: 2018-02-11</li>
+                  <li id="publishDate" class="pull-right">Last Published: 2018-02-12</li>
             </p>
                 </div>